Tunable Configuration Properties
Tunable properties are cluster properties that are specifically designed for tuning a cluster. For information on how to edit tunable properties, refer to Configuring Cluster Properties.
The following table lists the available tunable properties:
Property | Description |
---|---|
abort_index_segment_size |
Capacity (in number of txns) of an abort index segment. |
abort_timed_out_transactions_interval_ms |
How often to look for the inactive transactions and abort them. |
alter_topic_cfg_timeout_ms |
Time to wait for entries replication in controller log when executing alter configuration request. |
append_chunk_size |
Size of direct write operations to disk. |
cloud_storage_cache_check_interval |
Timeout to check if cache eviction should be triggered. |
cloud_storage_enable_remote_read |
Enable remote read for all topics. |
cloud_storage_enable_remote_write |
Enable remote write for all topics. |
cloud_storage_initial_backoff_ms |
Initial backoff time for exponential backoff algorithm (ms). |
cloud_storage_manifest_upload_timeout_ms |
Manifest upload timeout (ms). |
cloud_storage_max_connection_idle_time_ms |
Max https connection idle time (ms). |
cloud_storage_reconciliation_interval_ms |
Interval at which the archival service runs reconciliation (ms). |
cloud_storage_segment_max_upload_interval_sec |
Time that segment can be kept locally without uploading it to the remote storage (sec). |
cloud_storage_segment_upload_timeout_ms |
Log segment upload timeout (ms). |
cloud_storage_upload_ctrl_d_coeff |
Derivative coefficient for upload PID controller. |
cloud_storage_upload_ctrl_max_shares |
Maximum number of I/O and CPU shares that archival upload can use. |
cloud_storage_upload_ctrl_min_shares |
Minimum number of I/O and CPU shares that archival upload can use. |
cloud_storage_upload_ctrl_p_coeff |
Proportional coefficient for upload PID controller. |
cloud_storage_upload_ctrl_update_interval_ms |
No description. |
compacted_log_segment_size |
How large in bytes each compacted log segment should be (default 256 MB). |
compaction_ctrl_backlog_size |
Target backlog size for compaction controller. If not set, compaction target that the compaction backlog would be equal to. |
compaction_ctrl_d_coeff |
Derivative coefficient for compaction PID controller. |
compaction_ctrl_i_coeff |
Integral coefficient for compaction PID controller. |
compaction_ctrl_max_shares |
Maximum number of IO and CPU shares that compaction process can use. |
compaction_ctrl_min_shares |
Minimum number of IO and CPU shares that compaction process can use. |
compaction_ctrl_p_coeff |
Proportional coefficient for compaction PID controller. This has to be negative since compaction backlog should decrease when number of compaction shares increases. |
compaction_ctrl_update_interval_ms |
No description. |
controller_backend_housekeeping_interval_ms |
Interval between iterations of controller backend housekeeping loop. |
create_topic_timeout_ms |
Timeout (ms) to wait for new topic creation. |
default_num_windows |
Default number of quota tracking windows. |
default_window_sec |
Default quota tracking window size in milliseconds. |
developer_mode |
Skips most of the checks performed at startup are not recommended for production use. |
disable_batch_cache |
Disable batch cache in log manager. |
election_timeout_ms |
Election timeout expressed in milliseconds. |
enable_pid_file |
Enable pid file. You probably don’t want to change this. |
features_auto_enable |
Whether new feature flags may auto-activate after upgrades (true) or must wait for manual activation via the admin API (false). |
fetch_reads_debounce_timeout |
Time to wait for next read in fetch request when requested min bytes wasn’t reached. |
fetch_session_eviction_timeout_ms |
Minimum time before which unused session will get evicted from sessions. Maximum time after which inactive session will be deleted is two time given configuration value cache. |
full_raft_configuration_recovery_pattern |
Recover raft configuration on start for NTPs matching pattern. |
group_initial_rebalance_delay |
Extra delay (ms) added to rebalance phase to wait for new members. |
group_new_member_join_timeout |
Timeout for new member joins. |
group_topic_partitions |
Number of partitions in the internal group membership topic. |
health_manager_tick_interval |
How often the health manager runs. |
health_monitor_max_metadata_age |
Max age of metadata cached in the health monitor of non controller node. |
health_monitor_tick_interval |
How often health monitor refreshes cluster state. |
id_allocator_batch_size |
Id allocator allocates messages in batches (each batch is a one log record) and then serves requests from memory without touching the log until the batch is exhausted. |
id_allocator_log_capacity |
Capacity of the id_allocator log in number of messages. Once it reached id_allocator_stm should compact the log. |
join_retry_timeout_ms |
Time between cluster join retries in milliseconds. |
kafka_max_bytes_per_fetch |
Limit fetch responses to this many bytes even if total of partition bytes limits is higher. |
kafka_qdc_depth_alpha |
Smoothing factor for kafka queue depth control depth tracking. |
kafka_qdc_depth_update_ms |
Update frequency for kafka queue depth control. |
kafka_qdc_idle_depth |
Queue depth when idleness is detected in kafka queue depth control. |
kafka_qdc_latency_alpha |
Smoothing parameter for kafka queue depth control latency tracking. |
kafka_qdc_max_depth |
Maximum queue depth used in kafka queue depth control. |
kafka_qdc_min_depth |
Minimum queue depth used in kafka queue depth control. |
kafka_qdc_window_count |
Number of windows used in kafka queue depth control latency tracking. |
kafka_qdc_window_size_ms |
Window size for kafka queue depth control latency tracking. |
kvstore_flush_interval |
Key-value store flush interval (ms). |
kvstore_max_segment_size |
Key-value maximum segment size (bytes). |
leader_balancer_idle_timeout |
Leadership rebalancing idle timeout. |
leader_balancer_mute_timeout |
Leadership rebalancing mute timeout. |
leader_balancer_mute_timeout |
Leadership rebalancing node mute timeout. |
log_segment_size |
How large in bytes should each log segment be (default 1 GB). |
max_compacted_log_segment_size |
Max compacted segment size after consolidation. |
max_kafka_throttle_delay_ms |
Fail-safe maximum throttle delay on kafka requests. |
members_backend_retry_ms |
Time between members backend reconciliation loop retries. |
metadata_dissemination_interval_ms |
Interval for metadata dissemination batching. |
metadata_dissemination_retries |
Number of attempts to look up a topic’s metadata like shard before failing a request. |
metadata_dissemination_retry_delay_ms |
Delay before retrying a topic lookup in a shard or other meta tables. |
metadata_status_wait_timeout_ms |
Maximum time to wait in metadata request for cluster health to be refreshed. |
metrics_reporter_report_interval |
Cluster metrics reporter report interval. |
metrics_reporter_tick_interval |
Cluster metrics reporter tick interval. |
node_management_operation_timeout_ms |
Timeout for executing node management operations. |
quota_manager_gc_sec |
Quota manager GC frequency in milliseconds. |
raft_heartbeat_disconnect_failures |
After how many failed heartbeats to forcibly close an unresponsive TCP connection. Set to 0 to disable force disconnection. |
raft_heartbeat_interval_ms |
The interval in ms between raft leader heartbeats. |
raft_heartbeat_timeout_ms |
Raft heartbeat RPC timeout. |
raft_io_timeout_ms |
Raft I/O timeout. |
raft_max_concurrent_append_requests_per_follower |
Maximum number of concurrent append entries requests sent by leader to one follower. |
raft_max_recovery_memory |
Maximum memory that can be used for reads in the raft recovery process. |
raft_recovery_default_read_size |
Default size of read issued during raft follower recovery. |
raft_replicate_batch_window_size |
Maximum size of requests cached for replication. |
raft_smp_max_non_local_requests |
Maximum number of x-core requests pending in Raft seastar::smp group. (for more details look at seastar::smp_service_group documentation). |
raft_timeout_now_timeout_ms |
Timeout for a timeout now request. |
raft_transfer_leader_recovery_timeout_ms |
Timeout waiting for follower recovery when transferring leadership. |
readers_cache_eviction_timeout_ms |
Duration after which inactive readers will be evicted from cache. |
reclaim_batch_cache_min_free |
Free memory limit that will be kept by batch cache background reclaimer. |
reclaim_growth_window |
Length of time in which reclaim sizes grow. |
reclaim_max_size |
Maximum batch cache reclaim size. |
reclaim_min_size |
Minimum batch cache reclaim size. |
reclaim_stable_window |
Length of time above which growth is reset. |
recovery_append_timeout_ms |
Timeout for append entries requests issued while updating stale follower. |
release_cache_on_segment_roll |
Free cache when segments roll. |
replicate_append_timeout_ms |
Timeout for append entries requests issued while replicating entries. |
segment_appender_flush_timeout_ms |
Maximum delay until buffered data is written. |
segment_fallocation_step |
Size for segments fallocation. |
storage_read_buffer_size |
Size of each read buffer (one per in-flight read, per log segment). |
storage_read_readahead_count |
How many additional reads to issue ahead of current read location. |
storage_space_alert_free_threshold_bytes |
Threshold of minimim bytes free space before setting storage space alert. |
storage_space_alert_free_threshold_percent |
Threshold of minimim percent free space before setting storage space alert. |
topic_fds_per_partition |
Required file handles per partition when creating topics. |
topic_memory_per_partition |
Required memory per partition when creating topics. |
transaction_coordinator_log_segment_size |
How large in bytes should each log segment be (default 1 GB). |
wait_for_leader_timeout_ms |
Timeout (ms) to wait for leadership in metadata cache. |
zstd_decompress_workspace_bytes |
Size of the zstd decompression workspace. |