mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-10 01:25:21 +00:00
52 KiB
52 KiB
sidebar_position | sidebar_label |
---|---|
1 | 2023 |
2023 Changelog
ClickHouse release v23.6.1.1524-stable (d1c7e13d08
) FIXME as compared to v23.5.1.3174-stable (2fec796e73
)
Backward Incompatible Change
- Delete feature
do_not_evict_index_and_mark_files
in the fs cache. This feature was only making things worse. #51253 (Kseniia Sumarokova). - Remove ALTER support for experimental LIVE VIEW. #51287 (Alexey Milovidov).
New Feature
- Add setting
session_timezone
, it is used as default timezone for session when not explicitly specified. #44149 (Andrey Zvonov). - Added overlay database engine and representation of a directory as a database This commit adds 4 databases: 1. DatabaseOverlay: Implements the IDatabase interface. Allow to combine multiple databases, such as FileSystem and Memory. Internally, it stores a vector with other database pointers and proxies requests to them in turn until it is executed successfully. 2. DatabaseFilesystem: allows to read-only interact with files stored on the file system. Internally, it uses TableFunctionFile to implicitly load file when a user requests the table. Result of TableFunctionFile call cached inside to provide quick access. 3. DatabaseS3: allows to read-only interact with s3 storage. It uses TableFunctionS3 to implicitly load table from s3 4. DatabaseHDFS: allows to interact with hdfs storage. It uses TableFunctionHDFS to implicitly load table from hdfs. #48821 (alekseygolub).
- Add a new setting named
use_mysql_types_in_show_columns
to alter theSHOW COLUMNS
SQL statement to display MySQL equivalent types when a client is connected via the MySQL compatibility port. #49577 (Thomas Panetti). - Added option
--rename_files_after_processing <pattern>
. This closes #34207. #49626 (alekseygolub). - Allow to skip empty files in file/s3/url/hdfs table functions using settings
s3_skip_empty_files
,hdfs_skip_empty_files
,engine_file_skip_empty_files
,engine_url_skip_empty_files
. #50364 (Kruglov Pavel). - Clickhouse-client can now be called with a connection instead of "--host", "--port", "--user" etc. #50689 (Alexey Gerasimchuck).
- Codec DEFLATE_QPL is now controlled via server setting "enable_deflate_qpl_codec" (default: false) instead of setting "allow_experimental_codecs". This marks QPL_DEFLATE non-experimental. #50775 (Robert Schulze).
Performance Improvement
- Improve performance with enabled QueryProfiler using thread-local timer_id instead of global object. #48778 (Jiebin Sun).
- Rewrite CapnProto input/output format to improve its performance. Map column names and CapnProto fields case insensitive, fix reading/writing of nested structure fields. #49752 (Kruglov Pavel).
- Optimize parquet write performance for parallel threads. #50102 (Hongbin Ma).
-
Documentation entry for user-facing changes Disable
parallelize_output_from_storages
for processing MATERIALIZED VIEWs and storages with one block only. #50214 (Azat Khuzhin). - Merge PR https://github.com/ClickHouse/ClickHouse/pull/46558 (Avoid processing already sorted data). Avoid block permutation during sort if the block is already sorted. #50697 (Maksim Kita).
- In the earlier PRs (#50062, #50307), we used to propose an optimization pattern which transforms the predicates with toYear/toYYYYMM into its equivalent but converter-free form. This transformation could bring significant performance impact to some workloads, such as SSB. However, as issue #50628 indicated, these two PRs would introduce some issues which may results in incomplete query results, and as a result, they were reverted by #50629. #50951 (Zhiguo Zhou).
- Make multiple list requests to ZooKeeper in parallel to speed up reading from system.zookeeper table. #51042 (Alexander Gololobov).
- Speedup initialization of DateTime lookup tables for time zones. This should reduce startup/connect time of clickhouse client especially in debug build as it is rather heavy. #51347 (Alexander Gololobov).
Improvement
- Allow to cast IPv6 to IPv4 address for CIDR ::ffff:0:0/96 (IPv4-mapped addresses). #49759 (Yakov Olkhovskiy).
- Update MongoDB protocol to support MongoDB 5.1 version and newer. Support for the versions with the old protocol (<3.6) is preserved. Closes #45621, #49879. #50061 (Nikolay Degterinsky).
- Improved scheduling of merge selecting and cleanup tasks in
ReplicatedMergeTree
. The tasks will not be executed too frequently when there's nothing to merge or cleanup. Added settingsmax_merge_selecting_sleep_ms
,merge_selecting_sleep_slowdown_factor
,max_cleanup_delay_period
andcleanup_thread_preferred_points_per_iteration
. It should close #31919. #50107 (Alexander Tokmakov). - Support parallel replicas with the analyzer. #50441 (Raúl Marín).
- Add setting
input_format_max_bytes_to_read_for_schema_inference
to limit the number of bytes to read in schema inference. Closes #50577. #50592 (Kruglov Pavel). - Respect setting input_format_as_default in schema inference. #50602 (Kruglov Pavel).
- Make filter push down through cross join. #50605 (Han Fei).
- Actual lz4 version is used now. #50621 (Nikita Taranov).
- Allow to skip trailing empty lines in CSV/TSV/CustomSeparated formats via settings
input_format_csv_skip_trailing_empty_lines
,input_format_tsv_skip_trailing_empty_lines
andinput_format_custom_skip_trailing_empty_lines
(disabled by default). Closes #49315. #50635 (Kruglov Pavel). - Functions "toDateOrDefault|OrNull()" and "accuateCastOrDefault|OrNull" now correctly parse numeric arguments. #50709 (Dmitry Kardymon).
- Currently, the csv input format can not parse the csv file with whitespace or \t field delimiter, and these delimiters is supported in spark. #50712 (KevinyhZou).
- Settings
number_of_mutations_to_delay
andnumber_of_mutations_to_throw
are enabled by default now with values 500 and 1000 respectively. #50726 (Anton Popov). - Keeper improvement: add feature flags for Keeper API. Each feature flag can be disabled or enabled by defining it under
keeper_server.feature_flags
config. E.g. to enableCheckNotExists
request,keeper_server.feature_flags.check_not_exists
should be set to1
on Keeper. #50796 (Antonio Andelic). - The dashboard correctly shows missing values. This closes #50831. #50832 (Alexey Milovidov).
- CGroups metrics related to CPU are replaced with one metric,
CGroupMaxCPU
for better usability. TheNormalized
CPU usage metrics will be normalized to CGroups limits instead of the total number of CPUs when they are set. This closes #50836. #50835 (Alexey Milovidov). - Relax the thresholds for "too many parts" to be more modern. Return the backpressure during long-running insert queries. #50856 (Alexey Milovidov).
- Added the possibility to use date and time arguments in syslog timestamp format in functions parseDateTimeBestEffort*() and parseDateTime64BestEffort*(). #50925 (Victor Krasnov).
- Suggest using
APPEND
orTRUNCATE
forINTO OUTFILE
when file exists. #50950 (alekar). - Add embedded keeper-client to standalone keeper binary. #50964 (pufit).
- Command line parameter "--password" in clickhouse-client can now be specified only once. #50966 (Alexey Gerasimchuck).
- Fix data lakes slowness because of synchronous head requests. (Related to Iceberg/Deltalake/Hudi being slow with a lot of files). #50976 (Kseniia Sumarokova).
- Use
hash_of_all_files
fromsystem.parts
to check identity of parts during on-cluster backups. #50997 (Vitaly Baranov). - The system table zookeeper_connection connected_time identifies the time when the connection is established (standard format), and session_uptime_elapsed_seconds is added, which labels the duration of the established connection session (in seconds). #51026 (郭小龙).
- Show halves of checksums in
system.parts
,system.projection_parts
and in error messages in the correct order. #51040 (Vitaly Baranov). - Do not replicate
ALTER PARTITION
queries and mutations throughReplicated
database if it has only one shard and the underlying table isReplicatedMergeTree
. #51049 (Alexander Tokmakov). - Improve the progress bar for file/s3/hdfs/url table functions by using chunk size from source data and using incremental total size counting in each thread. Fix the progress bar for *Cluster functions. This closes #47250. #51088 (Kruglov Pavel).
- Add total_bytes_to_read to Progress packet in TCP protocol for better Progress bar. #51158 (Kruglov Pavel).
- Better checking of data parts on disks with filesystem cache. #51164 (Anton Popov).
- Disable cache setting
do_not_evict_index_and_mark_files
(Was enabled in23.5
). #51222 (Kseniia Sumarokova). - Fix sometimes not correct current_elements_num in fs cache. #51242 (Kseniia Sumarokova).
- Add random sleep before merges/mutations execution to split load more evenly between replicas in case of zero-copy replication. #51282 (alesapin).
- The function
transform
as well asCASE
with value matching started to support all data types. This closes #29730. This closes #32387. This closes #50827. This closes #31336. This closes #40493. #51351 (Alexey Milovidov). - We have found a bug in LLVM that makes the usage of
compile_expressions
setting unsafe. It is disabled by default. #51368 (Alexey Milovidov). - Issue #50220 reports a core in
grace_hash
join. We finally reproduce the exception on local, and found that the issue is related to the failure of creating temporary file. Somehow this is triggered in https://github.com/ClickHouse/ClickHouse/pull/49816 https://github.com/ClickHouse/ClickHouse/pull/49483. #51382 (lgbo).
Build/Testing/Packaging Improvement
- Update contrib/re2 to 2023-06-02. #50949 (Yuriy Chernyshov).
- ClickHouse server will print the list of changed settings on fatal errors. This closes #51137. #51138 (Alexey Milovidov).
- In https://github.com/ClickHouse/ClickHouse/pull/51143 the fasstests failed, but the status wasn't created because of the chown
file not found
. This addresses it. Decrease the default values forhttp-max-field-value-size
andhttp_max_field_name_size
to 128K. #51163 (Mikhail f. Shiryaev). - Update Ubuntu version in docker containers. #51180 (Mikhail f. Shiryaev).
- Allow building ClickHouse with clang-17. #51300 (Alexey Milovidov).
- SQLancer check is considered stable as bugs that were triggered by it are fixed. Now failures of SQLancer check will be reported as failed check status. #51340 (Ilya Yatsishin).
- Making our CI even better. #51494 (Nikita Mikhaylov).
- Split huge
RUN
in Dockerfile into smaller conditional. Install the necessary tools on demand in the sameRUN
layer, and remove them after that. Upgrade the OS only once at the beginning. Use a modern way to check the signed repository. Downgrade the base repo to ubuntu:20.04 to address the issues on older docker versions. Upgrade golang version to address golang vulnerabilities. #51504 (Mikhail f. Shiryaev). - This a follow-up for #51504, the cleanup was lost during refactoring. #51564 (Mikhail f. Shiryaev).
Bug Fix (user-visible misbehavior in an official stable release)
- Report loading status for executable dictionaries correctly #48775 (Anton Kozlov).
- Proper mutation of skip indices and projections #50104 (Amos Bird).
- Cleanup moving parts #50489 (vdimir).
- Fix backward compatibility for IP types hashing in aggregate functions #50551 (Yakov Olkhovskiy).
- Fix Log family table return wrong rows count after truncate #50585 (flynn).
- Fix bug in
uniqExact
parallel merging #50590 (Nikita Taranov). - Revert recent grace hash join changes #50699 (vdimir).
- Query Cache: Try to fix bad cast from ColumnConst to ColumnVector<char8_t> #50704 (Robert Schulze).
- Do not read all the columns from right GLOBAL JOIN table. #50721 (Nikolai Kochetov).
- Avoid storing logs in Keeper containing unknown operation #50751 (Antonio Andelic).
- SummingMergeTree support for DateTime64 #50797 (Jordi Villar).
- Add compat setting for non-const timezones #50834 (Robert Schulze).
- Fix type of LDAP server params hash in cache entry #50865 (Julian Maicher).
- Fallback to parsing big integer from String instead of exception in Parquet format #50873 (Kruglov Pavel).
- Fix checking the lock file too often while writing a backup #50889 (Vitaly Baranov).
- Do not apply projection if read-in-order was enabled. #50923 (Nikolai Kochetov).
- Fix race azure blob storage iterator #50936 (SmitaRKulkarni).
- Fix erroneous
sort_description
propagation inCreatingSets
#50955 (Nikita Taranov). - Fix iceberg V2 optional metadata parsing #50974 (Kseniia Sumarokova).
- MaterializedMySQL: Keep parentheses for empty table overrides #50977 (Val Doroshchuk).
- Fix crash in BackupCoordinationStageSync::setError() #51012 (Vitaly Baranov).
- Fix subtly broken copy-on-write of ColumnLowCardinality dictionary #51064 (Michael Kolupaev).
- Generate safe IVs #51086 (Salvatore Mesoraca).
- Fix ineffective query cache for SELECTs with subqueries #51132 (Robert Schulze).
- Fix Set index with constant nullable comparison. #51205 (Nikolai Kochetov).
- Fix a crash in s3 and s3Cluster functions #51209 (Nikolay Degterinsky).
- Fix core dump when compile expression #51231 (LiuNeng).
- Fix use-after-free in StorageURL when switching URLs #51260 (Michael Kolupaev).
- Updated check for parameterized view #51272 (SmitaRKulkarni).
- Fix multiple writing of same file to backup #51299 (Vitaly Baranov).
- Fix fuzzer failure in ActionsDAG #51301 (Alexey Milovidov).
- Remove garbage from function
transform
#51350 (Alexey Milovidov). - Fix MSan report in lowerUTF8/upperUTF8 #51371 (Alexey Milovidov).
- fs cache: fix a bit incorrect use_count after #44985 #51406 (Kseniia Sumarokova).
- Fix segfault in MathUnary #51499 (Ilya Yatsishin).
- Fix logical assert in
tupleElement()
with default values #51534 (Robert Schulze). - fs cache: remove file from opened file cache immediately when evicting file #51596 (Kseniia Sumarokova).
NOT FOR CHANGELOG / INSIGNIFICANT
- Deprecate delete-on-destroy.txt #49181 (Alexander Gololobov).
- Attempt to increase the general runners' survival rate #49283 (Mikhail f. Shiryaev).
- Refactor subqueries for IN #49570 (Nikolai Kochetov).
- Test plan optimization analyzer #50095 (Igor Nikonov).
- Implement endianness-independent serialization for quantileTiming #50324 (ltrk2).
- require
finalize()
call before d-tor for all writes buffers #50395 (Sema Checherinda). - Implement big-endian support for the deterministic reservoir sampler #50405 (ltrk2).
- Fix compilation error on big-endian platforms #50406 (ltrk2).
- Attach gdb in stateless tests #50487 (Kruglov Pavel).
- JIT infrastructure refactoring #50531 (Maksim Kita).
- Analyzer: Do not apply Query Tree optimizations on shards #50584 (Dmitry Novik).
- Increase max array size in group bitmap #50620 (Kruglov Pavel).
- Misc Annoy index improvements #50661 (Robert Schulze).
- Fix reading negative decimals in avro format #50668 (Kruglov Pavel).
- Unify priorities for connection pools #50675 (Sergei Trifonov).
- Prostpone check of outdated parts #50676 (Alexander Tokmakov).
- Unify priorities:
IExecutableTask
s #50677 (Sergei Trifonov). - Disable grace_hash join in stress tests #50693 (vdimir).
- ReverseTransform small improvement #50698 (Maksim Kita).
- Support OPTIMIZE for temporary tables #50710 (Alexander Tokmakov).
- Refactor reading from object storages #50711 (Kseniia Sumarokova).
- Fix data race in log message of cached buffer #50723 (Kseniia Sumarokova).
- Add new keywords into projections documentation #50743 (YalalovSM).
- Fix build for aarch64 (temporary disable azure) #50770 (alesapin).
- Update version after release #50772 (Alexey Milovidov).
- Update version_date.tsv and changelogs after v23.5.1.3174-stable #50774 (robot-clickhouse).
- Update CHANGELOG.md #50788 (Ilya Yatsishin).
- Update version_date.tsv and changelogs after v23.2.7.32-stable #50809 (robot-clickhouse).
- Desctructing --> Destructing #50810 (Robert Schulze).
- Don't mark a part as broken on
Poco::TimeoutException
#50811 (Alexander Tokmakov). - Rename azure_blob_storage to azureBlobStorage #50812 (SmitaRKulkarni).
- Fix ParallelReadBuffer seek #50820 (Michael Kolupaev).
- [RFC] Print git hash when crashing #50823 (Michael Kolupaev).
- Add tests for function "transform" #50833 (Alexey Milovidov).
- Update version_date.tsv and changelogs after v23.5.2.7-stable #50844 (robot-clickhouse).
- Updated changelog with azureBlobStorage table function & engine entry #50850 (SmitaRKulkarni).
- Update easy_tasks_sorted_ru.md #50853 (Alexey Milovidov).
- Document x86 / ARM prerequisites for Docker image #50867 (Robert Schulze).
- MaterializedMySQL: Add test_named_collections #50874 (Val Doroshchuk).
- Update version_date.tsv and changelogs after v22.8.18.31-lts #50881 (robot-clickhouse).
- Update version_date.tsv and changelogs after v23.3.3.52-lts #50882 (robot-clickhouse).
- Update version_date.tsv and changelogs after v23.4.3.48-stable #50883 (robot-clickhouse).
- MaterializedMySQL: Add additional test case to insert_with_modify_binlog_checksum #50884 (Val Doroshchuk).
- Update broken tests list #50886 (Dmitry Novik).
- Fix LOGICAL_ERROR in snowflakeToDateTime*() #50893 (Robert Schulze).
- Tests with parallel replicas are no more "always green" #50896 (Nikita Mikhaylov).
- Slightly more information in error message about cached disk #50897 (Michael Kolupaev).
- do not call finalize after exception #50907 (Sema Checherinda).
- Update Annoy docs #50912 (Robert Schulze).
- A bit safer UserDefinedSQLFunctionVisitor #50913 (Kseniia Sumarokova).
- Update contribe/orc in .gitmodules #50920 (San).
- MaterializedMySQL: Add missing DROP DATABASE for tests #50924 (Val Doroshchuk).
- Fix 'Illegal column timezone' in stress tests #50929 (Alexander Tokmakov).
- Fix tests sanity checks and avoid dropping system.query_log table #50934 (Azat Khuzhin).
- Fix tests for throttling by allowing more margin of error for trottling event #50935 (Azat Khuzhin).
- 01746_convert_type_with_default: Temporarily disable flaky test #50937 (Robert Schulze).
- Fix the statless tests image for old commits #50947 (Mikhail f. Shiryaev).
- Fix logic in
AsynchronousBoundedReadBuffer::seek
#50952 (Nikita Taranov). - Uncomment flaky test (01746_convert_type_with_default) #50954 (Dmitry Kardymon).
- Fix keeper-client help message #50965 (pufit).
- fix build issue on clang 15 #50967 (Chang chen).
- Docs: Fix embedded video link #50972 (Robert Schulze).
- Change submodule capnproto to it's fork in ClickHouse #50987 (Kruglov Pavel).
- Attempt to make 01281_group_by_limit_memory_tracking not flaky #50995 (Dmitry Novik).
- Fix flaky 02561_null_as_default_more_formats #51001 (Igor Nikonov).
- Fix flaky test_seekable_formats #51002 (Kruglov Pavel).
- Follow-up to #50448 #51006 (Alexander Tokmakov).
- Fix a versions' tweak for tagged commits, improve version_helper #51035 (Mikhail f. Shiryaev).
- Sqlancer has changed master to main #51060 (Mikhail f. Shiryaev).
- Do not spam sqlancer build log #51061 (Mikhail f. Shiryaev).
- Refactor IColumn::forEachSubcolumn to make it slightly harder to implement incorrectly #51072 (Michael Kolupaev).
- MaterializedMySQL: Rename materialize_with_ddl.py -> materialized_with_ddl #51074 (Val Doroshchuk).
- Improve woboq browser report #51077 (Mikhail f. Shiryaev).
- Fix for part_names_mutex used after destruction #51099 (Alexander Gololobov).
- Fix ColumnConst::forEachSubcolumn missing from previous PR #51102 (Michael Kolupaev).
- Fix the test 02783_parsedatetimebesteffort_syslog flakiness #51112 (Victor Krasnov).
- Compatibility with clang-17 #51114 (Alexey Milovidov).
- Make more parallel get requests to ZooKeeper in system.zookeeper #51118 (Alexander Gololobov).
- Fix 02703_max_local_write_bandwidth flakiness #51120 (Azat Khuzhin).
- Update version_date.tsv and changelogs after v23.5.3.24-stable #51121 (robot-clickhouse).
- Update version_date.tsv and changelogs after v23.4.4.16-stable #51122 (robot-clickhouse).
- Update version_date.tsv and changelogs after v23.3.4.17-lts #51123 (robot-clickhouse).
- Update version_date.tsv and changelogs after v22.8.19.10-lts #51124 (robot-clickhouse).
- Fix typo #51126 (Alexey Milovidov).
- Slightly better diagnostics #51127 (Alexey Milovidov).
- Small fix in
MergeTreePrefetchedReadPool
#51131 (Nikita Taranov). - Don't report table function accesses to system.errors #51147 (Raúl Marín).
- Fix SQLancer branch name #51148 (Ilya Yatsishin).
- Revert "Added ability to implicitly use file/hdfs/s3 table functions in clickhouse-local" #51149 (Alexander Tokmakov).
- More profile events for fs cache #51161 (Kseniia Sumarokova).
- Unforget to pass callback to readBigAt() in ParallelReadBuffer #51165 (Michael Kolupaev).
- Update README.md #51179 (Tyler Hannan).
- Update exception message #51187 (Kseniia Sumarokova).
- Split long test 02149_schema_inference_formats_with_schema into several tests to avoid timeout in debug #51197 (Kruglov Pavel).
- Avoid initializing DateLUT from emptyArray function registration #51199 (Alexander Gololobov).
- Suppress check for covered parts in ZooKeeper #51207 (Alexander Tokmakov).
- One more profile event for fs cache #51223 (Kseniia Sumarokova).
- Typo: passowrd_sha256_hex --> password_sha256_hex #51233 (Robert Schulze).
- Introduce settings enum field with auto-generated values list #51237 (Sergei Trifonov).
- Drop session if we fail to get Keeper API version #51238 (Alexander Gololobov).
- Revert "Fix a crash in s3 and s3Cluster functions" #51239 (Alexander Tokmakov).
- fix flaky
AsyncLoader
destructor #51245 (Sergei Trifonov). - Docs: little cleanup of configuration-files.md #51249 (Robert Schulze).
- Fix a stupid bug on Replicated database recovery #51252 (Alexander Tokmakov).
- FileCache: tryReserve() slight improvement #51259 (Igor Nikonov).
- Ugly hotfix for "terminate on uncaught exception" in WriteBufferFromOStream #51265 (Alexander Tokmakov).
- Avoid too many calls to Poco::Logger::get #51266 (Kseniia Sumarokova).
- Update version_date.tsv and changelogs after v23.3.5.9-lts #51269 (robot-clickhouse).
- Better reporting of broken parts #51270 (Anton Popov).
- Update ext-dict-functions.md #51283 (Mike Kot).
- Disable table structure check for secondary queries from Replicated db #51284 (Alexander Tokmakov).
- Define Thrift version for parquet and use correct arrow version #51285 (Kruglov Pavel).
- Restore Azure build on ARM #51288 (Robert Schulze).
- Query Cache: Un-comment settings in server cfg #51294 (Robert Schulze).
- Require more checks #51295 (Alexey Milovidov).
- Fix metadata loading test #51297 (Alexey Milovidov).
- Scratch the strange Python code #51302 (Alexey Milovidov).
- Add a test for #47865 #51306 (Alexey Milovidov).
- Add a test for #48894 #51307 (Alexey Milovidov).
- Add a test for #48676 #51308 (Alexey Milovidov).
- Fix long test
functions_bad_arguments
#51310 (Alexey Milovidov). - Unify merge predicate #51344 (Alexander Tokmakov).
- Fix using locks in ProcessList #51348 (Vitaly Baranov).
- Add a test for #42631 #51353 (Alexey Milovidov).
- Fix performance tests due to warnings from jemalloc about Per-CPU arena disabled #51362 (Azat Khuzhin).
- Fix "merge_truncate_long" test #51369 (Alexey Milovidov).
- Increase timeout of Fast Test #51372 (Alexey Milovidov).
- Fix bad tests for DNS #51374 (Alexey Milovidov).
- Attempt to fix the
relax_too_many_parts
test #51375 (Alexey Milovidov). - Fix MySQL test in Debug mode #51376 (Alexey Milovidov).
- Fix bad test
01018_Distributed__shard_num
#51377 (Alexey Milovidov). - Fix "logical error" in addressToLineWithInlines #51379 (Alexey Milovidov).
- Fix test 01280_ttl_where_group_by #51380 (Alexey Milovidov).
- Attempt to fix
test_ssl_cert_authentication
#51384 (Alexey Milovidov). - Revert "Merge pull request #50951 from ZhiguoZh/20230607-toyear-fix" #51390 (Alexey Milovidov).
- Two tests are twice longer in average with Analyzer and sometimes failing #51391 (Alexey Milovidov).
- Fix 00899_long_attach_memory_limit #51395 (Alexey Milovidov).
- Fix test 01293_optimize_final_force #51396 (Alexey Milovidov).
- Fix test 02481_parquet_list_monotonically_increasing_offsets #51397 (Alexey Milovidov).
- Fix test 02497_trace_events_stress_long #51398 (Alexey Milovidov).
- Fix broken labeling for
manual approve
#51405 (Mikhail f. Shiryaev). - Fix parts lifetime in
MergeTreeTransaction
#51407 (Alexander Tokmakov). - Fix flaky test test_skip_empty_files #51409 (Kruglov Pavel).
- fix flacky test test_profile_events_s3 #51412 (Sema Checherinda).
- Update README.md #51413 (Tyler Hannan).
- Replace try/catch logic in hasTokenOrNull() by something more lightweight #51425 (Robert Schulze).
- Add retries to
tlsv1_3
tests #51434 (János Benjamin Antal). - Update exception message #51440 (Kseniia Sumarokova).
- fs cache: add check for intersecting ranges #51444 (Kseniia Sumarokova).
- Slightly better code around packets for parallel replicas #51451 (Nikita Mikhaylov).
- Update system_warnings test #51453 (Alexey Milovidov).
- Many fixes #51455 (Alexey Milovidov).
- Fix test 01605_adaptive_granularity_block_borders #51457 (Alexey Milovidov).
- Try fix flaky 02497_storage_file_reader_selection #51468 (Kruglov Pavel).
- Try making Keeper in
DatabaseReplicated
tests more stable #51473 (Antonio Andelic). - Convert 02003_memory_limit_in_client from expect to sh test (to fix flakiness) #51475 (Azat Khuzhin).
- Fix test_disk_over_web_server #51476 (Kseniia Sumarokova).
- Delay shutdown of system and temporary databases #51479 (Kseniia Sumarokova).
- Fix memory leakage in CompressionCodecDeflateQpl #51480 (Vitaly Baranov).
- Increase retries in test_multiple_disks/test.py::test_start_stop_moves #51482 (Kseniia Sumarokova).
- Fix race in BoundedReadBuffer #51484 (Kseniia Sumarokova).
- Fix flaky unit test #51485 (Kseniia Sumarokova).
- Fix flaky test
test_host_regexp_multiple_ptr_records
#51506 (Nikolay Degterinsky). - Add a comment #51517 (Kseniia Sumarokova).
- Make
test_ssl_cert_authentication
similar totest_tlvs1_3
#51520 (János Benjamin Antal). - Fix duplicate storage set logical error. #51521 (Nikolai Kochetov).
- Update test_storage_postgresql/test.py::test_concurrent_queries #51523 (Kseniia Sumarokova).
- Fix FATAL: query context is not detached from thread group #51540 (Igor Nikonov).
- Update version_date.tsv and changelogs after v23.3.6.7-lts #51548 (robot-clickhouse).
- Decoupled commits from #51180 for backports #51561 (Mikhail f. Shiryaev).
- Try to fix deadlock in ZooKeeper client #51563 (Alexander Tokmakov).
- Retry chroot creation in ZK before stateless tests #51585 (Antonio Andelic).
- use timeout instead trap in 01443_merge_truncate_long.sh #51593 (Sema Checherinda).
- Update version_date.tsv and changelogs after v23.5.4.25-stable #51604 (robot-clickhouse).
- Fix MergeTreeMarksLoader segfaulting if marks file is longer than expected #51636 (Michael Kolupaev).
- Update version_date.tsv and changelogs after v23.4.5.22-stable #51638 (robot-clickhouse).
- Update version_date.tsv and changelogs after v23.3.7.5-lts #51639 (robot-clickhouse).
- Update parts.md #51643 (Ramazan Polat).