mirror of
https://github.com/ClickHouse/ClickHouse.git
synced 2024-11-10 01:25:21 +00:00
72 KiB
72 KiB
sidebar_position | sidebar_label |
---|---|
1 | 2022 |
2022 Changelog
ClickHouse release v21.9.1.8000-prestable FIXME as compared to v21.8.1.7409-prestable
Backward Incompatible Change
- Fix the issue that in case of some sophisticated query with column aliases identical to the names of expressions, bad cast may happen. This fixes #25447. This fixes #26914. This fix may introduce backward incompatibility: if there are different expressions with identical names, exception will be thrown. It may break some rare cases when
enable_optimize_predicate_expression
is set. #26639 (Alexey Milovidov). - Under clickhouse-local, always treat local addresses with a port as remote. #26736 (Raúl Marín).
- Do not allow to apply parametric aggregate function with
-Merge
combinator to aggregate function state if state was produced by aggregate function with different parameters. For example, state offooState(42)(x)
cannot be finalized withfooMerge(s)
orfooMerge(123)(s)
, parameters must be specified explicitly likefooMerge(42)(s)
and must be equal. It does not affect some special aggregate functions likequantile
andsequence*
that use parameters for finalization only. #26847 (Alexander Tokmakov). - Do not output trailing zeros in text representation of
Decimal
types. Example:1.23
will be printed instead of1.230000
for decimal with scale 6. This closes #15794. It may introduce slight incompatibility if your applications somehow relied on the trailing zeros. Serialization in output formats can be controlled with the settingoutput_format_decimal_trailing_zeros
. Implementation oftoString
and casting to String is changed unconditionally. #27680 (Alexey Milovidov).
New Feature
- Implement window function
nth_value(expr, N)
that returns the value of the Nth row of the window frame. #26334 (Zuo, RuoYu). - Functions that return (initial_)query_id of the current query. This closes #23682. #26410 (Alexey Boykov).
- Introduce syntax for here documents. Example
SELECT $doc$VALUE$doc$
. #26671 (Maksim Kita). - New functions
currentProfiles()
,enabledProfiles()
,defaultProfiles()
. #26714 (Vitaly Baranov). - Add new functions
currentRoles()
,enabledRoles()
,defaultRoles()
. #26780 (Vitaly Baranov). - Supported cluster macros inside table functions 'cluster' and 'clusterAllReplicas'. #26913 (Vadim Volodin).
- Added support for custom query for MySQL, PostgreSQL, ClickHouse, JDBC, Cassandra dictionary source. Closes #1270. #26995 (Maksim Kita).
- add column default_database to system.users. #27054 (kevin wan).
- Added
bitmapSubsetOffsetLimit(bitmap, offset, cardinality_limit)
function. It creates a subset of bitmap limit the results tocardinality_limit
with offset ofoffset
. #27234 (DHBin). - Add support for
bzip2
compression method for import/export. Closes #22428. #27377 (Nikolay Degterinsky). -
- Add replicated storage of user, roles, row policies, quotas and settings profiles through ZooKeeper (experimental). #27426 (Kevin Michel).
- Add "tupleToNameValuePairs", a function that turns a named tuple into an array of pairs. #27505 (Braulio Valdivielso Martínez).
- Enable using constants from with and select in aggregate function parameters. Close #10945. #27531 (abel-cheng).
- Added ComplexKeyRangeHashed dictionary. Closes #22029. #27629 (Maksim Kita).
Performance Improvement
- Compile aggregate functions
groupBitOr
,groupBitAnd
,groupBitXor
. #26161 (Maksim Kita). - Compile columns with
Enum
types. #26237 (Maksim Kita). -
- Vectorize the SUM of Nullable integer types with native representation (David Manzanares, Raúl Marín). #26248 (Raúl Marín).
- Don't build sets for indices when analyzing a query. #26365 (Raúl Marín).
- Improve latency of short queries, that require reading from tables with large number of columns. #26371 (Anton Popov).
- Share file descriptors in concurrent reads of the same files. There is no noticeable performance difference on Linux. But the number of opened files will be significantly (10..100 times) lower on typical servers and it makes operations easier. See #26214. #26768 (Alexey Milovidov).
- Specialize date time related comparison to achieve better performance. This fixes #27083 . #27122 (Amos Bird).
- Improve the performance of fast queries when
max_execution_time=0
by reducing the number ofclock_gettime
system calls. #27325 (filimonov). - Less number of
clock_gettime
syscalls that may lead to performance improvement for some types of fast queries. #27492 (filimonov).
Improvement
- Add error id (like
BAD_ARGUMENTS
) to exception messages. This closes #25862. #26172 (Alexey Milovidov). - Remove GLOBAL keyword for IN when scalar function is passed. In previous versions, if user specified
GLOBAL IN f(x)
exception was thrown. #26217 (Amos Bird). - Apply aggressive IN index analysis for projections so that better projection candidate can be selected. #26218 (Amos Bird).
- convert timestamp and timestamptz data types to DateTime64 in postgres engine. #26234 (jasine).
- Check for non-deterministic functions in keys, including constant expressions like
now()
,today()
. This closes #25875. This closes #11333. #26235 (Alexey Milovidov). - Don't throw exception when querying
system.detached_parts
table if there is custom disk configuration anddetached
directory does not exist on some disks. This closes #26078. #26236 (Alexey Milovidov). - Add information about column sizes in
system.columns
table forLog
andTinyLog
tables. This closes #9001. #26241 (Nikolay Degterinsky). - Added
output_format_avro_string_column_pattern
setting to put specified String columns to Avro as string instead of default bytes. Implements #22414. #26245 (Ilya Golshtein). -
- Add
system.warnings
table to collect warnings about server configuration. #26246 (Filatenkov Artur).
- Add
- Check hash function at table creation, not at sampling. Add settings in MergeTreeSettings, if someone create a table with incorrect sampling column but sampling never be used, disable this settings for starting the server without exception. #26256 (zhaoyu).
- Make
toTimeZone
monotonicity when timeZone is a constant value to support partition puring when use sql like:. #26261 (huangzhaowei). -
- When client connect to server, he receives information about all warnings that are already were collected by server. (It can be disabled by using option
--no-warnings
). #26282 (Filatenkov Artur).
- When client connect to server, he receives information about all warnings that are already were collected by server. (It can be disabled by using option
- Add a setting
function_range_max_elements_in_block
to tune the safety threshold for data volume generated by functionrange
. This closes #26303. #26305 (Alexey Milovidov). - Control the execution period of clear old temporary directories by parameter with default value. #26212. #26313 (fastio).
- Allow to reuse connections of shards among different clusters. It also avoids creating new connections when using
cluster
table function. #26318 (Amos Bird). - Add events to profile calls to sleep / sleepEachRow. #26320 (Raúl Marín).
- Save server address in history URLs in web UI if it differs from the origin of web UI. This closes #26044. #26322 (Alexey Milovidov).
- Add ability to set Distributed directory monitor settings via CREATE TABLE (i.e.
CREATE TABLE dist (key Int) Engine=Distributed(cluster, db, table) SETTINGS monitor_batch_inserts=1
and similar). #26336 (Azat Khuzhin). - Fix behaviour with non-existing host in user allowed host list. #26368 (ianton-ru).
- Added comments for the code written in https://github.com/ClickHouse/ClickHouse/pull/24206; the code has been improved in several places. #26377 (Vitaly Baranov).
- Enable
use_hedged_requests
setting that allows to mitigate tail latencies on large clusters. #26380 (Alexey Milovidov). - Updated protobuf to 3.17.3. Changelogs are available on https://github.com/protocolbuffers/protobuf/releases. #26424 (Ilya Yatsishin).
- After https://github.com/ClickHouse/ClickHouse/pull/26377. Encryption algorithm now should be specified explicitly if it's not default (
aes_128_ctr
):. #26465 (Vitaly Baranov). - Apply
LIMIT
on the shards for queries likeSELECT * FROM dist ORDER BY key LIMIT 10
w/distributed_push_down_limit=1
. Avoid runningDistinct
/LIMIT BY
steps for queries likeSELECT DISTINCT shading_key FROM dist ORDER BY key
. Nowdistributed_push_down_limit
is respected byoptimize_distributed_group_by_sharding_key
optimization. #26466 (Azat Khuzhin). -
- Set client query kind for mysql and postgresql handler. #26498 (anneji-dev).
- Executable dictionaries (ExecutableDictionarySource, ExecutablePoolDictionarySource) enable creation with DDL query using clickhouse-local. Closes #22355. #26510 (Maksim Kita).
- Add round-robin support for clickhouse-benchmark (it does not differ from the regular multi host/port run except for statistics report). #26607 (Azat Khuzhin).
- Improve the high performance machine to use the kafka engine. and it can recuce the query node work load. #26642 (feihengye).
- Avoid hanging clickhouse-benchmark if connection fails (i.e. on EMFILE). #26656 (Azat Khuzhin).
- Fix excessive (x2) connect attempts with skip_unavailable_shards. #26658 (Azat Khuzhin).
-
mapPopulatesSeries
function supportsMap
type. #26663 (Ildus Kurbangaliev).
- Improve handling of KILL QUERY requests. #26675 (Raúl Marín).
- SET PROFILE now applies constraints too if they're set for a passed profile. #26730 (Vitaly Baranov).
- Support multiple keys for encrypted disk. Display error message if the key is probably wrong. (see https://github.com/ClickHouse/ClickHouse/pull/26465#issuecomment-882015970). #26733 (Vitaly Baranov).
- remove uncessary exception thrown. #26740 (Caspian).
- Watchdog is disabled in docker by default. Fix for not handling ctrl+c. #26757 (Mikhail f. Shiryaev).
- Changing default roles affects new sessions only. #26759 (Vitaly Baranov).
- Less verbose internal RocksDB logs. This closes #26252. #26789 (Alexey Milovidov).
- Expose rocksdb statistics via system.rocksdb table. Read rocksdb options from ClickHouse config (
rocksdb
/rocksdb_TABLE
keys). #26821 (Azat Khuzhin). - Updated extractAllGroupsHorizontal - upper limit on the number of matches per row can be set via optional third argument. ... #26961 (Vasily Nemkov).
- Now functions can be shard-level constants, which means if it's executed in the context of some distributed table, it generates a normal column, otherwise it produces a constant value. Notable functions are:
hostName()
,tcpPort()
,version()
,buildId()
,uptime()
, etc. #27020 (Amos Bird). -
- Merge join correctly handles empty set in the right. #27078 (Vladimir C).
- Improve compatibility with non-whole-minute timezone offsets. #27080 (Raúl Marín).
- Enable distributed_push_down_limit by default. #27104 (Azat Khuzhin).
- Improved the existence condition judgment and empty string node judgment when clickhouse-keeper creates znode. #27125 (小路).
- Add compression for
INTO OUTFILE
that automatically choose compression algorithm. Closes #3473. #27134 (Filatenkov Artur). - add a new metric called MaxPushedDDLEntryID which is the maximum ddl entry id that current node push to zookeeper. #27174 (Fuwang Hu).
- Allow to pass query settings via server URI in Web UI. #27177 (kolsys).
- Added columns
replica_is_active
that maps replica name to is replica active status to tablesystem.replicas
. Closes #27138. #27180 (Maksim Kita). - Try recording
query_kind
even when query fails to start. #27182 (Amos Bird). - Mark window functions as ready for general use. Remove the
allow_experimental_window_functions
setting. #27184 (Alexander Kuzmenkov). - Memory client in client. #27191 (Filatenkov Artur).
- Support schema for postgres database engine. Closes #27166. #27198 (Kseniia Sumarokova).
- Split global mutex into individual regexp construction. This helps avoid huge regexp construction blocking other related threads. Not sure how to proper test the improvement. #27211 (Amos Bird).
- Add 10 seconds cache for S3 proxy resolver. #27216 (ianton-ru).
- Add new index data skipping minmax index format for proper Nullable support. #27250 (Azat Khuzhin).
- Memory consumed by bitmap aggregate functions now is taken into account for memory limits. This closes #26555. #27252 (Alexey Milovidov).
- Add two settings
max_hyperscan_regexp_length
andmax_hyperscan_regexp_total_length
to prevent huge regexp being used in hyperscan related functions, such asmultiMatchAny
. #27378 (Amos Bird). - Add setting
log_formatted_queries
to log additional formatted query intosystem.query_log
. It's useful for normalized query analysis because functions likenormalizeQuery
andnormalizeQueryKeepNames
don't parse/format queries in order to achieve better performance. #27380 (Amos Bird). - Add Cast function for internal usage, which will not preserve type nullability, but non-internal cast will preserve according to setting cast_keep_nullable. Closes #12636. #27382 (Kseniia Sumarokova).
- Send response with error message if HTTP port is not set and user tries to send HTTP request to TCP port. #27385 (Braulio Valdivielso Martínez).
- Use bytes instead of strings for binary data in the GRPC protocol. #27431 (Vitaly Baranov).
- Log client IP address if authentication fails. #27514 (Misko Lee).
- Disable arrayJoin on partition expressions. #27648 (Raúl Marín).
-
- Add
FROM INFILE
command. #27655 (Filatenkov Artur).
- Add
- Enables query parameters to be passed in the body of http requests. #27706 (Hermano Lustosa).
- Remove duplicate index analysis and avoid possible invalid limit checks during projection analysis. #27742 (Amos Bird).
Bug Fix
- Fix potential crash if more than one
untuple
expression is used. #26179 (Alexey Milovidov). - Remove excessive newline in
thread_name
column insystem.stack_trace
table. This fixes #24124. #26210 (Alexey Milovidov). - Fix logical error on join with totals, close #26017. #26250 (Vladimir C).
- Fix zstd decompression in case there are escape sequences at the end of internal buffer. Closes #26013. #26314 (Kseniia Sumarokova).
- Fixed rare bug in lost replica recovery that may cause replicas to diverge. #26321 (Alexander Tokmakov).
- Fix
optimize_distributed_group_by_sharding_key
for multiple columns (leads to incorrect result w/optimize_skip_unused_shards=1
/allow_nondeterministic_optimize_skip_unused_shards=1
and multiple columns in sharding key expression). #26353 (Azat Khuzhin). - Fix possible crash when login as dropped user. This PR fixes #26073. #26363 (Vitaly Baranov).
- Fix infinite non joined block stream in
partial_merge_join
close #26325. #26374 (Vladimir C). - Now, scalar subquery always returns
Nullable
result if it's type can beNullable
. It is needed because in case of empty subquery it's result should beNull
. Previously, it was possible to get error about incompatible types (type deduction does not execute scalar subquery, and it could use not-nullable type). Scalar subquery with empty result which can't be converted toNullable
(likeArray
orTuple
) now throws error. Fixes #25411. #26423 (Nikolai Kochetov). - Fix some fuzzed msan crash. Fixes #22517. #26428 (Nikolai Kochetov).
- Fix broken name resolution after rewriting column aliases. This fixes #26432. #26475 (Amos Bird).
- Fix issues with
CREATE DICTIONARY
query if dictionary name or database name was quoted. Closes #26491. #26508 (Maksim Kita). - Fix crash in rabbitmq shutdown in case rabbitmq setup was not started. Closes #26504. #26529 (Kseniia Sumarokova).
- Update
chown
cmd check in clickhouse-server docker entrypoint. It fixes the bug that cluster pod restart failed (or timeout) on kubernetes. #26545 (Ky Li). - Fix incorrect function names of groupBitmapAnd/Or/Xor. This fixes. #26557 (Amos Bird).
- Fix history file conversion if file is empty. #26589 (Azat Khuzhin).
- Fix potential nullptr dereference in window functions. This fixes #25276. #26668 (Alexander Kuzmenkov).
- ParallelFormattingOutputFormat: Use mutex to handle the join to the collector_thread (https://github.com/ClickHouse/ClickHouse/issues/26694). #26703 (Raúl Marín).
- Sometimes SET ROLE could work incorrectly, this PR fixes that. #26707 (Vitaly Baranov).
- Do not remove data on ReplicatedMergeTree table shutdown to avoid creating data to metadata inconsistency. #26716 (nvartolomei).
- Add
event_time_microseconds
value forREMOVE_PART
insystem.part_log
. In previous versions is was not set. #26720 (Azat Khuzhin). - Aggregate function parameters might be lost when applying some combinators causing exceptions like
Conversion from AggregateFunction(topKArray, Array(String)) to AggregateFunction(topKArray(10), Array(String)) is not supported
. It's fixed. Fixes #26196 and #26433. #26814 (Alexander Tokmakov). - Fix library-bridge ids load. #26834 (Kseniia Sumarokova).
- Fix error
Missing columns: 'xxx'
whenDEFAULT
column references other non materialized column withoutDEFAULT
expression. Fixes #26591. #26900 (alesapin). - Fix reading of custom TLDs (stops processing with lower buffer or bigger file). #26948 (Azat Khuzhin).
- Fix "Unknown column name" error with multiple JOINs in some cases, close #26899. #26957 (Vladimir C).
- Now partition ID in queries like
ALTER TABLE ... PARTITION ID xxx
validates for correctness. Fixes #25718. #26963 (alesapin). - [RFC] Fix possible mutation stack due to race with DROP_RANGE. #27002 (Azat Khuzhin).
- Fixed
cache
,complex_key_cache
,ssd_cache
,complex_key_ssd_cache
configuration parsing. Optionsallow_read_expired_keys
,max_update_queue_size
,update_queue_push_timeout_milliseconds
,query_wait_timeout_milliseconds
were not parsed for dictionaries with noncache
type. #27032 (Maksim Kita). - Fix synchronization in GRPCServer This PR fixes #27024. #27064 (Vitaly Baranov).
-
- Fix uninitialized memory in functions
multiSearch*
with empty array, close #27169. #27181 (Vladimir C).
- Fix uninitialized memory in functions
- In rare cases
system.detached_parts
table might contain incorrect information for some parts, it's fixed. Fixes #27114. #27183 (Alexander Tokmakov). - Fix on-disk format breakage for secondary indices over Nullable column (no stable release had been affected). #27197 (Azat Khuzhin).
- Fix column structure in merge join, close #27091. #27217 (Vladimir C).
- In case of ambiguity, lambda functions prefer its arguments to other aliases or identifiers. #27235 (Raúl Marín).
- Fix mutation stuck on invalid partitions in non-replicated MergeTree. #27248 (Azat Khuzhin).
- Fix
distributed_group_by_no_merge=2
+distributed_push_down_limit=1
oroptimize_distributed_group_by_sharding_key=1
withLIMIT BY
andLIMIT OFFSET
. #27249 (Azat Khuzhin). - Fix errors like
Expected ColumnLowCardinality, gotUInt8
orBad cast from type DB::ColumnVector<char8_t> to DB::ColumnLowCardinality
for some queries withLowCardinality
inPREWHERE
. Fixes #23515. #27298 (Nikolai Kochetov). - Fix
Cannot find column
error for queries with sampling. Was introduced in #24574. Fixes #26522. #27301 (Nikolai Kochetov). - Fix Mysql protocol when using parallel formats (CSV / TSV). #27326 (Raúl Marín).
- Fixed incorrect validation of partition id for MergeTree tables that created with old syntax. #27328 (Alexander Tokmakov).
- Fix incorrect result for query with row-level security, prewhere and LowCardinality filter. Fixes #27179. #27329 (Nikolai Kochetov).
- /proc/info contains metrics like. #27361 (Mike Kot).
- Fix distributed queries with zero shards and aggregation. #27427 (Azat Khuzhin).
- fix metric BackgroundMessageBrokerSchedulePoolTask, maybe mistyped。. #27452 (Ben).
- Fix crash during projection materialization when some parts contain missing columns. This fixes #27512. #27528 (Amos Bird).
- Fixed underflow of the time value when constructing it from components. Closes #27193. #27605 (Vasily Nemkov).
- After setting
max_memory_usage*
to non-zero value it was not possible to reset it back to 0 (unlimited). It's fixed. #27638 (Alexander Tokmakov). -
- Fix bug with aliased column in
Distributed
table. #27652 (Vladimir C).
- Fix bug with aliased column in
- Fixed another case of
Unexpected merged part ... intersecting drop range ...
error. #27656 (Alexander Tokmakov). - Fix postgresql table function resulting in non-closing connections. Closes #26088. #27662 (Kseniia Sumarokova).
- Fix bad type cast when functions like
arrayHas
are applied to arrays of LowCardinality of Nullable of different non-numeric types likeDateTime
andDateTime64
. In previous versions bad cast occurs. In new version it will lead to exception. This closes #26330. #27682 (Alexey Milovidov). - Fix column filtering with union distinct in subquery. Closes #27578. #27689 (Kseniia Sumarokova).
- After https://github.com/ClickHouse/ClickHouse/pull/26384. To execute
GRANT WITH REPLACE OPTION
now the current user should haveGRANT OPTION
for access rights it's going to grant AND for access rights it's going to revoke. #27701 (Vitaly Baranov). - After https://github.com/ClickHouse/ClickHouse/pull/25687. Add backquotes for the default database shown in CREATE USER. #27702 (Vitaly Baranov).
- Remove duplicated source files in CMakeLists.txt in arrow-cmake. #27736 (李扬).
- Fix possible crash when asynchronous connection draining is enabled and hedged connection is disabled. #27774 (Amos Bird).
- Prevent crashes for some formats when NULL (tombstone) message was coming from Kafka. Closes #19255. #27794 (filimonov).
- Fix a rare bug in
DROP PART
which can lead to the errorUnexpected merged part intersects drop range
. #27807 (alesapin). - Fix a couple of bugs that may cause replicas to diverge. #27808 (Alexander Tokmakov).
Build/Testing/Packaging Improvement
- Update RocksDB to 2021-07-16 master. #26411 (Alexey Milovidov).
clickhouse-test
supports SQL tests with Jinja2 templates. #26579 (Vladimir C).- Fix /clickhouse/window functions/tests/non distributed/errors/error window function in join. #26744 (vzakaznikov).
- Enabling RBAC TestFlows tests and crossing out new fails. #26747 (vzakaznikov).
- Tests: Fix CLICKHOUSE_CLIENT_SECURE with the default config. #26901 (Raúl Marín).
- Fix linking of auxiliar programs when using dynamic libraries. #26958 (Raúl Marín).
- Add CMake options to build with or without specific CPU instruction set. This is for #17469 and #27509. #27508 (Alexey Milovidov).
- Add support for build with
clang-13
. This closes #27705. #27714 (Alexey Milovidov). - Improve support for build with
clang-13
. #27777 (Sergei Semin).
Other
- Rename
MaterializeMySQL
toMaterializedMySQL
. #26822 (Alexander Tokmakov).
NO CL ENTRY
- NO CL ENTRY: 'Modify code comments'. #26265 (xiedeyantu).
- NO CL ENTRY: 'Revert "Datatype Date32, support range 1925 to 2283"'. #26352 (Alexey Milovidov).
- NO CL ENTRY: 'Fix CURR_DATABASE empty for 01034_move_partition_from_table_zookeeper.sh'. #27164 (小路).
- NO CL ENTRY: 'DOCSUP-12413: macros support in functions cluster and clusterAllReplicas'. #27759 (olgarev).
- NO CL ENTRY: 'Revert "less sys calls #2: make vdso work again"'. #27829 (Alexey Milovidov).
- NO CL ENTRY: 'Revert "Do not miss exceptions from the ThreadPool"'. #27844 (Alexey Milovidov).
NOT FOR CHANGELOG / INSIGNIFICANT
- Fix prometheus metric name #26140 (Vladimir C).
- Add comments for the implementations of the pad functions #26147 (Vitaly Baranov).
- Change color in client for double colon #26152 (Anton Popov).
- Remove misleading stderr output #26155 (Kseniia Sumarokova).
- Merging #26041. #26180 (Alexey Milovidov).
- Fix bad code (default function argument) #26213 (Alexey Milovidov).
- Support for
pread
inReadBufferFromFile
#26232 (Alexey Milovidov). - Fix ReadBufferFromS3 #26249 (Vitaly Baranov).
- Fix output of TSV in integration tests #26257 (Anton Popov).
- Enum type additional support for compilation #26258 (Maksim Kita).
- Bump poco (now poco fork has CI via github actions) #26262 (Azat Khuzhin).
- Add check for sqlite database path #26266 (Kseniia Sumarokova).
- Fix arcadia #26285 (Nikita Mikhaylov).
- yandex/clickhouse-test-base Dockerfile fix (mysql connector moved) #26294 (Ilya Golshtein).
- Improve read_file_to_stringcolumn test compatibility #26317 (Raúl Marín).
- Make socket poll() 7x faster (by replacing epoll() with poll()) #26323 (Azat Khuzhin).
- Modifications to an obscure Yandex TSKV format #26326 (egatov).
- Fixing RBAC sample by tests in TestFlows. #26329 (vzakaznikov).
- Fix error in stress test script #26349 (Alexey Milovidov).
- Fix flaky integration test about "replicated max parallel fetches". #26362 (Alexey Milovidov).
- Continuation of #25774 #26364 (Kseniia Sumarokova).
- Enabling all TestFlows modules except LDAP after Kerberos merge. #26366 (vzakaznikov).
- Fix flaky test 01293_client_interactive_vertical_multiline_long #26367 (Alexey Milovidov).
- Small bugfix in Block #26373 (Anton Popov).
- More integration tests improvements. #26375 (Ilya Yatsishin).
- Fix arcadia #26378 (Kseniia Sumarokova).
- Add separate step to read from remote. #26381 (Nikolai Kochetov).
- Fix calculating of intersection of access rights. #26383 (Vitaly Baranov).
- Less logging in AsynchronousMetrics #26391 (Alexey Milovidov).
- stress tests report improvements #26393 (Azat Khuzhin).
- Fix failed assertion in RocksDB in case of bad_alloc exception during batch write #26394 (Alexey Milovidov).
- Add integrity for loaded scripts in play.html #26409 (Vladimir C).
- Relax condition in flaky test #26425 (Alexey Milovidov).
- Split FunctionsCoding into several files #26426 (Vladimir C).
- Remove MySQLWireContext #26429 (Vitaly Baranov).
- Fix "While sending batch" (on Distributed async send) #26430 (Azat Khuzhin).
- Tests fixes v21.9.1.7477 #26431 (Azat Khuzhin).
- Fix flaky test_replicated_mutations (due to lack of threads in pool) #26461 (Azat Khuzhin).
- Fix undefined-behavior in DirectoryMonitor (for exponential back off) #26464 (Azat Khuzhin).
- Remove some code #26468 (Alexey Milovidov).
- Rewrite distributed DDL to Processors #26469 (Alexey Milovidov).
- Fix flaky test
distributed_ddl_output_mode
#26470 (Alexey Milovidov). - Update link to dpkg-deb in dockerfiles #26497 (Vladimir C).
- SELECT String from ClickHouse as Avro string - PartialMatch #26499 (Ilya Golshtein).
- Fix arcadia #26505 (Anton Popov).
- Fix build under AppleClang 12 #26509 (Nikita Mikhaylov).
- fix lagInFrame for nullable types #26521 (Alexander Kuzmenkov).
- Handle empty testset in 'Functional stateless tests flaky check' #26552 (Vladimir C).
- Remove some streams. #26590 (Nikolai Kochetov).
- Fix flaky test 01622_defaults_for_url_engine #26617 (Alexey Milovidov).
- Fix flaky test 01509_check_many_parallel_quorum_inserts #26618 (Alexey Milovidov).
- Fix one possible cause of tests flakiness #26619 (Alexey Milovidov).
- Remove some code, more C++ way #26620 (Alexey Milovidov).
- Fix mysql_kill_sync_thread_restore_test #26673 (Vladimir C).
- Minor bugfix #26678 (Anton Popov).
- copypaste error #26679 (Denny Crane).
- Fix flaky test
mutation_stuck_after_replace_partition
#26684 (Alexey Milovidov). - Log errors on integration test listing error in ci-runner #26691 (Vladimir C).
- more debug checks for window functions #26701 (Alexander Kuzmenkov).
- record server exit code in fuzzer #26706 (Alexander Kuzmenkov).
- Remove more streams. #26713 (Nikolai Kochetov).
- 01946_test_wrong_host_name_access: Clear DNS in the end #26715 (Raúl Marín).
- Setting min_count_to_compile_aggregate_expression fix #26718 (Maksim Kita).
- Compile aggregate functions profile events fix #26719 (Maksim Kita).
- Fix use after free in AsyncDrain connection from S3Cluster #26731 (Vladimir C).
- Fixed wrong error message in
S3Common
#26738 (Vladimir Chebotarev). - Lock mutex before access to std::cerr in clickhouse-benchmark #26742 (Vladimir C).
- Remove some output streams #26758 (Nikolai Kochetov).
- Merging #25960 (Bolonini/read_from_file) #26777 (Alexey Milovidov).
- Heredoc updated tests #26784 (Maksim Kita).
- Fix double unlock in RocksDB #26786 (Alexey Milovidov).
- Fix sqlite engine attach #26795 (Kseniia Sumarokova).
- Remove unneeded mutex during connection draining #26807 (Amos Bird).
- Make sure table is readonly when restarting fails. #26808 (Amos Bird).
- Check stdout for messages to retry in clickhouse-test #26817 (Alexander Tokmakov).
- Fix killing unstopped containers in integration tests. #26818 (Vitaly Baranov).
- Do not start new hedged connection if query was already canceled. #26820 (Nikolai Kochetov).
- Try fix rabbitmq tests #26826 (Kseniia Sumarokova).
- Wait for self datasource to be initialized in test_jdbc_bridge #26827 (Ilya Yatsishin).
- Flush LazyOutputFormat on query cancel. #26828 (Nikolai Kochetov).
- Try fix timeout in functional tests with pytest #26830 (Alexander Tokmakov).
- Compile aggregate functions without key #26845 (Maksim Kita).
- Introduce sessions #26864 (Vitaly Baranov).
- Fix rabbitmq sink #26871 (Kseniia Sumarokova).
- One more library bridge fix #26873 (Kseniia Sumarokova).
- Fix keeper bench compilation #26874 (Raúl Marín).
- Better integration tests #26894 (Ilya Yatsishin).
- Maybe fix extremely rare
intersecting parts
. #26896 (alesapin). - Try increase diff upper bound #26897 (Ilya Yatsishin).
- Enable Arrow format in Arcadia #26898 (Vitaly Stoyan).
- Improve test compatibility (00646_url_engine and 01854_HTTP_dict_decompression) #26915 (Raúl Marín).
- Update NuRaft #26916 (alesapin).
- 01921_datatype_date32: Adapt it to work under Pacific/Fiji #26918 (Raúl Marín).
- Remove unused files that confuse developers #26913 #26947 (Alexey Milovidov).
- Set allow_remote_fs_zero_copy_replication to true by default #26951 (ianton-ru).
- Hold context in HedgedConnections to prevent use-after-free on settings. #26953 (Nikolai Kochetov).
- Fix client options in stress test #26959 (Alexander Tokmakov).
- fix window function partition boundary search #26960 (Alexander Kuzmenkov).
- Print trace from std::terminate exception line-by-line to make it grep easier #26962 (Nikolai Kochetov).
- Fix system.zookeeper_log initialization #26972 (Alexander Tokmakov).
- Benchmark script fix #26974 (Maksim Kita).
- Fix 01600_quota_by_forwarded_ip #26975 (Raúl Marín).
- 01674_executable_dictionary_implicit_key: executable_dictionary: Use printf #26978 (Raúl Marín).
- Remove test_keeper_server usage (for {operation/session}_timeout_ms) #26984 (Azat Khuzhin).
- Set insert_quorum_timeout to 1 minute for tests. #27007 (Alexander Tokmakov).
- Adjust 00537_quarters to be timezone independent #27008 (Raúl Marín).
- Help with #26424 #27009 (Alexey Milovidov).
- Attempt to fix flaky 00705_drop_create_merge_tree #27023 (Raúl Marín).
- Improved
runner
to usepytest
keyword expressions #27026 (Vladimir Chebotarev). - Improve 01006_simpod_empty_part_single_column_write #27028 (Raúl Marín).
- Improved logging of
hwmon
sensor errors inAsynchronousMetrics
#27031 (Vladimir Chebotarev). - Fix assertions in Replicated database #27033 (Alexander Tokmakov).
- Make test 01852_cast_operator independent of timezone #27037 (Alexey Milovidov).
- Moving to TestFlows 1.7.20 that has native support for parallel tests. #27040 (vzakaznikov).
- library bridge fixes #27060 (Kseniia Sumarokova).
- Fix synchronization while updating from the config of an encrypted disk. #27065 (Vitaly Baranov).
- Fix excessive logging in NuRaft on server shutdown #27081 (alesapin).
- Fix test_merge_tree_s3_failover with debug build #27089 (ianton-ru).
- Stateless tests: Keep an DNS error free log #27092 (Raúl Marín).
- Normalize hostname in stateless tests #27093 (Amos Bird).
- Try update AMQP-CPP #27095 (Ilya Yatsishin).
- Try update arrow #27097 (Ilya Yatsishin).
- GlobalSubqueriesVisitor external storage check fix #27131 (Maksim Kita).
- Better code around decompression #27136 (Nikita Mikhaylov).
- Add test for parsing maps with integer keys #27146 (Anton Popov).
- Fix arcadia src/Access gtest #27152 (Ilya Yatsishin).
- Implement
legacy_column_name_of_tuple_literal
in a less intrusive way #27153 (Anton Popov). - Updated readIntTextUnsafe #27155 (Maksim Kita).
- Safer
ReadBufferFromS3
for merges and backports #27168 (Vladimir Chebotarev). - properly check the settings in perf test #27190 (Alexander Kuzmenkov).
- Save information about used functions/tables/... into query_log on error #27194 (Azat Khuzhin).
- Fix polling of /sys/block #27195 (Azat Khuzhin).
- Allow parallel execution of *.sql tests with ReplicatedMergeTree (by using {database} macro) #27214 (Azat Khuzhin).
- Fix NLP performance test #27219 (Nikolay Degterinsky).
- Update changelog/README.md #27221 (filimonov).
- more careful handling of reconnects in fuzzer #27222 (Alexander Kuzmenkov).
- ADDINCL proper fast_float directory #27224 (Yuriy Chernyshov).
- DatabaseReplicatedWorker logs_to_keep race fix #27225 (Maksim Kita).
- Revert #24095. User-level settings will affect queries from view. #27227 (Nikolai Kochetov).
- Using formatted string literals in clickhouse-test, extracted sort key functions and stacktraces printer #27228 (Mike Kot).
- Fix polling of /sys/block in case of block devices reopened on error #27266 (Azat Khuzhin).
- Remove streams from dicts #27273 (Nikolai Kochetov).
- 01099_operators_date_and_timestamp: Use dates that work with all available timezones #27275 (Raúl Marín).
- Improve kafka integration test error messages #27294 (Raúl Marín).
- Improve 00738_lock_for_inner_table stability #27300 (Raúl Marín).
- Add and check system.projection_parts for database filter #27303 (Azat Khuzhin).
- Update PVS checksum #27317 (Alexander Tokmakov).
- Fix 01300_client_save_history_when_terminated_long #27324 (Raúl Marín).
- Try update contrib/zlib-ng #27327 (Ilya Yatsishin).
- Fix flacky test #27383 (Kseniia Sumarokova).
- Add and check system.mutations for database filter #27384 (Azat Khuzhin).
- Correct the key data type used in mapContains #27423 (Fuwang Hu).
- Fix tests for WithMergeableStateAfterAggregationAndLimit #27424 (Azat Khuzhin).
- Do not miss exceptions from the ThreadPool #27428 (Azat Khuzhin).
- Accept error code by error name in client test hints #27430 (Azat Khuzhin).
- Added reserve method to Block #27483 (Nikita Mikhaylov).
- make it possible to cancel window functions on ctrl+c #27487 (Alexander Kuzmenkov).
- Fix Nullable const columns in JOIN #27516 (Vladimir C).
- Fix Logical error: 'Table UUID is not specified in DDL log' #27521 (Alexander Tokmakov).
- Fix 01236_graphite_mt for random timezones #27525 (Raúl Marín).
- Add timeout for integration tests runner #27535 (Alexander Tokmakov).
- Fix polling of /sys/class on errors #27554 (Azat Khuzhin).
- fix recalculate QueryMemoryLimitExceeded event error #27556 (Ben).
- Fix 01961_roaring_memory_tracking for split builds #27557 (Raúl Marín).
- Improve the experience of running stateless tests locally #27561 (Raúl Marín).
- Fix integration tests #27562 (Kseniia Sumarokova).
- Dictionaries refactor #27566 (Maksim Kita).
- Less Stopwatch.h #27569 (filimonov).
- Aggregation temporary disable compilation without key #27574 (Maksim Kita).
- Removed some data streams #27575 (Maksim Kita).
- Remove streams from lv #27577 (Nikolai Kochetov).
- fix ProfileEvents::CompileFunction #27606 (Ben).
- Refactor mysql format check #27609 (Raúl Marín).
- enable part_log by default #27631 (Denny Crane).
- Remove the remains of ANTLR in the tests #27637 (Raúl Marín).
- MV: Improve text logs when doing parallel processing #27639 (Raúl Marín).
- Fix test_sqlite_odbc_hashed_dictionary #27647 (Kseniia Sumarokova).
- Add a test for #10735 #27677 (Alexey Milovidov).
- Disable memory tracking for roaring bitmaps on Mac OS #27681 (Alexey Milovidov).
- Use only SSE2 in "unbundled" build #27683 (Alexey Milovidov).
- Remove trash #27685 (Alexey Milovidov).
- Fix stress test in
~CompressedWriteBuffer
#27686 (Alexey Milovidov). - Mark tests for
DatabaseReplicated
as green #27688 (Alexey Milovidov). - Removed DenseHashMap, DenseHashSet #27690 (Maksim Kita).
- Map data type parsing tests #27692 (Maksim Kita).
- Refactor arrayJoin check on partition expressions #27733 (Raúl Marín).
- Fix test 01014_lazy_database_concurrent_recreate_reattach_and_show_tables #27734 (Alexander Tokmakov).
- Disable jemalloc under OSX #27751 (Raúl Marín).
- Fix jemalloc under osx (zone_register() had been optimized out again) #27753 (Azat Khuzhin).
- Fix intersect/except with limit #27757 (Kseniia Sumarokova).
- Add HTTP string parsing test #27762 (Nikolay Degterinsky).
- Fix some tests #27785 (Alexander Tokmakov).
- Set function divide as suitable for short-circuit in case of Nullable(Decimal) #27788 (Kruglov Pavel).
- Remove unnecessary files #27789 (Kruglov Pavel).
- Revert "Mark tests for
DatabaseReplicated
as green" #27791 (Alexander Tokmakov). - Remove hardening for watches in DDLWorker #27792 (Alexander Tokmakov).
- Stateless test: Cleanup leftovers #27793 (Raúl Marín).
- Dictionaries key types refactoring #27795 (Maksim Kita).
- Update 01822_short_circuit.reference (after merging #27680) #27802 (Azat Khuzhin).
- Proper shutdown global context #27804 (Amos Bird).
- 01766_todatetime64_no_timezone_arg: Use a date without timezone changes #27810 (Raúl Marín).
- Fix setting name "allow_experimental_database_materialized_postgresql" in the error message #27824 (Denny Crane).
- Fix bug in short-circuit found by fuzzer #27826 (Kruglov Pavel).