# Get cluster configuration **GET /v1/cluster_config** List the configuration properties of a cluster. For supported cluster properties, see [/cluster_config/schema](#operation/get_cluster_config_schema). ## Servers - http://localhost:9644: http://localhost:9644 () ## Parameters ### Query parameters - **include_defaults** (string) If false, only properties which have been changed from the default are included. ## Responses ### 200 Cluster configuration response #### Body: application/json (array[object]) - **abort_index_segment_size** (integer) Capacity (in number of txns) of an abort index segment - **abort_timed_out_transactions_interval_ms** (integer) How often look for the inactive transactions and abort them - **admin_api_require_auth** (boolean) Whether admin API clients must provide HTTP Basic authentication headers - **aggregate_metrics** (boolean) Enable aggregations of metrics returned by the prometheus '/metrics' endpoint. Metric aggregation is performed by summing the values of samples by labels. Aggregations are performed where it makes sense by the shard and/or partition labels. - **alter_topic_cfg_timeout_ms** (integer) Time to wait for entries replication in controller log when executing alter configuration requst - **append_chunk_size** (integer) Size of direct write operations to disk in bytes - **auto_create_topics_enabled** (boolean) Allow topic auto creation - **cloud_storage_access_key** (string) AWS access key - **cloud_storage_api_endpoint** (string) Optional API endpoint - **cloud_storage_api_endpoint_port** (integer) TLS port override - **cloud_storage_azure_container** (string) The name of the Azure container to use with Tiered Storage. Note that the container must belong to `cloud_storage_azure_storage_account` - **cloud_storage_azure_shared_key** (string) The shared key to be used for Azure Shared Key authentication with the configured Azure storage account (see `cloud_storage_azure_storage_account`). Note that Redpanda expects this string to be Base64 encoded. - **cloud_storage_azure_storage_account** (string) The name of the Azure storage account to use with Tiered Storage - **cloud_storage_backend** (string) Optional cloud storage backend variant used to select API capabilities. If not supplied, will be inferred from other configuration parameters. - **cloud_storage_bucket** (string) AWS bucket that should be used to store data - **cloud_storage_cache_check_interval** (integer) Minimum time between trims of tiered storage cache. If a fetch operation requires trimming the cache, and the most recent trim was within this period, then trimming will be delayed until this period has elapsed - **cloud_storage_cache_chunk_size** (integer) Size of chunks of segments downloaded into cloud storage cache. Reduces space usage by only downloading the necessary chunk from a segment. - **cloud_storage_cache_size** (integer) Max size of archival cache - **cloud_storage_chunk_eviction_strategy** (string) Selects a strategy for evicting unused cache chunks. - **cloud_storage_cluster_metadata_upload_interval_ms** (integer) Time interval to wait between cluster metadata uploads. - **cloud_storage_credentials_host** (string) The hostname to connect to for retrieving role based credentials. Derived from cloud_storage_credentials_source if not set. Only required when using IAM role based access. - **cloud_storage_credentials_source** (string) The source of credentials to connect to cloud services - **cloud_storage_disable_chunk_reads** (boolean) Disable chunk reads and switch back to legacy mode where full segments are downloaded. - **cloud_storage_disable_tls** (boolean) Disable TLS for all S3 connections - **cloud_storage_enable_compacted_topic_reupload** (boolean) Enable re-uploading data for compacted topics - **cloud_storage_enable_remote_read** (boolean) Default remote read config value for new topics - **cloud_storage_enable_remote_write** (boolean) Default remote write value for new topics - **cloud_storage_enable_segment_merging** (boolean) Enables adjacent segment merging. The segments are reuploaded if there is an opportunity for that and if it will improve the tiered-storage performance - **cloud_storage_enabled** (boolean) Enable archival storage - **cloud_storage_graceful_transfer_timeout_ms** (integer) Time limit on waiting for uploads to complete before a leadership transfer. If this is null, leadership transfers will proceed without waiting. - **cloud_storage_housekeeping_interval_ms** (integer) Interval for cloud storage housekeeping tasks - **cloud_storage_hydrated_chunks_per_segment_ratio** (number) The maximum number of chunks per segment that can be hydrated at a time. Above this number, unused chunks will be trimmed. - **cloud_storage_idle_threshold_rps** (number) The cloud storage request rate threshold for idle state detection. If the average request rate for the configured period is lower than this threshold the cloud storage is considered being idle. - **cloud_storage_idle_timeout_ms** (integer) Timeout used to detect idle state of the cloud storage API. If the average cloud storage request rate is below this threshold for a configured amount of time the cloud storage is considered idle and the housekeeping jobs are started. - **cloud_storage_initial_backoff_ms** (integer) Initial backoff time for exponential backoff algorithm (ms) - **cloud_storage_manifest_cache_size** (integer) Amount of memory that can be used to handle tiered-storage metadata - **cloud_storage_manifest_max_upload_interval_sec** (integer) Wait at least this long between partition manifest uploads. Actual time between uploads may be greater than this interval. If this is null, metadata will be updated after each segment upload. - **cloud_storage_manifest_upload_timeout_ms** (integer) Manifest upload timeout (ms) - **cloud_storage_materialized_manifest_ttl_ms** (integer) The time interval that determins how long the materialized manifest can stay in cache under contention. This parameter is used for performance tuning. When the spillover manifest is materialized and stored in cache and the cache needs to evict it it will use 'cloud_storage_materialized_manifest_ttl_ms' value as a timeout. The cursor that uses the spillover manifest uses this value as a TTL interval after which it stops referencing the manifest making it available for eviction. This only affects spillover manifests under contention. - **cloud_storage_max_connection_idle_time_ms** (integer) Max https connection idle time (ms) - **cloud_storage_max_connections** (integer) Max number of simultaneous connections to S3 per shard (includes connections used for both uploads and downloads) - **cloud_storage_max_materialized_segments_per_shard** (integer) Maximum concurrent readers of remote data per CPU core. If unset, value of `topic_partitions_per_shard` multiplied by 2 is used. - **cloud_storage_max_readers_per_shard** (integer) Maximum concurrent readers of remote data per CPU core. If unset, value of `topic_partitions_per_shard` is used, i.e. one reader per partition if the shard is at its maximum partition capacity. - **cloud_storage_max_segments_pending_deletion_per_partition** (integer) The per-partition limit for the number of segments pending deletion from the cloud. Segments can be deleted due to retention or compaction. If this limit is breached and deletion fails, then segments will be orphaned in the cloud and will have to be removed manually - **cloud_storage_metadata_sync_timeout_ms** (integer) Timeout for SI metadata synchronization - **cloud_storage_min_chunks_per_segment_threshold** (integer) The minimum number of chunks per segment for trimming to be enabled. If the number of chunks in a segment is below this threshold, the segment is small enough that all chunks in it can be hydrated at any given time - **cloud_storage_readreplica_manifest_sync_timeout_ms** (integer) Timeout to check if new data is available for partition in S3 for read replica - **cloud_storage_recovery_temporary_retention_bytes_default** (integer) Retention in bytes for topics created during automated recovery - **cloud_storage_region** (string) AWS region that houses the bucket used for storage - **cloud_storage_roles_operation_timeout_ms** (integer) Timeout for IAM role related operations (ms) - **cloud_storage_secret_key** (string) AWS secret key - **cloud_storage_segment_max_upload_interval_sec** (integer) Time that segment can be kept locally without uploading it to the remote storage (sec) - **cloud_storage_segment_size_min** (integer) Smallest acceptable segment size in the cloud storage. Default: cloud_storage_segment_size_target/2 - **cloud_storage_segment_size_target** (integer) Desired segment size in the cloud storage. Default: segment.bytes - **cloud_storage_segment_upload_timeout_ms** (integer) Log segment upload timeout (ms) - **cloud_storage_spillover_manifest_size** (integer) The size of the manifest which can be offloaded to the cloud. If the size of the local manifest stored in redpanda exceeds cloud_storage_spillover_manifest_size x2 the spillover mechanism will split the manifest into two parts and one of them will be uploaded to S3. - **cloud_storage_trust_file** (string) Path to certificate that should be used to validate server certificate during TLS handshake - **cloud_storage_upload_ctrl_d_coeff** (number) derivative coefficient for upload PID controller. - **cloud_storage_upload_ctrl_max_shares** (integer) maximum number of IO and CPU shares that archival upload can use - **cloud_storage_upload_ctrl_min_shares** (integer) minimum number of IO and CPU shares that archival upload can use - **cloud_storage_upload_ctrl_p_coeff** (number) proportional coefficient for upload PID controller - **cloud_storage_upload_ctrl_update_interval_ms** (integer) - **cloud_storage_upload_loop_initial_backoff_ms** (integer) Initial backoff interval when there is nothing to upload for a partition (ms) - **cloud_storage_upload_loop_max_backoff_ms** (integer) Max backoff interval when there is nothing to upload for a partition (ms) - **cluster_id** (string) Cluster identifier - **compacted_log_segment_size** (integer) How large in bytes should each compacted log segment be (default 256MiB) - **compaction_ctrl_backlog_size** (integer) target backlog size for compaction controller. if not set compaction target compaction backlog would be equal to - **compaction_ctrl_d_coeff** (number) derivative coefficient for compaction PID controller. - **compaction_ctrl_i_coeff** (number) integral coefficient for compaction PID controller. - **compaction_ctrl_max_shares** (integer) maximum number of IO and CPU shares that compaction process can use - **compaction_ctrl_min_shares** (integer) minimum number of IO and CPU shares that compaction process can use - **compaction_ctrl_p_coeff** (number) 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** (integer) - **controller_backend_housekeeping_interval_ms** (integer) Interval between iterations of controller backend housekeeping loop - **controller_log_accummulation_rps_capacity_acls_and_users_operations** (integer) Maximum capacity of rate limit accumulationin controller acls and users operations limit - **controller_log_accummulation_rps_capacity_configuration_operations** (integer) Maximum capacity of rate limit accumulationin controller configuration operations limit - **controller_log_accummulation_rps_capacity_move_operations** (integer) Maximum capacity of rate limit accumulationin controller move operations limit - **controller_log_accummulation_rps_capacity_node_management_operations** (integer) Maximum capacity of rate limit accumulationin controller node management operations limit - **controller_log_accummulation_rps_capacity_topic_operations** (integer) Maximum capacity of rate limit accumulationin controller topic operations limit - **controller_snapshot_max_age_sec** (integer) Max time that will pass before we make an attempt to create a controller snapshot, after a new controller command appears - **create_topic_timeout_ms** (integer) Timeout (ms) to wait for new topic creation - **default_num_windows** (integer) Default number of quota tracking windows - **default_topic_partitions** (integer) Default number of partitions per topic - **default_topic_replications** (integer) Default replication factor for new topics - **default_window_sec** (integer) Default quota tracking window size in milliseconds - **delete_retention_ms** (integer) delete segments older than this - default 1 week - **disable_batch_cache** (boolean) Disable batch cache in log manager - **disable_metrics** (boolean) Disable registering metrics exposed on the internal metrics endpoint (/metrics) - **disable_public_metrics** (boolean) Disable registering metrics exposed on the public metrics endpoint (/public_metrics) - **election_timeout_ms** (integer) Election timeout expressed in milliseconds - **enable_controller_log_rate_limiting** (boolean) Enables limiting of controller log write rate - **enable_idempotence** (boolean) Enable idempotent producer - **enable_leader_balancer** (boolean) Enable automatic leadership rebalancing - **enable_metrics_reporter** (boolean) Enable cluster metrics reporter - **enable_pid_file** (boolean) Enable pid file. You probably don't want to change this. - **enable_rack_awareness** (boolean) Enables rack-aware replica assignment - **enable_sasl** (boolean) Enable SASL authentication for Kafka connections, authorization is required. see also `kafka_enable_authorization` - **enable_schema_id_validation** (string) Enable Server Side Schema ID Validation. - **enable_storage_space_manager** (boolean) Enable the storage space manager that coordinates and control space usage between log data and the cloud storage cache. - **enable_transactions** (boolean) Enable transactions - **enable_usage** (boolean) Enables the usage tracking mechanism, storing windowed history of kafka/cloud_storage metrics over time - **features_auto_enable** (boolean) Whether new feature flags may auto-activate after upgrades (true) or must wait for manual activation via the admin API (false) - **fetch_max_bytes** (integer) Maximum number of bytes returned in fetch request - **fetch_reads_debounce_timeout** (integer) Time to wait for next read in fetch request when requested min bytes wasn't reached - **fetch_session_eviction_timeout_ms** (integer) 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 valuecache - **find_coordinator_timeout_ms** (integer) Time to wait for a response from tx_registry - **full_raft_configuration_recovery_pattern** (array[string]) Recover raft configuration on start for NTPs matching pattern - **group_initial_rebalance_delay** (integer) Extra delay (ms) added to rebalance phase to wait for new members - **group_max_session_timeout_ms** (integer) The maximum allowed session timeout for registered consumers. Longer timeouts give consumers more time to process messages in between heartbeats at the cost of a longer time to detect failures. - **group_min_session_timeout_ms** (integer) The minimum allowed session timeout for registered consumers. Shorter timeouts result in quicker failure detection at the cost of more frequent consumer heartbeating, which can overwhelm broker resources. - **group_new_member_join_timeout** (integer) Timeout for new member joins - **group_offset_retention_check_ms** (integer) How often the system should check for expired group offsets. - **group_offset_retention_sec** (integer) Consumer group offset retention seconds. Offset retention can be disabled by setting this value to null. - **group_topic_partitions** (integer) Number of partitions in the internal group membership topic - **health_manager_tick_interval** (integer) How often the health manager runs - **health_monitor_max_metadata_age** (integer) Max age of metadata cached in the health monitor of non controller node - **id_allocator_batch_size** (integer) 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** (integer) Capacity of the id_allocator log in number of messages. Once it reached id_allocator_stm should compact the log. - **internal_topic_replication_factor** (integer) Target replication factor for internal topics - **join_retry_timeout_ms** (integer) Time between cluster join retries in milliseconds - **kafka_admin_topic_api_rate** (integer) Target quota rate (partition mutations per default_window_sec) - **kafka_batch_max_bytes** (integer) Maximum size of a batch processed by server. If batch is compressed the limit applies to compressed batch size - **kafka_client_group_byte_rate_quota** (array[object]) Per-group target produce quota byte rate (bytes per second). Client is considered part of the group if client_id contains clients_prefix - **kafka_client_group_fetch_byte_rate_quota** (array[object]) Per-group target fetch quota byte rate (bytes per second). Client is considered part of the group if client_id contains clients_prefix - **kafka_connection_rate_limit** (integer) Maximum connections per second for one core - **kafka_connection_rate_limit_overrides** (array[string]) Overrides for specific ips for maximum connections per second for one core - **kafka_connections_max** (integer) Maximum number of Kafka client connections per broker - **kafka_connections_max_overrides** (array[string]) Per-IP overrides of kafka connection count limit, list of : strings - **kafka_connections_max_per_ip** (integer) Maximum number of Kafka client connections from each IP address, per broker - **kafka_enable_authorization** (boolean) Enable authorization for Kafka connections. Values:- `nil`: Ignored. Authorization is enabled with `enable_sasl: true`; `true`: authorization is required; `false`: authorization is disabled. See also: `enable_sasl` and `kafka_api[].authentication_method` - **kafka_enable_describe_log_dirs_remote_storage** (boolean) Whether to include tiered storage as a special remote:// directory in DescribeLogDirs Kafka API requests. - **kafka_enable_partition_reassignment** (boolean) Enable the Kafka partition reassignment API - **kafka_group_recovery_timeout_ms** (integer) Kafka group recovery timeout expressed in milliseconds - **kafka_max_bytes_per_fetch** (integer) Limit fetch responses to this many bytes, even if total of partition bytes limits is higher - **kafka_memory_batch_size_estimate_for_fetch** (integer) The size of the batch used to estimate memory consumption for Fetch requests, in bytes. Smaller sizes allow more concurrent fetch requests per shard, larger sizes prevent running out of memory because of too many concurrent fetch requests. - **kafka_memory_share_for_fetch** (number) The share of kafka subsystem memory that can be used for fetch read buffers, as a fraction of kafka subsystem memory amount - **kafka_mtls_principal_mapping_rules** (array[string]) Principal Mapping Rules for mTLS Authentication on the Kafka API - **kafka_nodelete_topics** (array[string]) Prevents the topics in the list from being deleted via the kafka api - **kafka_noproduce_topics** (array[string]) Prevents the topics in the list from having message produced to them via the kafka api - **kafka_qdc_depth_alpha** (number) Smoothing factor for kafka queue depth control depth tracking. - **kafka_qdc_depth_update_ms** (integer) Update frequency for kafka queue depth control. - **kafka_qdc_enable** (boolean) Enable kafka queue depth control. - **kafka_qdc_idle_depth** (integer) Queue depth when idleness is detected in kafka queue depth control. - **kafka_qdc_latency_alpha** (number) Smoothing parameter for kafka queue depth control latency tracking. - **kafka_qdc_max_depth** (integer) Maximum queue depth used in kafka queue depth control. - **kafka_qdc_max_latency_ms** (integer) Max latency threshold for kafka queue depth control depth tracking. - **kafka_qdc_min_depth** (integer) Minimum queue depth used in kafka queue depth control. - **kafka_qdc_window_count** (integer) Number of windows used in kafka queue depth control latency tracking. - **kafka_qdc_window_size_ms** (integer) Window size for kafka queue depth control latency tracking. - **kafka_quota_balancer_min_shard_throughput_bps** (integer) The lowest value of the throughput quota a shard can get in the process of quota balancing, in bytes/s. 0 means there is no minimum. - **kafka_quota_balancer_min_shard_throughput_ratio** (number) The lowest value of the throughput quota a shard can get in the process of quota balancing, expressed as a ratio of default shard quota. 0 means there is no minimum, 1 means no quota can be taken away by the balancer. - **kafka_quota_balancer_node_period_ms** (integer) Intra-node throughput quota balancer invocation period, in milliseconds. Value of 0 disables the balancer and makes all the throughput quotas immutable. - **kafka_quota_balancer_window_ms** (integer) Time window used to average current throughput measurement for quota balancer, in milliseconds - **kafka_request_max_bytes** (integer) Maximum size of a single request processed via Kafka API - **kafka_rpc_server_stream_recv_buf** (integer) Userspace receive buffer max size in bytes - **kafka_rpc_server_tcp_recv_buf** (integer) Kafka server TCP receive buffer size in bytes. - **kafka_rpc_server_tcp_send_buf** (integer) Kafka server TCP transmit buffer size in bytes. - **kafka_schema_id_validation_cache_capacity** (integer) Per-shard capacity of the cache for validating schema IDs. - **kafka_throughput_control** (array[object]) List of throughput control groups that define exclusions from node-wide throughput limits. Each group consists of: (name (optional) - any unique group name, client_id - regex to match client_id). A connection is assigned the first matching group, then the connection is excluded from throughput control. - **kafka_throughput_controlled_api_keys** (array[string]) List of Kafka API keys that are subject to cluster-wide and node-wide throughput limit control - **kafka_throughput_limit_node_in_bps** (integer) Node wide throughput ingress limit - maximum kafka traffic throughput allowed on the ingress side of each node, in bytes/s. Default is no limit. - **kafka_throughput_limit_node_out_bps** (integer) Node wide throughput egress limit - maximum kafka traffic throughput allowed on the egress side of each node, in bytes/s. Default is no limit. - **kvstore_flush_interval** (integer) Key-value store flush interval (ms) - **kvstore_max_segment_size** (integer) Key-value maximum segment size (bytes) - **leader_balancer_idle_timeout** (integer) Leadership rebalancing idle timeout - **leader_balancer_mode** (string) Leader balancer mode - **leader_balancer_mute_timeout** (integer) Leadership rebalancing mute timeout - **leader_balancer_transfer_limit_per_shard** (integer) Per shard limit for in progress leadership transfers - **legacy_group_offset_retention_enabled** (boolean) Group offset retention is enabled by default in versions of Redpanda >= 23.1. To enable offset retention after upgrading from an older version set this option to true. - **legacy_permit_unsafe_log_operation** (boolean) Permits the use of strings that may induct log injection/modification - **legacy_unsafe_log_warning_interval_sec** (integer) Interval, in seconds, of how often a message informing the operator that unsafe strings are permitted - **log_cleanup_policy** (string) Default topic cleanup policy - **log_compaction_interval_ms** (integer) How often do we trigger background compaction - **log_compression_type** (string) Default topic compression type - **log_message_timestamp_type** (string) Default topic messages timestamp type - **log_segment_ms** (integer) Default log segment lifetime in ms for topics which do not set segment.ms - **log_segment_ms_max** (integer) Upper bound on topic segment.ms: higher values will be clamped to this value - **log_segment_ms_min** (integer) Lower bound on topic segment.ms: lower values will be clamped to this value - **log_segment_size** (integer) Default log segment size in bytes for topics which do not set segment.bytes - **log_segment_size_jitter_percent** (integer) Random variation to the segment size limit used for each partition - **log_segment_size_max** (integer) Upper bound on topic segment.bytes: higher values will be clamped to this limit - **log_segment_size_min** (integer) Lower bound on topic segment.bytes: lower values will be clamped to this limit - **max_compacted_log_segment_size** (integer) Max compacted segment size after consolidation - **max_concurrent_producer_ids** (integer) Max cache size for pids which rm_stm stores inside internal state. In overflow rm_stm will delete old pids and clear their status - **max_kafka_throttle_delay_ms** (integer) Fail-safe maximum throttle delay on kafka requests - **members_backend_retry_ms** (integer) Time between members backend reconciliation loop retries - **memory_abort_on_alloc_failure** (boolean) If true, the redpanda process will terminate immediately when an allocation cannot be satisfied due to memory exhasution. If false, an exception is thrown instead. - **metadata_dissemination_interval_ms** (integer) Interaval for metadata dissemination batching - **metadata_dissemination_retries** (integer) Number of attempts of looking up a topic's meta data like shard before failing a request - **metadata_dissemination_retry_delay_ms** (integer) Delay before retry a topic lookup in a shard or other meta tables - **metadata_status_wait_timeout_ms** (integer) Maximum time to wait in metadata request for cluster health to be refreshed - **metrics_reporter_report_interval** (integer) cluster metrics reporter report interval - **metrics_reporter_tick_interval** (integer) Cluster metrics reporter tick interval - **metrics_reporter_url** (string) cluster metrics reporter url - **node_isolation_heartbeat_timeout** (integer) How long after the last heartbeat request a node will wait before considering itself to be isolated - **node_management_operation_timeout_ms** (integer) Timeout for executing node management operations - **node_status_interval** (integer) Time interval between two node status messages. Node status messages establish liveness status outside of the Raft protocol. - **partition_autobalancing_concurrent_moves** (integer) Number of partitions that can be reassigned at once - **partition_autobalancing_max_disk_usage_percent** (integer) Disk usage threshold that triggers moving partitions from the node - **partition_autobalancing_min_size_threshold** (integer) Minimum size of partition that is going to be prioritized when rebalancing cluster due to disk size threshold being breached. By default this value is calculated automaticaly - **partition_autobalancing_mode** (string) Partition autobalancing mode - **partition_autobalancing_movement_batch_size_bytes** (integer) Total size of partitions that autobalancer is going to move in one batch - **partition_autobalancing_node_availability_timeout_sec** (integer) Node unavailability timeout that triggers moving partitions from the node - **partition_autobalancing_tick_interval_ms** (integer) Partition autobalancer tick interval - **partition_autobalancing_tick_moves_drop_threshold** (number) If the number of scheduled tick moves drops by this ratio, a new tick is scheduled immediately. Valid values are (0, 1]. For #example, with a value of 0.2 and 100 scheduled moves in a tick, a new tick is scheduled when the inprogress moves are < 80. - **quota_manager_gc_sec** (integer) Quota manager GC frequency in milliseconds - **raft_heartbeat_disconnect_failures** (integer) After how many failed heartbeats to forcibly close an unresponsive TCP connection. Set to 0 to disable force disconnection. - **raft_heartbeat_interval_ms** (integer) Milliseconds for raft leader heartbeats - **raft_heartbeat_timeout_ms** (integer) raft heartbeat RPC timeout - **raft_io_timeout_ms** (integer) Raft I/O timeout - **raft_learner_recovery_rate** (integer) Raft learner recovery rate limit in bytes per sec - **raft_max_concurrent_append_requests_per_follower** (integer) Maximum number of concurrent append entries requests sent by leader to one follower - **raft_max_recovery_memory** (integer) Max memory that can be used for reads in raft recovery process by default 15% of total memory - **raft_recovery_default_read_size** (integer) default size of read issued during raft follower recovery - **raft_recovery_throttle_disable_dynamic_mode** (boolean) Disables dynamic rate allocation in recovery throttle (advanced). - **raft_replicate_batch_window_size** (integer) Max size of requests cached for replication - **raft_smp_max_non_local_requests** (integer) 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** (integer) Timeout for a timeout now request - **raft_transfer_leader_recovery_timeout_ms** (integer) Timeout waiting for follower recovery when transferring leadership - **readers_cache_eviction_timeout_ms** (integer) Duration after which inactive readers will be evicted from cache - **reclaim_batch_cache_min_free** (integer) Free memory limit that will be kept by batch cache background reclaimer - **reclaim_growth_window** (integer) Length of time in which reclaim sizes grow - **reclaim_max_size** (integer) Maximum batch cache reclaim size - **reclaim_min_size** (integer) Minimum batch cache reclaim size - **reclaim_stable_window** (integer) Length of time above which growth is reset - **recovery_append_timeout_ms** (integer) Timeout for append entries requests issued while updating stale follower - **release_cache_on_segment_roll** (boolean) Free cache when segments roll - **replicate_append_timeout_ms** (integer) Timeout for append entries requests issued while replicating entries - **retention_bytes** (integer) Default max bytes per partition on disk before triggering a compaction - **retention_local_target_bytes_default** (integer) Local retention size target for partitions of topics with cloud storage write enabled - **retention_local_target_ms_default** (integer) Local retention time target for partitions of topics with cloud storage write enabled - **rm_sync_timeout_ms** (integer) Time to wait state catch up before rejecting a request - **rpc_server_listen_backlog** (integer) TCP connection queue length for Kafka server and internal RPC server - **rpc_server_tcp_recv_buf** (integer) Internal RPC TCP receive buffer size in bytes. - **rpc_server_tcp_send_buf** (integer) Internal RPC TCP transmit buffer size in bytes. - **rps_limit_acls_and_users_operations** (integer) Rate limit for controller acls and users operations - **rps_limit_configuration_operations** (integer) Rate limit for controller configuration operations - **rps_limit_move_operations** (integer) Rate limit for controller move operations - **rps_limit_node_management_operations** (integer) Rate limit for controller node management operations - **rps_limit_topic_operations** (integer) Rate limit for controller topic operations - **sasl_kerberos_config** (string) The location of the Kerberos krb5.conf file for Redpanda - **sasl_kerberos_keytab** (string) The location of the Kerberos keytab file for Redpanda - **sasl_kerberos_principal** (string) The primary of the Kerberos Service Principal Name (SPN) for Redpanda - **sasl_kerberos_principal_mapping** (array[string]) Rules for mapping Kerberos Principal Names to Redpanda User Principals - **sasl_mechanisms** (array[string]) A list of supported SASL mechanisms. `SCRAM` and `GSSAPI` are allowed. - **segment_appender_flush_timeout_ms** (integer) Maximum delay until buffered data is written - **segment_fallocation_step** (integer) Size for segments fallocation - **seq_table_min_size** (integer) Minimum size of the seq table non affected by compaction - **storage_compaction_index_memory** (integer) Maximum number of bytes that may be used on each shard by compactionindex writers - **storage_ignore_timestamps_in_future_sec** (integer) If set, timestamps more than this many seconds in the future relative tothe server's clock will be ignored for data retention purposes, and retention will act based on another timestamp in the same segment, or the mtime of the segment file if no valid timestamp is available - **storage_max_concurrent_replay** (integer) Maximum number of partitions' logs that will be replayed concurrently at startup, or flushed concurrently on shutdown. - **storage_min_free_bytes** (integer) Threshold of minimum bytes free space before rejecting producers. - **storage_read_buffer_size** (integer) Size of each read buffer (one per in-flight read, per log segment) - **storage_read_readahead_count** (integer) How many additional reads to issue ahead of current read location - **storage_reserve_min_segments** (integer) The number of segments per partition that the system will attempt to reserve disk capcity for. For #example, if the maximum segment size is configured to be 100 MB, and the value of this option is 2, then in a system with 10 partitions Redpanda will attempt to reserve at least 2 GB of disk space. - **storage_space_alert_free_threshold_bytes** (integer) Threshold of minimim bytes free space before setting storage space alert - **storage_space_alert_free_threshold_percent** (integer) Threshold of minimim percent free space before setting storage space alert - **storage_strict_data_init** (boolean) Requires that an empty file named `.redpanda_data_dir` be present in the data directory. Redpanda will refuse to start if it is not found. - **storage_target_replay_bytes** (integer) Target bytes to replay from disk on startup after clean shutdown: controls frequency of snapshots and checkpoints - **superusers** (array[string]) List of superuser usernames - **target_fetch_quota_byte_rate** (integer) Target fetch size quota byte rate (bytes per second) - disabled default - **target_quota_byte_rate** (integer) Target request size quota byte rate (bytes per second) - 2GB default - **tm_sync_timeout_ms** (integer) Time to wait state catch up before rejecting a request - **topic_fds_per_partition** (integer) Required file handles per partition when creating topics - **topic_memory_per_partition** (integer) Required memory per partition when creating topics - **topic_partitions_per_shard** (integer) Maximum number of partitions which may be allocated to one shard (CPU core) - **topic_partitions_reserve_shard0** (integer) Reserved partition slots on shard (CPU core) 0 on each node. If this is >= topic_partitions_per_core, no data partitions will be scheduled on shard 0 - **transaction_coordinator_cleanup_policy** (string) Cleanup policy for a transaction coordinator topic - **transaction_coordinator_delete_retention_ms** (integer) delete segments older than this - default 1 week - **transaction_coordinator_log_segment_size** (integer) How large in bytes should each log segment be (default 1G) - **transaction_coordinator_partitions** (integer) Amount of partitions for transactions coordinator - **transactional_id_expiration_ms** (integer) Producer ids are expired once this time has elapsed after the last write with the given producer id. - **tx_log_stats_interval_s** (integer) How often to log per partition tx stats, works only with debug logging enabled. - **tx_timeout_delay_ms** (integer) Delay before scheduling next check for timed out transactions - **usage_disk_persistance_interval_sec** (integer) The interval in which all usage stats are written to disk - **usage_num_windows** (integer) The number of windows to persist in memory and disk - **usage_window_width_interval_sec** (integer) The width of a usage window, tracking cloud and kafka ingress/egress traffic each interval - **use_fetch_scheduler_group** (boolean) Use a separate scheduler group for fetch processing - **wait_for_leader_timeout_ms** (integer) Timeout (ms) to wait for leadership in metadata cache - **zstd_decompress_workspace_bytes** (integer) Size of the zstd decompression workspace [Powered by Bump.sh](https://bump.sh)