ClickHouse/docs/changelogs/v24.7.1.2915-stable.md

99 KiB

sidebar_position sidebar_label
1 2024

2024 Changelog

ClickHouse release v24.7.1.2915-stable (a37d2d43da) FIXME as compared to v24.7.1.1-new (aa023477a9)

Backward Incompatible Change

  • Change binary serialization of Variant data type: add compact mode to avoid writing the same discriminator multiple times for granules with single variant or with only NULL values. Add MergeTree setting use_compact_variant_discriminators_serialization that is enabled by default. Note that Variant type is still experimental and backward-incompatible change in serialization is ok. #62774 (Kruglov Pavel).
  • Forbid CREATE MATERIALIZED VIEW ... ENGINE Replicated*MergeTree POPULATE AS SELECT ... with Replicated databases. #63963 (vdimir).
  • clickhouse-keeper-client will only accept paths in string literals, such as ls '/hello/world', not bare strings such as ls /hello/world. #65494 (Alexey Milovidov).
  • Metric KeeperOutstandingRequets was renamed to KeeperOutstandingRequests. This fixes a typo reported in #66179. #66206 (Robert Schulze).
  • Remove is_deterministic field from the system.functions table. #66630 (Alexey Milovidov).

New Feature

  • Extend function tuple to construct named tuples in query. Introduce function tupleNames to extract names from tuples. #54881 (Amos Bird).
  • ASOF JOIN support for full_sorting_join algorithm Close #54493. #55051 (vdimir).
  • A new table function, fuzzQuery, was added. This function allows you to modify a given query string with random variations. Example: SELECT query FROM fuzzQuery('SELECT 1');. #62103 (pufit).
  • Add new window function percent_rank. #62747 (lgbo).
  • Support JWT authentication in clickhouse-client. #62829 (Konstantin Bogdanov).
  • Add SQL functions changeYear, changeMonth, changeDay, changeHour, changeMinute, changeSecond. For example, SELECT changeMonth(toDate('2024-06-14'), 7) returns date 2024-07-14. #63186 (cucumber95).
  • Introduce startup scripts, which allow the execution of preconfigured queries at the startup stage. #64889 (pufit).
  • Support accept_invalid_certificate in client's config in order to allow for client to connect over secure TCP to a server running with self-signed certificate - can be used as a shorthand for corresponding openSSL client settings verificationMode=none + invalidCertificateHandler.name=AcceptCertificateHandler. #65238 (peacewalker122).
  • Add system.error_log which contains history of error values from table system.errors, periodically flushed to disk. #65381 (Pablo Marcos).
  • Add aggregate function groupConcat. About the same as arrayStringConcat( groupArray(column), ',') Can receive 2 parameters: a string delimiter and the number of elements to be processed. #65451 (Yarik Briukhovetskyi).
  • Add AzureQueue storage. #65458 (Kseniia Sumarokova).
  • Add a new setting to disable/enable writing page index into parquet files. #65475 (lgbo).
  • Allow system administrators to configure logger.console_log_level. #65559 (Azat Khuzhin).
  • Automatically append a wildcard * to the end of a directory path with table function file. #66019 (Zhidong (David) Guo).
  • Add --memory-usage option to client in non interactive mode. #66393 (vdimir).

Performance Improvement

  • Enable optimize_functions_to_subcolumns by default. #58661 (Anton Popov).
  • Replace int to string algorithm with a faster one (from a modified amdn/itoa to a modified jeaiii/itoa). #61661 (Raúl Marín).
  • Sizes of hash tables created by join (parallel_hash algorithm) is collected and cached now. This information will be used to preallocate space in hash tables for subsequent query executions and save time on hash table resizes. #64553 (Nikita Taranov).
  • Optimized queries with ORDER BY primary key and WHERE that have a condition with high selectivity by using of buffering. It is controlled by setting read_in_order_use_buffering (enabled by default) and can increase memory usage of query. #64607 (Anton Popov).
  • Improve performance of loading plain_rewritable metadata. #65634 (Alexey Milovidov).
  • Attaching tables on read-only disks will use fewer resources by not loading outdated parts. #65635 (Alexey Milovidov).
  • Support minmax hyperrectangle for Set indices. #65676 (AntiTopQuark).
  • Unload primary index of outdated parts to reduce total memory usage. #65852 (Anton Popov).
  • Functions replaceRegexpAll and replaceRegexpOne are now significantly faster if the pattern is trivial, i.e. contains no metacharacters, pattern classes, flags, grouping characters etc. (Thanks to Taiyang Li). #66185 (Robert Schulze).

Improvement

  • Support rocksdb as backend storage of keeper. #56626 (Han Fei).
  • The setting optimize_trivial_insert_select is disabled by default. In most cases, it should be beneficial. Nevertheless, if you are seeing slower INSERT SELECT or increased memory usage, you can enable it back or SET compatibility = '24.6'. #58970 (Alexey Milovidov).
  • Print stacktrace and diagnostic info if clickhouse-client or clickhouse-local crashes. #61109 (Alexander Tokmakov).
  • The result of SHOW INDEX | INDEXES | INDICES | KEYS was previously sorted by the primary key column names. Since this was unintuitive, the result is now sorted by the position of the primary key columns within the primary key. #61131 (Robert Schulze).
  • This PR changes how deduplication for MV works. Fixed a lot of cases like: - on destination table: data is split for 2 or more blocks and that blocks is considered as duplicate when that block is inserted in parallel. - on MV destination table: the equal blocks are deduplicated, that happens when MV often produces equal data as a result for different input data due to performing aggregation. - on MV destination table: the equal blocks which comes from different MV are deduplicated. #61601 (Sema Checherinda).
  • Allow matching column names in a case insensitive manner when reading json files (input_format_json_case_insensitive_column_matching). #61750 (kevinyhzou).
  • Support reading partitioned data DeltaLake data. Infer DeltaLake schema by reading metadata instead of data. #63201 (Kseniia Sumarokova).
  • In composable protocols TLS layer accepted only certificateFile and privateKeyFile parameters. https://clickhouse.com/docs/en/operations/settings/composable-protocols. #63985 (Anton Ivashkin).
  • Make an interactive client for clickhouse-disks, add local disk from the local directory. Fixes #56791. #64446 (Daniil Ivanik).
  • Added profile event SelectQueriesWithPrimaryKeyUsage which indicates how many SELECT queries use the primary key to evaluate the WHERE clause. #64492 (0x01f).
  • StorageS3Queue related fixes and improvements. Deduce a default value of s3queue_processing_threads_num according to the number of physical cpu cores on the server (instead of the previous default value as 1). Set default value of s3queue_loading_retries to 10. Fix possible vague "Uncaught exception" in exception column of system.s3queue. Do not increment retry count on MEMORY_LIMIT_EXCEEDED exception. Move files commit to a stage after insertion into table fully finished to avoid files being commited while not inserted. Add settings s3queue_max_processed_files_before_commit, s3queue_max_processed_rows_before_commit, s3queue_max_processed_bytes_before_commit, s3queue_max_processing_time_sec_before_commit, to better control commit and flush time. #65046 (Kseniia Sumarokova).
  • Fixed broken multiple columns aggregation on s390x. #65062 (Harry Lee).
  • Support aliases in parametrized view function (only new analyzer). #65190 (Kseniia Sumarokova).
  • S3. reduce retires time for queries, increase retries count for backups. 8.5 minutes and 100 retires for queries, 1.2 hours and 1000 retries for backup restore. #65232 (Sema Checherinda).
  • Updated to mask account key in logs in azureBlobStorage. #65273 (SmitaRKulkarni).
  • Partition pruning for IN predicates when filter expression is a part of PARTITION BY expression. #65335 (Eduard Karacharov).
  • Add system tables with main information about all detached tables. #65400 (Konstantin Morozov).
  • Add support for cluster_for_parallel_replicas when using custom key parallel replicas. It allows you to use parallel replicas with custom key with MergeTree tables. #65453 (Antonio Andelic).
  • Support query plan LIMIT optimization. Support LIMIT pushdown for PostgreSQL storage and table function. #65454 (Maksim Kita).
  • Arraymin/max can be applicable to all data types that are comparable. #65455 (pn).
  • Improved memory accounting for cgroups v2 to exclude the amount occupied by the page cache. #65470 (Nikita Taranov).
  • Do not create format settings for each rows when serializing chunks to insert to EmbeddedRocksDB table. #65474 (Duc Canh Le).
  • Fixed out-of-range exception in parsing Dwarf5 on s390x. #65501 (Harry Lee).
  • Reduce clickhouse-local prompt to just :). getFQDNOrHostName() takes too long on macOS, and we don't want a hostname in the prompt for clickhouse-local anyway. #65510 (Konstantin Bogdanov).
  • Avoid printing a message from jemalloc about per-CPU arenas on low-end virtual machines. #65532 (Alexey Milovidov).
  • Disable filesystem cache background download by default. It will be enabled back when we fix the issue with possible "Memory limit exceeded" because memory deallocation is done outside of query context (while buffer is allocated inside of query context) if we use background download threads. Plus we need to add a separate setting to define max size to download for background workers (currently it is limited by max_file_segment_size, which might be too big). #65534 (Kseniia Sumarokova).
  • Add new option to config <config_reload_interval_ms> which allow to specify how often clickhouse will reload config. #65545 (alesapin).
  • Implement binary encoding for ClickHouse data types and add its specification in docs. Use it in Dynamic binary serialization, allow to use it in RowBinaryWithNamesAndTypes and Native formats under settings. #65546 (Kruglov Pavel).
  • Improved ZooKeeper load balancing. The current session doesn't expire until the optimal nodes become available despite fallback_session_lifetime. Added support for AZ-aware balancing. #65570 (Alexander Tokmakov).
  • Server settings compiled_expression_cache_size and compiled_expression_cache_elements_size are now shown in system.server_settings. #65584 (Robert Schulze).
  • When lightweight delete happens on a table with projection(s), users have choices either throw an exception (by default) or drop the projection lightweight delete would happen. #65594 (jsc0218).
  • Add support for user identification based on x509 SubjectAltName extension. #65626 (Anton Kozlov).
  • clickhouse-local will respect the max_server_memory_usage and max_server_memory_usage_to_ram_ratio from the configuration file. It will also set the max memory usage to 90% of the system memory by default, like clickhouse-server does. This closes #65695. #65697 (Alexey Milovidov).
  • Add a script to backup your files to ClickHouse. This is strange, but works. #65699 (Alexey Milovidov).
  • PostgreSQL source support cancel. #65722 (Maksim Kita).
  • Make allow_experimental_analyzer be controlled by the initiator for distributed queries. This ensures compatibility and correctness during operations in mixed version clusters. #65777 (Nikita Mikhaylov).
  • Respect cgroup CPU limit in Keeper. #65819 (Antonio Andelic).
  • Allow to use concat function with empty arguments ``` sql :) select concat();. #65887 (李扬).
  • Allow controlling named collections in clickhouse-local. #65973 (Alexey Milovidov).
  • Improve Azure profile events. #65999 (alesapin).
  • Query was cancelled might have been printed twice in clickhouse-client. This behaviour is fixed. #66005 (Nikita Mikhaylov).
  • Support ORC file read by writer time zone. #66025 (kevinyhzou).
  • Refactor JSONExtract functions, support more types including experimental Dynamic type. #66046 (Kruglov Pavel).
  • DatabaseCatalog drops tables faster by using up to database_catalog_drop_table_concurrency threads. #66065 (Sema Checherinda).
  • This PR changes how deduplication for MV works. Fixed a lot of cases like: - on destination table: data is split for 2 or more blocks and that blocks is considered as duplicate when that block is inserted in parallel. - on MV destination table: the equal blocks are deduplicated, that happens when MV often produces equal data as a result for different input data due to performing aggregation. - on MV destination table: the equal blocks which comes from different MV are deduplicated. #66144 (Sema Checherinda).
  • Support null map subcolumn for Variant and Dynamic subcolumns. #66178 (Kruglov Pavel).
  • Add settings to control connection to the PostgreSQL. * Setting postgresql_connection_attempt_timeout specifies the value passed to connect_timeout parameter of connection URL. * Setting postgresql_connection_pool_retries specifies the number of retries to establish a connection to the PostgreSQL end-point. #66232 (Dmitry Novik).
  • Reduce inaccuracy of input_wait_elapsed_us/input_wait_elapsed_us/elapsed_us. #66239 (Azat Khuzhin).
  • Improve FilesystemCache ProfileEvents. #66249 (zhukai).
  • Add settings to ignore ON CLUSTER clause in queries for named collection management with replicated storage. #66288 (MikhailBurdukov).
  • Upgraded pocketfft dependency to the recent commit f4c1aa8aa9. #66291 (Nikita Mikhaylov).
  • Upgraded azure-sdk-for-cpp to the recent commit ea3e19a7be. #66292 (Nikita Mikhaylov).
  • Function generateSnowflakeID now allows to specify a machine ID as a parameter to prevent collisions in large clusters. #66374 (ZAWA_ll).
  • Disable suspending on Ctrl+Z in interactive mode. This is a common trap and is not expected behavior for almost all users. I imagine only a few extreme power users could appreciate suspending terminal applications to the background, but I don't know any. #66511 (Alexey Milovidov).
  • Add option for validating the Primary key type in Dictionaries. Without this option for simple layouts any column type will be implicitly converted to UInt64. ### Documentation entry for user-facing changes. #66595 (MikhailBurdukov).
  • Fix SHOW MERGES remaining time. #66735 (Alexey Milovidov).

Critical Bug Fix (crash, LOGICAL_ERROR, data loss, RBAC)

  • Fix unexpeced size of low cardinality column in function calls. #65298 (Raúl Marín).
  • Check cyclic dependencies on CREATE/REPLACE/RENAME/EXCHANGE queries and throw an exception if there is a cyclic dependency. Previously such cyclic dependencies could lead to a deadlock during server startup. Closes #65355. Also fix some bugs in dependencies creation. #65405 (Kruglov Pavel).
  • Fix crash in maxIntersections. #65689 (Raúl Marín).
  • Fix the VALID UNTIL clause in the user definition resetting after a restart. Closes #66405. #66409 (Nikolay Degterinsky).

Bug Fix (user-visible misbehavior in an official stable release)

  • Fixed crash while using MaterializedMySQL with TABLE OVERRIDE that maps MySQL NULL field into ClickHouse not NULL field. #54649 (Filipp Ozinov).
  • Fix logical error when PREWHERE expression read no columns and table has no adaptive index granularity (very old table). Fix #56640. #59173 (Alexander Gololobov).
  • Fix bug with cancelation buffer when canceling a query. #64478 (Sema Checherinda).
  • Fix filling parts columns from metadata (when columns.txt does not exists). #64757 (Azat Khuzhin).
  • Fix AST formatting of 'create table b empty as a'. #64951 (Michael Kolupaev).
  • Fix crash for ALTER TABLE ... ON CLUSTER ... MODIFY SQL SECURITY. #64957 (pufit).
  • Fix crash on destroying AccessControl: add explicit shutdown. #64993 (Vitaly Baranov).
  • Eliminate injective function in argument of functions uniq* recursively. This used to work correctly but was broken in the new analyzer. #65140 (Duc Canh Le).
  • Fix unexpected projection name when query with CTE. #65267 (wudidapaopao).
  • Require dictGet privilege when accessing dictionaries via direct query or the Dictionary table engine. #65359 (Joe Lynch).
  • Fix user-specific S3 auth with incremental backups. #65481 (Antonio Andelic).
  • Disable non-intersecting-parts optimization for queries with FINAL in case of read-in-order optimization was enabled. This could lead to an incorrect query result. As a workaround, disable do_not_merge_across_partitions_select_final and split_parts_ranges_into_intersecting_and_non_intersecting_final before this fix is merged. #65505 (Nikolai Kochetov).
  • Fix getting exception Index out of bound for blob metadata in case all files from list batch were filtered out. #65523 (Kseniia Sumarokova).
  • Fix NOT_FOUND_COLUMN_IN_BLOCK for deduplicate merge of projection. #65573 (Yakov Olkhovskiy).
  • Fixed bug in MergeJoin. Column in sparse serialisation might be treated as a column of its nested type though the required conversion wasn't performed. #65632 (Nikita Taranov).
  • Fixed a bug that compatibility level '23.4' was not properly applied. #65737 (cw5121).
  • Fix odbc table with nullable fields. #65738 (Rodolphe Dugé de Bernonville).
  • Fix data race in TCPHandler, which could happen on fatal error. #65744 (Kseniia Sumarokova).
  • Fix invalid exceptions in function parseDateTime with %F and %D placeholders. #65768 (Antonio Andelic).
  • For queries that read from PostgreSQL, cancel the internal PostgreSQL query if the ClickHouse query is finished. Otherwise, ClickHouse query cannot be canceled until the internal PostgreSQL query is finished. #65771 (Maksim Kita).
  • Fix a bug in short circuit logic when old analyzer and dictGetOrDefault is used. #65802 (jsc0218).
  • Fix a bug leads to EmbeddedRocksDB with TTL write corrupted SST files. #65816 (Duc Canh Le).
  • Functions bitTest, bitTestAll, and bitTestAny now return an error if the specified bit index is out-of-bounds (issue #65517). #65818 (Pablo Marcos).
  • Setting join_any_take_last_row is supported in any query with hash join. #65820 (vdimir).
  • Better handling of join conditions involving IS NULL checks (for example ON (a = b AND (a IS NOT NULL) AND (b IS NOT NULL) ) OR ( (a IS NULL) AND (b IS NULL) ) is rewritten to ON a <=> b), fix incorrect optimization when condition other then IS NULL are present. #65835 (vdimir).
  • Functions bitShiftLeft and bitShitfRight return an error for out of bounds shift positions (issue #65516). #65838 (Pablo Marcos).
  • Fix growing memory usage in S3Queue. #65839 (Kseniia Sumarokova).
  • Fix tie handling in arrayAUC to match sklearn. #65840 (gabrielmcg44).
  • Fix possible issues with MySQL server protocol TLS connections. #65917 (Azat Khuzhin).
  • Fix possible issues with MySQL client protocol TLS connections. #65938 (Azat Khuzhin).
  • Fix handling of SSL_ERROR_WANT_READ/SSL_ERROR_WANT_WRITE with zero timeout. #65941 (Azat Khuzhin).
  • Add missing settings input_format_csv_skip_first_lines/input_format_tsv_skip_first_lines/input_format_csv_try_infer_numbers_from_strings/input_format_csv_try_infer_strings_from_quoted_tuples in schema inference cache because they can change the resulting schema. It prevents from incorrect result of schema inference with these settings changed. #65980 (Kruglov Pavel).
  • Column _size in s3 engine and s3 table function denotes the size of a file inside the archive, not a size of the archive itself. #65993 (Daniil Ivanik).
  • Fix resolving dynamic subcolumns in analyzer, avoid reading the whole column on dynamic subcolumn reading. #66004 (Kruglov Pavel).
  • Fix config merging for from_env with replace overrides. #66034 (Azat Khuzhin).
  • Fix a possible hanging in GRPCServer during shutdown. This PR fixes #65622. #66061 (Vitaly Baranov).
  • Fix reading dynamic subcolumns from altered Memory table. Previously if max_types peremeter of a Dynamic type was changed in Memory table via alter, further subcolumns reading can return wrong result. #66066 (Kruglov Pavel).
  • Fixed several cases in function has with non-constant LowCardinality arguments. #66088 (Anton Popov).
  • Fix for groupArrayIntersect. It had incorrect behavior in the merge() function. Also, fixed behavior in deserialise() for numeric and general data. #66103 (Yarik Briukhovetskyi).
  • Fixed buffer overflow bug in unbin/unhex implementation. #66106 (Nikita Taranov).
  • Disable the merge-filters optimization introduced in #64760. It may cause an exception if optimization merges two filter expressions and does not apply a short-circuit evaluation. #66126 (Nikolai Kochetov).
  • Fixed the issue when the server failed to parse Avro files with negative block size arrays encoded, which is now allowed by the Avro specification. #66130 (Serge Klochkov).
  • Fixed a bug in ZooKeeper client: a session could get stuck in unusable state after receiving a hardware error from ZooKeeper. For example, this might happen due to "soft memory limit" in ClickHouse Keeper. #66140 (Alexander Tokmakov).
  • Fix issue in SumIfToCountIfVisitor and signed integers. #66146 (Raúl Marín).
  • Fix rare case with missing data in the result of distributed query, close #61432. #66174 (vdimir).
  • Fix order of parsing metadata fields in StorageDeltaLake. #66211 (Kseniia Sumarokova).
  • Don't throw TIMEOUT_EXCEEDED for none_only_active mode of distributed_ddl_output_mode. #66218 (Alexander Tokmakov).
  • Fix handling limit for system.numbers_mt when no index can be used. #66231 (János Benjamin Antal).
  • Fixed how the ClickHouse server detects the maximum number of usable CPU cores as specified by cgroups v2 if the server runs in a container such as Docker. In more detail, containers often run their process in the root cgroup which has an empty name. In that case, ClickHouse ignored the CPU limits set by cgroups v2. #66237 (filimonov).
  • Fix the Not-ready set error when a subquery with IN is used in the constraint. #66261 (Nikolai Kochetov).
  • Fix indexHint function case found by fuzzer. #66286 (Anton Popov).
  • Fix error reporting while copying to S3 or AzureBlobStorage. #66295 (Vitaly Baranov).
  • Prevent watchdog from keeping descriptors of unlinked(rotated) log files. #66334 (Aleksei Filatov).
  • Fix the bug that logicalexpressionoptimizerpass lost logical type of constant. closes #64487. #66344 (pn).
  • Fix Column identifier is already registered error with group_by_use_nulls=true and new analyzer. #66400 (Nikolai Kochetov).
  • Fix possible incorrect result for queries joining and filtering table external engine (like PostgreSQL), due to too aggressive filter pushdown. Since now, conditions from where section won't be send to external database in case of outer join with external table. #66402 (vdimir).
  • Added missing column materialization for cross join. #66413 (lgbo).
  • Fix Cannot find column error for queries with constant expression in GROUP BY key and new analyzer enabled. #66433 (Nikolai Kochetov).
  • Avoid possible logical error during import from Npy format in case of bad array nesting level, fix testing of other kinds of errors. #66461 (Yarik Briukhovetskyi).
  • Fix wrong count() result when there is non-deterministic function in predicate. #66510 (Duc Canh Le).
  • Correctly track memory for Allocator::realloc. #66548 (Antonio Andelic).
  • Fix reading of uninitialized memory when hashing empty tuples. This closes #66559. #66562 (Alexey Milovidov).
  • Fix an invalid result for queries with WINDOW. This could happen when PARTITION columns have sparse serialization and window functions are executed in parallel. #66579 (Nikolai Kochetov).
  • Fix removing named collections in local storage. #66599 (János Benjamin Antal).
  • Fix logical error in PrometheusRequestHandler. #66621 (Vitaly Baranov).
  • column_length is not updated in ColumnTuple::insertManyFrom. #66626 (lgbo).
  • Fix Unknown identifier and Column is not under aggregate function errors for queries with the expression (column IS NULL). The bug was triggered by #65088, with the disabled analyzer only. #66654 (Nikolai Kochetov).
  • Fix Method getResultType is not supported for QUERY query node error when scalar subquery was used as the first argument of IN (with new analyzer). #66655 (Nikolai Kochetov).
  • Fix possible PARAMETER_OUT_OF_BOUND error during reading variant subcolumn. #66659 (Kruglov Pavel).
  • Fix rare case of stuck merge after drop column. #66707 (Raúl Marín).
  • Fix assertion isUniqTypes when insert select from remote sources. #66722 (Sema Checherinda).
  • Backported in #67026: In rare cases ClickHouse could consider parts as broken because of some unexpected projections on disk. Now it's fixed. #66898 (alesapin).
  • Backported in #67443: Forbid create as select even when database_replicated_allow_heavy_create is set. It was unconditionally forbidden in 23.12 and accidentally allowed under the setting in unreleased 24.7. #66980 (vdimir).
  • Backported in #67201: TRUNCATE DATABASE used to stop replication as if it was a DROP DATABASE query, it's fixed. #67129 (Alexander Tokmakov).
  • Backported in #67383: Fix error Cannot convert column because it is non constant in source stream but must be constant in result. for a query that reads from the Merge table over the Distriburted table with one shard. #67146 (Nikolai Kochetov).
  • Backported in #67246: This closes #67156. This closes #66447. The bug was introduced in https://github.com/ClickHouse/ClickHouse/pull/62907. #67178 (Maksim Kita).

Build/Testing/Packaging Improvement

NO CL CATEGORY

NO CL ENTRY

  • NO CL ENTRY: 'Revert "Revert "Small fix for 02340_parts_refcnt_mergetree""'. #65155 (Nikita Taranov).
  • NO CL ENTRY: 'Revert "Use 1MB HTTP buffers to avoid frequent send syscalls"'. #65498 (Sergei Trifonov).
  • NO CL ENTRY: 'Revert "Resubmit http_external_tables_memory_tracking test"'. #65500 (Nikita Taranov).
  • NO CL ENTRY: 'Revert "Add an assertion in ReplicatedMergeTreeQueue"'. #65686 (Raúl Marín).
  • NO CL ENTRY: 'Revert "insertion deduplication on retries for materialised views"'. #66134 (Sema Checherinda).

NOT FOR CHANGELOG / INSIGNIFICANT