Optional allow_Optional allow_Allow Nullable types as primary keys.
Optional allow_Don't use this setting in production, because it is not ready.
Optional allow_Reject primary/secondary indexes and sorting keys with identical expressions
Optional allow_Allows vertical merges from compact to wide parts. This settings must have the same value on all replicas
Optional always_If true, replica never merge parts and always download merged parts from other replicas.
Optional assign_Generate UUIDs for parts. Before enabling check that all replicas support new format.
Optional async_minimum interval between updates of async_block_ids_cache
Optional async_If true, data from INSERT query is stored in queue and later flushed to table in background.
Optional check_Obsolete setting, does nothing.
Optional check_Check columns or columns by hash for sampling are unsigned integer.
Optional clean_Is the Replicated Merge cleanup has to be done automatically at each merge or manually (possible values are 'Always'/'Never' (default))
Optional cleanup_Minimum period to clean old queue logs, blocks hashes and parts.
Optional cleanup_Add uniformly distributed value from 0 to x seconds to cleanup_delay_period to avoid thundering herd effect and subsequent DoS of ZooKeeper in case of very large number of tables.
Optional cleanup_Preferred batch size for background cleanup (points are abstract but 1 point is approximately equivalent to 1 inserted block).
Optional compatibility_Allow to create a table with sampling expression not in primary key. This is needed only to temporarily allow to run the server with wrong tables for backward compatibility.
Optional compress_Marks support compression, reduce mark file size and speed up network transmission.
Optional compress_Primary key support compression, reduce primary key file size and speed up network transmission.
Optional concurrent_Activate concurrent part removal (see 'max_part_removal_threads') only if the number of inactive data parts is at least this.
Optional detach_Do not remove non byte-identical parts for ReplicatedMergeTree, instead detach them (maybe useful for further analysis).
Optional detach_Do not remove old local parts when repairing lost replica.
Optional diskName of storage disk. Can be specified instead of storage policy.
Optional enable_Enable parts with adaptive and non-adaptive granularity
Optional enable_Enable the endpoint id with zookeeper name prefix for the replicated merge tree table
Optional enable_Enable usage of Vertical merge algorithm.
Optional execute_When greater than zero only a single replica starts the merge immediately, others wait up to that amount of time to download the result instead of doing merges locally. If the chosen replica doesn't finish the merge during that amount of time, fallback to standard behavior happens.
Optional finished_How many records about mutations that are done to keep. If zero, then keep all of them.
Optional fsync_Do fsync for every inserted part. Significantly decreases performance of inserts, not recommended to use with wide parts.
Optional fsync_Do fsync for part directory after all part operations (writes, renames, etc.).
Optional in_Obsolete setting, does nothing.
Optional in_Obsolete setting, does nothing.
Optional inactive_If table contains at least that many inactive parts in single partition, artificially slow down insert into table.
Optional inactive_If more than this number inactive parts in single partition, throw 'Too many inactive parts ...' exception.
Optional index_How many rows correspond to one primary key value.
Optional index_Approximate amount of bytes in single granule (0 - disabled).
Optional initialization_Retry period for table initialization, in seconds.
Optional lock_For background operations like merges, mutations etc. How many seconds before failing to acquire table locks.
Optional marks_Mark compress block size, the actual size of the block to compress.
Optional marks_Compression encoding used by marks, marks are small enough and cached, so the default compression is ZSTD(3).
Optional materialize_Only recalculate ttl info when MATERIALIZE TTL
Optional max_The 'too many parts' check according to 'parts_to_delay_insert' and 'parts_to_throw_insert' will be active only if the average part size (in the relevant partition) is not larger than the specified threshold. If it is larger than the specified threshold, the INSERTs will be neither delayed or rejected. This allows to have hundreds of terabytes in a single table on a single server if the parts are successfully merged to larger parts. This does not affect the thresholds on inactive parts or total parts.
Optional max_Maximum in total size of parts to merge, when there are maximum free threads in background pool (or entries in replication queue).
Optional max_Maximum in total size of parts to merge, when there are minimum free threads in background pool (or entries in replication queue).
Optional max_Maximum period to clean old queue logs, blocks hashes and parts.
Optional max_Compress the pending uncompressed data in buffer if its size is larger or equal than the specified threshold. Block of data will be compressed even if the current granule is not finished. If this setting is not set, the corresponding global setting is used.
Optional max_Max number of concurrently executed queries related to the MergeTree table (0 - disabled). Queries will still be limited by other max_concurrent_queries settings.
Optional max_Max delay of inserting data into MergeTree table in seconds, if there are a lot of unmerged parts in single partition.
Optional max_Max delay of mutating MergeTree table in milliseconds, if there are a lot of unfinished mutations
Optional max_Max number of bytes to digest per segment to build GIN index.
Optional max_Not apply ALTER if number of files for modification(deletion, addition) more than this.
Optional max_Not apply ALTER, if number of files for deletion more than this.
Optional max_Maximum sleep time for merge selecting, a lower setting will trigger selecting tasks in background_schedule_pool frequently which result in large amount of requests to zookeeper in large-scale clusters
Optional max_When there is more than specified number of merges with TTL entries in pool, do not assign new merge with TTL. This is to leave free threads for regular merges and avoid "Too many parts"
Optional max_Limit the number of part mutations per replica to the specified amount. Zero means no limit on the number of mutations per replica (the execution can still be constrained by other settings).
Optional max_Obsolete setting, does nothing.
Optional max_Obsolete setting, does nothing.
Optional max_Limit the max number of partitions that can be accessed in one query. <= 0 means unlimited. This setting is the default that can be overridden by the query-level setting with the same name.
Optional max_If more than this number active parts in all partitions in total, throw 'Too many parts ...' exception.
Optional max_Max amount of parts which can be merged at once (0 - disabled). Doesn't affect OPTIMIZE FINAL query.
Optional max_The maximum speed of data exchange over the network in bytes per second for replicated fetches. Zero means unlimited.
Optional max_How many records may be in log, if there is inactive replica. Inactive replica becomes lost when when this number exceed.
Optional max_How many tasks of merging and mutating parts are allowed simultaneously in ReplicatedMergeTree queue.
Optional max_How many tasks of merging parts with TTL are allowed simultaneously in ReplicatedMergeTree queue.
Optional max_How many tasks of mutating parts are allowed simultaneously in ReplicatedMergeTree queue.
Optional max_The maximum speed of data exchange over the network in bytes per second for replicated sends. Zero means unlimited.
Optional max_Max broken parts, if more - deny automatic deletion.
Optional max_Max size of all broken parts, if more - deny automatic deletion.
Optional merge_How many rows in blocks should be formed for merge operations. By default, has the same value as index_granularity.
Optional merge_How many bytes in blocks should be formed for merge operations. By default, has the same value as index_granularity_bytes.
Optional merge_Maximum sleep time for merge selecting, a lower setting will trigger selecting tasks in background_schedule_pool frequently which result in large amount of requests to zookeeper in large-scale clusters
Optional merge_The sleep time for merge selecting task is multiplied by this factor when there's nothing to merge and divided when a merge was assigned
Optional merge_Remove old broken detached parts in the background if they remained untouched for a specified by this setting period of time.
Optional merge_The period of executing the clear old parts operation in background.
Optional merge_The period of executing the clear old temporary directories operation in background.
Optional merge_Enable clearing old broken detached parts operation in background.
Optional merge_Minimal time in seconds, when merge with recompression TTL can be repeated.
Optional merge_Minimal time in seconds, when merge with delete TTL can be repeated.
Optional min_Minimal absolute delay to close, stop serving requests and not return Ok during status check.
Optional min_Whether min_age_to_force_merge_seconds should be applied only on the entire partition and not on subset.
Optional min_If all parts in a certain range are older than this value, range will be always eligible for merging. Set to 0 to disable.
Optional min_Obsolete setting, does nothing.
Optional min_Minimal uncompressed size in bytes to create part in wide format instead of compact
Optional min_Minimal amount of bytes to enable part rebalance over JBOD array (0 - disabled).
Optional min_When granule is written, compress the data in buffer if the size of pending uncompressed data is larger or equal than the specified threshold. If this setting is not set, the corresponding global setting is used.
Optional min_Minimal number of compressed bytes to do fsync for part after fetch (0 - disabled)
Optional min_Minimal number of compressed bytes to do fsync for part after merge (0 - disabled)
Optional min_Min delay of inserting data into MergeTree table in milliseconds, if there are a lot of unmerged parts in single partition.
Optional min_Min delay of mutating MergeTree table in milliseconds, if there are a lot of unfinished mutations
Optional min_Minimum amount of bytes in single granule.
Optional min_Minimal number of marks to honor the MergeTree-level's max_concurrent_queries (0 - disabled). Queries will still be limited by other max_concurrent_queries settings.
Optional min_Minimal amount of bytes to enable O_DIRECT in merge (0 - disabled).
Optional min_Minimal delay from other replicas to close, stop serving requests and not return Ok during status check.
Optional min_Calculate relative replica delay only if absolute delay is not less that this value.
Optional min_Obsolete setting, does nothing.
Optional min_Keep about this number of last records in ZooKeeper log, even if they are obsolete. It doesn't affect work of tables: used only to diagnose ZooKeeper log before cleaning.
Optional min_Obsolete setting, does nothing.
Optional min_Minimal number of rows to create part in wide format instead of compact
Optional min_Minimal number of rows to do fsync for part after merge (0 - disabled)
Optional non_How many last blocks of hashes should be kept on disk (0 - disabled).
Optional number_When there is less than specified number of free entries in pool, do not execute part mutations. This is to leave free threads for regular merges and avoid "Too many parts"
Optional number_When there is less than specified number of free entries in pool (or replicated queue), start to lower maximum size of merge to process (or to put in queue). This is to allow small merges to process - not filling the pool with long running merges.
Optional number_If table has at least that many unfinished mutations, artificially slow down mutations of table. Disabled if set to 0
Optional number_If table has at least that many unfinished mutations, throw 'Too many mutations' exception. Disabled if set to 0
Optional old_How many seconds to keep obsolete parts.
Optional part_Time to wait before/after moving parts between shards.
Optional part_Experimental/Incomplete feature to move parts between shards. Does not take into account sharding expressions.
Optional parts_If table contains at least that many active parts in single partition, artificially slow down insert into table. Disabled if set to 0
Optional parts_If more than this number active parts in single partition, throw 'Too many parts ...' exception.
Optional prefer_If sum size of parts exceeds this threshold and time passed after replication log entry creation is greater than "prefer_fetch_merged_part_time_threshold", prefer fetching merged part from replica instead of doing merge locally. To speed up very long merges.
Optional prefer_If time passed after replication log entry creation exceeds this threshold and sum size of parts is greater than "prefer_fetch_merged_part_size_threshold", prefer fetching merged part from replica instead of doing merge locally. To speed up very long merges.
Optional primary_Primary compress block size, the actual size of the block to compress.
Optional primary_Compression encoding used by primary, primary key is small enough and cached, so the default compression is ZSTD(3).
Optional ratio_Minimal ratio of number of default values to number of all values in column to store it in sparse serializations. If >= 1, columns will be always written in full serialization.
Optional remote_When greater than zero only a single replica starts the merge immediately if merged part on shared storage and 'allow_remote_fs_zero_copy_replication' is enabled.
Optional remote_Run zero-copy in compatible mode during conversion process.
Optional remote_ZooKeeper path for zero-copy table-independent info.
Optional remove_Remove empty parts after they were pruned by TTL, mutation, or collapsing merge algorithm.
Optional remove_Setting for an incomplete experimental feature.
Optional replicated_If true, Replicated tables replicas on this node will try to acquire leadership.
Optional replicated_How many last blocks of hashes should be kept in ZooKeeper (old blocks will be deleted).
Optional replicated_How many last hash values of async_insert blocks should be kept in ZooKeeper (old blocks will be deleted).
Optional replicated_Similar to "replicated_deduplication_window", but determines old blocks by their lifetime. Hash of an inserted block will be deleted (and the block will not be deduplicated after) if it outside of one "window". You can set very big replicated_deduplication_window to avoid duplicating INSERTs during that period of time.
Optional replicated_Similar to "replicated_deduplication_window_for_async_inserts", but determines old blocks by their lifetime. Hash of an inserted block will be deleted (and the block will not be deduplicated after) if it outside of one "window". You can set very big replicated_deduplication_window to avoid duplicating INSERTs during that period of time.
Optional replicated_HTTP connection timeout for part fetch requests. Inherited from default profile http_connection_timeout if not set explicitly.
Optional replicated_HTTP receive timeout for fetch part requests. Inherited from default profile http_receive_timeout if not set explicitly.
Optional replicated_HTTP send timeout for part fetch requests. Inherited from default profile http_send_timeout if not set explicitly.
Optional replicated_Max number of mutation commands that can be merged together and executed in one MUTATE_PART entry (0 means unlimited)
Optional replicated_Obsolete setting, does nothing.
Optional replicated_Limit parallel fetches from endpoint (actually pool size).
Optional replicated_Obsolete setting, does nothing.
Optional replicated_Obsolete setting, does nothing.
Optional replicated_Obsolete setting, does nothing.
Optional replicated_If ratio of wrong parts to total number of parts is less than this - allow to start.
Optional simultaneous_Maximum number of parts to remove during one CleanupThread iteration (0 means unlimited).
Optional storage_Name of storage disk policy
Optional temporary_How many seconds to keep tmp_-directories. You should not lower this value because merges and mutations may not be able to work with low value of this setting.
Optional try_Recompression works slow in most cases, so we don't start merge with recompression until this timeout and trying to fetch recompressed part from replica which assigned this merge with recompression.
Optional ttl_Only drop altogether the expired parts and not partially prune them.
Optional use_use in-memory cache to filter duplicated async inserts based on block ids
Optional use_Experimental feature to speed up parts loading process by using MergeTree metadata cache
Optional use_Use small format (dozens bytes) for part checksums in ZooKeeper instead of ordinary ones (dozens KB). Before enabling check that all replicas support new format.
Optional use_Store part header (checksums and columns) in a compact format and a single part znode instead of separate znodes (
Optional vertical_Minimal (approximate) uncompressed size in bytes in merging parts to activate Vertical merge algorithm.
Optional vertical_Minimal amount of non-PK columns to activate Vertical merge algorithm.
Optional vertical_Minimal (approximate) sum of rows in merging parts to activate Vertical merge algorithm.
Optional write_Obsolete setting, does nothing.
Optional write_Obsolete setting, does nothing.
Optional write_Obsolete setting, does nothing.
Optional write_Obsolete setting, does nothing.
Optional zero_Max percentage of top level parts to postpone removal in order to get smaller independent ranges (highly not recommended to change)
Optional zero_Max recursion depth for splitting independent Outdated parts ranges into smaller subranges (highly not recommended to change)
Optional zero_If zero copy replication is enabled sleep random amount of time before trying to lock depending on parts size for merge or mutation
Optional zookeeper_ZooKeeper session expiration check period, in seconds.
Generated using TypeDoc
Allow floating point as partition key