Cluster settings apply to all nodes of a CockroachDB cluster and control, for example, whether or not to share diagnostic details with Cockroach Labs as well as advanced options for debugging and cluster tuning.
In contrast to cluster-wide settings, node-level settings apply to a single node. They are defined by flags passed to the cockroach start command when starting a node and cannot be changed without stopping and restarting the node. For more details, see Start a Node.
This page provides information on:
- Available settings
- How to view current cluster settings
- How to change a cluster setting
- Sensitive settings
Settings
These cluster settings have a broad impact on CockroachDB internals and affect all applications, workloads, and users running on a CockroachDB cluster. For some settings, a session setting could be a more appropriate scope.
Use ALTER ROLE ALL SET {sessionvar} = {val} instead of the sql.defaults.* cluster settings. This allows you to set a default value for all users for any session variable that applies during login, making the sql.defaults.* cluster settings redundant.
| Setting | Type | Default | Description | Supported Deployments | 
|---|---|---|---|---|
| admission.disk_bandwidth_tokens.elastic.enabled | boolean | true | when true, and provisioned bandwidth for the disk corresponding to a store is configured, tokens for elastic work will be limited if disk bandwidth becomes a bottleneck | Advanced/Self-Hosted | 
| admission.epoch_lifo.enabled | boolean | false | when true, epoch-LIFO behavior is enabled when there is significant delay in admission | Basic/Standard/Advanced/Self-Hosted | 
| admission.epoch_lifo.epoch_closing_delta_duration | duration | 5ms | the delta duration before closing an epoch, for epoch-LIFO admission control ordering | Basic/Standard/Advanced/Self-Hosted | 
| admission.epoch_lifo.epoch_duration | duration | 100ms | the duration of an epoch, for epoch-LIFO admission control ordering | Basic/Standard/Advanced/Self-Hosted | 
| admission.epoch_lifo.queue_delay_threshold_to_switch_to_lifo | duration | 105ms | the queue delay encountered by a (tenant,priority) for switching to epoch-LIFO ordering | Basic/Standard/Advanced/Self-Hosted | 
| admission.kv.enabled | boolean | true | when true, work performed by the KV layer is subject to admission control | Advanced/Self-Hosted | 
| admission.sql_kv_response.enabled | boolean | true | when true, work performed by the SQL layer when receiving a KV response is subject to admission control | Basic/Standard/Advanced/Self-Hosted | 
| admission.sql_sql_response.enabled | boolean | true | when true, work performed by the SQL layer when receiving a DistSQL response is subject to admission control | Basic/Standard/Advanced/Self-Hosted | 
| bulkio.backup.file_size | byte size | 128 MiB | target size for individual data files produced during BACKUP | Basic/Standard/Advanced/Self-Hosted | 
| bulkio.backup.read_timeout | duration | 5m0s | amount of time after which a read attempt is considered timed out, which causes the backup to fail | Basic/Standard/Advanced/Self-Hosted | 
| bulkio.backup.read_with_priority_after | duration | 1m0s | amount of time since the read-as-of time above which a BACKUP should use priority when retrying reads | Basic/Standard/Advanced/Self-Hosted | 
| physical_replication.consumer.minimum_flush_interval | duration | 5s | the minimum timestamp between flushes; flushes may still occur if internal buffers fill up | Advanced/Self-Hosted | 
| changefeed.aggregator.flush_jitter | float | 0.1 | jitter aggregator flushes as a fraction of min_checkpoint_frequency. This setting has no effect if min_checkpoint_frequency is set to 0. | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.backfill.concurrent_scan_requests | integer | 0 | number of concurrent scan requests per node issued during a backfill | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.backfill.scan_request_size | integer | 524288 | the maximum number of bytes returned by each scan request | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.batch_reduction_retry.enabled | boolean | false | if true, kafka changefeeds upon erroring on an oversized batch will attempt to resend the messages with progressively lower batch sizes | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.default_range_distribution_strategy | enumeration | default | configures how work is distributed among nodes for a given changefeed. for the most balanced distribution, use `balanced_simple`. changing this setting will not override locality restrictions [default = 0, balanced_simple = 1] | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.event_consumer_worker_queue_size | integer | 16 | if changefeed.event_consumer_workers is enabled, this setting sets the maxmimum number of events which a worker can buffer | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.event_consumer_workers | integer | 0 | the number of workers to use when processing events: <0 disables, 0 assigns a reasonable default, >0 assigns the setting value. for experimental/core changefeeds and changefeeds using parquet format, this is disabled | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.fast_gzip.enabled | boolean | true | use fast gzip implementation | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.span_checkpoint.lag_threshold | duration | 10m0s | the amount of time a changefeed's lagging (slowest) spans must lag behind its leading (fastest) spans before a span-level checkpoint to save leading span progress is written; if 0, span-level checkpoints due to lagging spans is disabled | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.kafka_v2_error_details.enabled | boolean | true | if enabled, Kafka v2 sinks will include the message key, size, and MVCC timestamp in message too large errors | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.memory.per_changefeed_limit | byte size | 512 MiB | controls amount of data that can be buffered per changefeed | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.resolved_timestamp.min_update_interval | duration | 0s | minimum amount of time that must have elapsed since the last time a changefeed's resolved timestamp was updated before it is eligible to be updated again; default of 0 means no minimum interval is enforced but updating will still be limited by the average time it takes to checkpoint progress | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.node_throttle_config | string |  | specifies node level throttling configuration for all changefeeeds | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.progress.frontier_persistence.interval | duration | 30s | minimum amount of time that must elapse before a changefeed will persist its entire span frontier again | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.protect_timestamp.max_age | duration | 96h0m0s | fail the changefeed if the protected timestamp age exceeds this threshold; 0 disables expiration | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.protect_timestamp_interval | duration | 10m0s | controls how often the changefeed forwards its protected timestamp to the resolved timestamp | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.schema_feed.read_with_priority_after | duration | 1m0s | retry with high priority if we were not able to read descriptors for too long; 0 disables | Basic/Standard/Advanced/Self-Hosted | 
| changefeed.sink_io_workers | integer | 0 | the number of workers used by changefeeds when sending requests to the sink (currently the batching versions of webhook, pubsub, and kafka sinks that are enabled by changefeed.new_<sink type>_sink_enabled only): <0 disables, 0 assigns a reasonable default, >0 assigns the setting value | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.azure.concurrent_upload_buffers | integer | 1 | controls the number of concurrent buffers that will be used by the Azure client when uploading chunks.Each buffer can buffer up to cloudstorage.write_chunk.size of memory during an upload | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.azure.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.azure.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.azure.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.azure.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.gs.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.gs.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.gs.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.gs.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.http.custom_ca | string |  | custom root CA (appended to system's default CAs) for verifying certificates when interacting with HTTPS storage | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.http.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.http.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.http.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.http.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nodelocal.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nodelocal.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nodelocal.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nodelocal.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nullsink.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nullsink.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nullsink.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.nullsink.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.s3.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.s3.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.s3.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.s3.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.timeout | duration | 10m0s | the timeout for import/export storage operations | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.userfile.read.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.userfile.read.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.userfile.write.node_burst_limit | byte size | 0 B | burst limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cloudstorage.userfile.write.node_rate_limit | byte size | 0 B | limit on number of bytes per second per node across operations writing to the designated cloud storage provider if non-zero | Basic/Standard/Advanced/Self-Hosted | 
| cluster.auto_upgrade.enabled | boolean | true | disable automatic cluster version upgrade until reset | Basic/Standard/Advanced/Self-Hosted | 
| cluster.organization | string |  | organization name | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| cluster.preserve_downgrade_option | string |  | disable (automatic or manual) cluster version upgrade from the specified version until reset | Basic/Standard/Advanced/Self-Hosted | 
| debug.zip.redact_addresses.enabled | boolean | false | enables the redaction of hostnames and ip addresses in debug zip | Basic/Standard/Advanced/Self-Hosted | 
| diagnostics.active_query_dumps.enabled | boolean | true | experimental: enable dumping of anonymized active queries to disk when node is under memory pressure | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| diagnostics.forced_sql_stat_reset.interval | duration | 2h0m0s | interval after which the reported SQL Stats are reset even if not collected by telemetry reporter. It has a max value of 24H. | Basic/Standard/Advanced/Self-Hosted | 
| diagnostics.memory_monitoring_dumps.enabled | boolean | true | enable dumping of memory monitoring state at the same time as heap profiles are taken | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| diagnostics.reporting.enabled | boolean | true | enable reporting diagnostic metrics to cockroach labs, but is ignored for Trial or Free licenses | Basic/Standard/Advanced/Self-Hosted | 
| diagnostics.reporting.interval | duration | 1h0m0s | interval at which diagnostics data should be reported | Basic/Standard/Advanced/Self-Hosted | 
| enterprise.license | string |  | the encoded cluster license | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| external.graphite.endpoint | string |  | if nonempty, push server metrics to the Graphite or Carbon server at the specified host:port | Basic/Standard/Advanced/Self-Hosted | 
| external.graphite.interval | duration | 10s | the interval at which metrics are pushed to Graphite (if enabled) | Basic/Standard/Advanced/Self-Hosted | 
| feature.backup.enabled | boolean | true | set to true to enable backups, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.changefeed.enabled | boolean | true | set to true to enable changefeeds, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.export.enabled | boolean | true | set to true to enable exports, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.import.enabled | boolean | true | set to true to enable imports, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.infer_rbr_region_col_using_constraint.enabled | boolean | false | set to true to enable looking up the region column via a foreign key constraint in a REGIONAL BY ROW table, false to disable; default is false | Basic/Standard/Advanced/Self-Hosted | 
| feature.restore.enabled | boolean | true | set to true to enable restore, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.schema_change.enabled | boolean | true | set to true to enable schema changes, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.stats.enabled | boolean | true | set to true to enable CREATE STATISTICS/ANALYZE, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| feature.vector_index.enabled | boolean | true | set to true to enable vector indexes, false to disable; default is true | Basic/Standard/Advanced/Self-Hosted | 
| jobs.retention_time | duration | 336h0m0s | the amount of time for which records for completed jobs are retained | Basic/Standard/Advanced/Self-Hosted | 
| kv.allocator.lease_rebalance_threshold | float | 0.05 | minimum fraction away from the mean a store's lease count can be before it is considered for lease-transfers | Advanced/Self-Hosted | 
| kv.allocator.load_based_lease_rebalancing.enabled | boolean | true | set to enable rebalancing of range leases based on load and latency | Advanced/Self-Hosted | 
| kv.allocator.load_based_rebalancing | enumeration | leases and replicas | whether to rebalance based on the distribution of load across stores [off = 0, leases = 1, leases and replicas = 2, multi-metric only = 3, multi-metric and count = 4] | Advanced/Self-Hosted | 
| kv.allocator.load_based_rebalancing.objective | enumeration | cpu | what objective does the cluster use to rebalance; if set to `qps` the cluster will attempt to balance qps among stores, if set to `cpu` the cluster will attempt to balance cpu usage among stores [qps = 0, cpu = 1] | Advanced/Self-Hosted | 
| kv.allocator.load_based_rebalancing_interval | duration | 1m0s | the rough interval at which each store will check for load-based lease / replica rebalancing opportunities | Advanced/Self-Hosted | 
| kv.allocator.qps_rebalance_threshold | float | 0.1 | minimum fraction away from the mean a store's QPS (such as queries per second) can be before it is considered overfull or underfull | Advanced/Self-Hosted | 
| kv.allocator.range_rebalance_threshold | float | 0.05 | minimum fraction away from the mean a store's range count can be before it is considered overfull or underfull | Advanced/Self-Hosted | 
| kv.allocator.store_cpu_rebalance_threshold | float | 0.1 | minimum fraction away from the mean a store's cpu usage can be before it is considered overfull or underfull | Advanced/Self-Hosted | 
| kv.bulk_io_write.max_rate | byte size | 1.0 TiB | the rate limit (bytes/sec) to use for writes to disk on behalf of bulk io ops | Advanced/Self-Hosted | 
| kv.bulk_io_write.min_capacity_remaining_fraction | float | 0.05 | remaining store capacity fraction below which bulk ingestion requests are rejected | Advanced/Self-Hosted | 
| kv.bulk_sst.max_allowed_overage | byte size | 64 MiB | if positive, allowed size in excess of target size for SSTs from export requests; export requests (i.e. BACKUP) may buffer up to the sum of kv.bulk_sst.target_size and kv.bulk_sst.max_allowed_overage in memory | Advanced/Self-Hosted | 
| kv.bulk_sst.target_size | byte size | 16 MiB | target size for SSTs emitted from export requests; export requests (i.e. BACKUP) may buffer up to the sum of kv.bulk_sst.target_size and kv.bulk_sst.max_allowed_overage in memory | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.closed_timestamp.follower_reads.enabled | boolean | true | allow (all) replicas to serve consistent historical reads based on closed timestamp information | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.closed_timestamp.lead_for_global_reads_auto_tune.enabled | boolean | false | if enabled, observed network latency between leaseholders and their furthest follower will be used to adjust closed timestamp policies for rangesranges configured to serve global reads. kv.closed_timestamp.lead_for_global_reads_override takes precedence if set. | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.closed_timestamp.lead_for_global_reads_override | duration | 0s | if nonzero, overrides the lead time that global_read ranges use to publish closed timestamps | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.closed_timestamp.side_transport_interval | duration | 200ms | the interval at which the closed timestamp side-transport attempts to advance each range's closed timestamp; set to 0 to disable the side-transport | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.closed_timestamp.target_duration | duration | 3s | if nonzero, attempt to provide closed timestamp notifications for timestamps trailing cluster time by approximately this duration | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.dist_sender.circuit_breaker.cancellation.enabled | boolean | true | when enabled, in-flight requests will be cancelled when the circuit breaker trips | Basic/Standard/Advanced/Self-Hosted | 
| kv.dist_sender.circuit_breaker.cancellation.write_grace_period | duration | 10s | how long after the circuit breaker trips to cancel write requests (these can't retry internally, so should be long enough to allow quorum/lease recovery) | Basic/Standard/Advanced/Self-Hosted | 
| kv.dist_sender.circuit_breaker.probe.interval | duration | 3s | interval between replica probes | Basic/Standard/Advanced/Self-Hosted | 
| kv.dist_sender.circuit_breaker.probe.threshold | duration | 3s | duration of errors or stalls after which a replica will be probed | Basic/Standard/Advanced/Self-Hosted | 
| kv.dist_sender.circuit_breaker.probe.timeout | duration | 3s | timeout for replica probes | Basic/Standard/Advanced/Self-Hosted | 
| kv.dist_sender.circuit_breakers.mode | enumeration | liveness range only | set of ranges to trip circuit breakers for failing or stalled replicas [no ranges = 0, liveness range only = 1, all ranges = 2] | Basic/Standard/Advanced/Self-Hosted | 
| kv.lease_transfer_read_summary.global_budget | byte size | 0 B | controls the maximum number of bytes that will be used to summarize the global segment of the timestamp cache during lease transfers and range merges. A smaller budget will result in loss of precision. | Advanced/Self-Hosted | 
| kv.lease_transfer_read_summary.local_budget | byte size | 4.0 MiB | controls the maximum number of bytes that will be used to summarize the local segment of the timestamp cache during lease transfers and range merges. A smaller budget will result in loss of precision. | Advanced/Self-Hosted | 
| kv.log_range_and_node_events.enabled | boolean | true | set to true to transactionally log range events (e.g., split, merge, add/remove voter/non-voter) into system.rangelogand node join and restart events into system.eventolog | Advanced/Self-Hosted | 
| kv.protectedts.reconciliation.interval | duration | 5m0s | the frequency for reconciling jobs with protected timestamp records | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.raft.leader_fortification.fraction_enabled | float | 1 | controls the fraction of ranges for which the raft leader fortification protocol is enabled. Leader fortification is needed for a range to use a Leader lease. Set to 0.0 to disable leader fortification and, by extension, Leader leases. Set to 1.0 to enable leader fortification for all ranges and, by extension, use Leader leases for all ranges which do not require expiration-based leases. Set to a value between 0.0 and 1.0 to gradually roll out Leader leases across the ranges in a cluster. | Advanced/Self-Hosted | 
| kv.range.range_size_hard_cap | byte size | 8.0 GiB | hard cap on the maximum size a range is allowed to grow to withoutsplitting before writes to the range are blocked. Takes precedence over all other configurations | Advanced/Self-Hosted | 
| kv.range_split.by_load.enabled | boolean | true | allow automatic splits of ranges based on where load is concentrated | Advanced/Self-Hosted | 
| kv.range_split.load_cpu_threshold | duration | 500ms | the CPU use per second over which, the range becomes a candidate for load based splitting | Advanced/Self-Hosted | 
| kv.range_split.load_qps_threshold | integer | 2500 | the QPS over which, the range becomes a candidate for load based splitting | Advanced/Self-Hosted | 
| kv.rangefeed.client.stream_startup_rate | integer | 100 | controls the rate per second the client will initiate new rangefeed stream for a single range; 0 implies unlimited | Basic/Standard/Advanced/Self-Hosted | 
| kv.rangefeed.closed_timestamp_refresh_interval | duration | 3s | the interval at which closed-timestamp updatesare delivered to rangefeeds; set to 0 to use kv.closed_timestamp.side_transport_interval | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.rangefeed.enabled | boolean | false | if set, rangefeed registration is enabled | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| kv.replica_circuit_breaker.slow_replication_threshold | duration | 1m0s | duration after which slow proposals trip the per-Replica circuit breaker (zero duration disables breakers) | Advanced/Self-Hosted | 
| duration | 1m0s | duration after which leaderless replicas is considered unavailable. Set to 0 to disable leaderless replica availability checks | Advanced/Self-Hosted | |
| kv.replica_stats.addsst_request_size_factor | integer | 50000 | the divisor that is applied to addsstable request sizes, then recorded in a leaseholders QPS; 0 means all requests are treated as cost 1 | Advanced/Self-Hosted | 
| kv.replication_reports.interval | duration | 1m0s | the frequency for generating the replication_constraint_stats, replication_stats_report and replication_critical_localities reports (set to 0 to disable) | Advanced/Self-Hosted | 
| kv.snapshot_rebalance.max_rate | byte size | 32 MiB | the rate limit (bytes/sec) to use for rebalance and upreplication snapshots | Advanced/Self-Hosted | 
| kv.transaction.max_intents_and_locks | integer | 0 | maximum count of inserts or durable locks for a single transactions, 0 to disable | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.max_intents_bytes | integer | 4194304 | maximum number of bytes used to track locks in transactions | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.max_refresh_spans_bytes | integer | 4194304 | maximum number of bytes used to track refresh spans in serializable transactions | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.randomized_anchor_key.enabled | boolean | false | dictates whether a transactions anchor key is randomized or not | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.reject_over_max_intents_budget.enabled | boolean | false | if set, transactions that exceed their lock tracking budget (kv.transaction.max_intents_bytes) are rejected instead of having their lock spans imprecisely compressed | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.write_pipelining.locking_reads.enabled | boolean | true | if enabled, transactional locking reads are pipelined through Raft consensus | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.write_pipelining.ranged_writes.enabled | boolean | true | if enabled, transactional ranged writes are pipelined through Raft consensus | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.write_pipelining.enabled | boolean | true | if enabled, transactional writes are pipelined through Raft consensus | Basic/Standard/Advanced/Self-Hosted | 
| kv.transaction.write_pipelining.max_batch_size | integer | 128 | if non-zero, defines that maximum size batch that will be pipelined through Raft consensus | Basic/Standard/Advanced/Self-Hosted | 
| kvadmission.store.provisioned_bandwidth | byte size | 0 B | if set to a non-zero value, this is used as the provisioned bandwidth (in bytes/s), for each store. It can be overridden on a per-store basis using the --store flag. Note that setting the provisioned bandwidth to a positive value may enable disk bandwidth based admission control, since admission.disk_bandwidth_tokens.elastic.enabled defaults to true | Advanced/Self-Hosted | 
| kvadmission.store.snapshot_ingest_bandwidth_control.enabled | boolean | true | if set to true, snapshot ingests will be subject to disk write control in AC | Advanced/Self-Hosted | 
| log.channel_compatibility_mode.enabled | boolean | true | when true, logs will continue to log to the expected logging channels; when false, logs will be moved to new logging channels as part of a logging channel consolidation effort | Basic/Standard/Advanced/Self-Hosted | 
| obs.tablemetadata.automatic_updates.enabled | boolean | false | enables automatic updates of the table metadata cache system.table_metadata | Basic/Standard/Advanced/Self-Hosted | 
| obs.tablemetadata.data_valid_duration | duration | 20m0s | the duration for which the data in system.table_metadata is considered valid | Basic/Standard/Advanced/Self-Hosted | 
| schedules.backup.gc_protection.enabled | boolean | true | enable chaining of GC protection across backups run as part of a schedule | Basic/Standard/Advanced/Self-Hosted | 
| security.client_cert.subject_required.enabled | boolean | false | mandates a requirement for subject role to be set for db user | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| security.ocsp.mode | enumeration | off | use OCSP to check whether TLS certificates are revoked. If the OCSP server is unreachable, in strict mode all certificates will be rejected and in lax mode all certificates will be accepted. [off = 0, lax = 1, strict = 2] | Basic/Standard/Advanced/Self-Hosted | 
| security.ocsp.timeout | duration | 3s | timeout before considering the OCSP server unreachable | Basic/Standard/Advanced/Self-Hosted | 
| security.provisioning.ldap.enabled | boolean | false | enables automatic creation of SQL users upon successful LDAP login | Basic/Standard/Advanced/Self-Hosted | 
| server.auth_log.sql_connections.enabled | boolean | false | if set, log SQL client connect and disconnect events to the SESSIONS log channel (note: may hinder performance on loaded nodes) | Basic/Standard/Advanced/Self-Hosted | 
| server.auth_log.sql_sessions.enabled | boolean | false | if set, log verbose SQL session authentication events to the SESSIONS log channel (note: may hinder performance on loaded nodes). Session start and end events are always logged regardless of this setting; disable the SESSIONS log channel to suppress them. | Basic/Standard/Advanced/Self-Hosted | 
| server.authentication_cache.enabled | boolean | true | enables a cache used during authentication to avoid lookups to system tables when retrieving per-user authentication-related information | Basic/Standard/Advanced/Self-Hosted | 
| server.child_metrics.enabled | boolean | false | enables the exporting of child metrics, additional prometheus time series with extra labels | Basic/Standard/Advanced/Self-Hosted | 
| server.child_metrics.include_aggregate.enabled | boolean | true | include the reporting of the aggregate time series when child metrics are enabled. This cluster setting has no effect if child metrics are disabled. | Basic/Standard/Advanced/Self-Hosted | 
| server.clock.forward_jump_check.enabled | boolean | false | if enabled, forward clock jumps > max_offset/2 will cause a panic | Basic/Standard/Advanced/Self-Hosted | 
| server.clock.persist_upper_bound_interval | duration | 0s | the interval between persisting the wall time upper bound of the clock. The clock does not generate a wall time greater than the persisted timestamp and will panic if it sees a wall time greater than this value. When cockroach starts, it waits for the wall time to catch-up till this persisted timestamp. This guarantees monotonic wall time across server restarts. Not setting this or setting a value of 0 disables this feature. | Basic/Standard/Advanced/Self-Hosted | 
| server.consistency_check.max_rate | byte size | 8.0 MiB | the rate limit (bytes/sec) to use for consistency checks; used in conjunction with server.consistency_check.interval to control the frequency of consistency checks. Note that setting this too high can negatively impact performance. | Advanced/Self-Hosted | 
| server.eventlog.enabled | boolean | true | if set, logged notable events are also stored in the table system.eventlog | Basic/Standard/Advanced/Self-Hosted | 
| server.eventlog.ttl | duration | 2160h0m0s | if nonzero, entries in system.eventlog older than this duration are periodically purged | Basic/Standard/Advanced/Self-Hosted | 
| server.host_based_authentication.configuration | string |  | host-based authentication configuration to use during connection authentication | Basic/Standard/Advanced/Self-Hosted | 
| server.hot_ranges_request.node.timeout | duration | 5m0s | the duration allowed for a single node to return hot range data before the request is cancelled; if set to 0, there is no timeout | Basic/Standard/Advanced/Self-Hosted | 
| server.hsts.enabled | boolean | false | if true, HSTS headers will be sent along with all HTTP requests. The headers will contain a max-age setting of one year. Browsers honoring the header will always use HTTPS to access the DB Console. Ensure that TLS is correctly configured prior to enabling. | Basic/Standard/Advanced/Self-Hosted | 
| server.http.base_path | string | / | path to redirect the user to upon succcessful login | Basic/Standard/Advanced/Self-Hosted | 
| server.identity_map.configuration | string |  | system-identity to database-username mappings | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.audience | string |  | sets accepted audience values for JWT logins over the SQL interface | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.claim | string |  | sets the JWT claim that is parsed to get the username | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.client.timeout | duration | 15s | sets the client timeout for external calls made during JWT authentication (e.g. fetching JWKS, etc.) | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.enabled | boolean | false | enables or disables JWT login for the SQL interface | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.issuers.configuration | string |  | sets accepted issuer values for JWT logins over the SQL interface which can be a single issuer URL string or a JSON string containing an array of issuer URLs or a JSON object containing map of issuer URLS to JWKS URIs | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.issuers.custom_ca | string |  | sets the PEM encoded custom root CA for verifying certificates while fetching JWKS | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.jwks | string | {"keys":[]} | sets the public key set for JWT logins over the SQL interface (JWKS format) | Basic/Standard/Advanced/Self-Hosted | 
| server.jwt_authentication.jwks_auto_fetch.enabled | boolean | false | enables or disables automatic fetching of JWKS from the issuer's well-known endpoint or JWKS URI set in JWTAuthIssuersConfig. If this is enabled, the server.jwt_authentication.jwks will be ignored. | Basic/Standard/Advanced/Self-Hosted | 
| server.ldap_authentication.client.tls_certificate | string |  | sets the client certificate PEM for establishing mTLS connection with LDAP server | Basic/Standard/Advanced/Self-Hosted | 
| server.ldap_authentication.client.tls_key | string |  | sets the client key PEM for establishing mTLS connection with LDAP server | Basic/Standard/Advanced/Self-Hosted | 
| server.ldap_authentication.domain.custom_ca | string |  | sets the PEM encoded custom root CA for verifying domain certificates when establishing connection with LDAP server | Basic/Standard/Advanced/Self-Hosted | 
| server.log_gc.max_deletions_per_cycle | integer | 1000 | the maximum number of entries to delete on each purge of log-like system tables | Basic/Standard/Advanced/Self-Hosted | 
| server.log_gc.period | duration | 1h0m0s | the period at which log-like system tables are checked for old entries | Basic/Standard/Advanced/Self-Hosted | 
| server.max_connections_per_gateway | integer | -1 | the maximum number of SQL connections per gateway allowed at a given time (note: this will only limit future connection attempts and will not affect already established connections). Negative values result in unlimited number of connections. Superusers are not affected by this limit. | Basic/Standard/Advanced/Self-Hosted | 
| server.max_open_transactions_per_gateway | integer | -1 | the maximum number of open SQL transactions per gateway allowed at a given time. Negative values result in unlimited number of connections. Superusers are not affected by this limit. | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.autologin.enabled | boolean | false | if true, logged-out visitors to the DB Console will be automatically redirected to the OIDC login endpoint | Basic/Standard/Advanced/Self-Hosted | 
| string | Log in with your OIDC provider | text to show on button on DB Console login page to login with your OIDC provider (only shown if OIDC is enabled) | Basic/Standard/Advanced/Self-Hosted | |
| server.oidc_authentication.claim_json_key | string |  | sets JSON key of principal to extract from payload after OIDC authentication completes (usually email or sid) | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.client.timeout | duration | 15s | sets the client timeout for external calls made during OIDC authentication (e.g. authorization code flow, etc.) | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.client_id | string |  | sets OIDC client id | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.client_secret | string |  | sets OIDC client secret | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.enabled | boolean | false | enables or disabled OIDC login for the DB Console | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.principal_regex | string | (.+) | regular expression to apply to extracted principal (see claim_json_key setting) to translate to SQL user (golang regex format, must include 1 grouping to extract) | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.provider.custom_ca | string |  | sets the PEM encoded custom root CA for verifying certificates while authenticating through the OIDC provider | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.provider_url | string |  | sets OIDC provider URL ({provider_url}/.well-known/openid-configuration must resolve) | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.redirect_url | string | https://localhost:8080/oidc/v1/callback | sets OIDC redirect URL via a URL string or a JSON string containing a required `redirect_urls` key with an object that maps from region keys to URL strings (URLs should point to your load balancer and must route to the path /oidc/v1/callback) | Basic/Standard/Advanced/Self-Hosted | 
| server.oidc_authentication.scopes | string | openid | sets OIDC scopes to include with authentication request (space delimited list of strings, required to start with `openid`) | Basic/Standard/Advanced/Self-Hosted | 
| server.rangelog.ttl | duration | 720h0m0s | if nonzero, entries in system.rangelog older than this duration are periodically purged | Advanced/Self-Hosted | 
| server.redact_sensitive_settings.enabled | boolean | false | enables or disables the redaction of sensitive settings in the output of SHOW CLUSTER SETTINGS and SHOW ALL CLUSTER SETTINGS for users without the MODIFYCLUSTERSETTING privilege | Basic/Standard/Advanced/Self-Hosted | 
| server.shutdown.connections.timeout | duration | 0s | the maximum amount of time a server waits for all SQL connections to be closed before proceeding with a drain. (note that the --drain-wait parameter for cockroach node drain may need adjustment after changing this setting) | Basic/Standard/Advanced/Self-Hosted | 
| server.shutdown.initial_wait | duration | 0s | the amount of time a server waits in an unready state before proceeding with a drain (note that the --drain-wait parameter for cockroach node drain may need adjustment after changing this setting. --drain-wait is to specify the duration of the whole draining process, while server.shutdown.initial_wait is to set the wait time for health probes to notice that the node is not ready.) | Basic/Standard/Advanced/Self-Hosted | 
| server.shutdown.lease_transfer_iteration.timeout | duration | 5s | the timeout for a single iteration of the range lease transfer phase of draining (note that the --drain-wait parameter for cockroach node drain may need adjustment after changing this setting) | Advanced/Self-Hosted | 
| server.shutdown.transactions.timeout | duration | 10s | the timeout for waiting for active transactions to finish during a drain (note that the --drain-wait parameter for cockroach node drain may need adjustment after changing this setting) | Basic/Standard/Advanced/Self-Hosted | 
| server.sql_tcp_keep_alive.count | integer | 3 | maximum number of probes that will be sent out before a connection is dropped because it's unresponsive (Linux and Darwin only) | Basic/Standard/Advanced/Self-Hosted | 
| server.sql_tcp_keep_alive.interval | duration | 10s | time between keep alive probes and idle time before probes are sent out | Basic/Standard/Advanced/Self-Hosted | 
| server.time_until_store_dead | duration | 5m0s | the time after which if there is no new gossiped information about a store, it is considered dead | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.cert_password_method.auto_scram_promotion.enabled | boolean | true | whether to automatically promote cert-password authentication to use SCRAM | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.downgrade_scram_stored_passwords_to_bcrypt.enabled | boolean | true | if server.user_login.password_encryption=crdb-bcrypt, this controls whether to automatically re-encode stored passwords using scram-sha-256 to crdb-bcrypt | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.min_password_length | integer | 1 | the minimum length accepted for passwords set in cleartext via SQL. Note that a value lower than 1 is ignored: passwords cannot be empty in any case. This setting only applies when adding new users or altering an existing user's password; it will not affect existing logins. | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.password_encryption | enumeration | scram-sha-256 | which hash method to use to encode cleartext passwords passed via ALTER/CREATE USER/ROLE WITH PASSWORD [crdb-bcrypt = 2, scram-sha-256 = 3] | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.password_hashes.default_cost.crdb_bcrypt | integer | 10 | the hashing cost to use when storing passwords supplied as cleartext by SQL clients with the hashing method crdb-bcrypt (allowed range: 4-31) | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.password_hashes.default_cost.scram_sha_256 | integer | 10610 | the hashing cost to use when storing passwords supplied as cleartext by SQL clients with the hashing method scram-sha-256 (allowed range: 4096-240000000000) | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.rehash_scram_stored_passwords_on_cost_change.enabled | boolean | true | if server.user_login.password_hashes.default_cost.scram_sha_256 differs from, the cost in a stored hash, this controls whether to automatically re-encode stored passwords using scram-sha-256 with the new default cost | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.timeout | duration | 10s | timeout after which client authentication times out if some system range is unavailable (0 = no timeout) | Basic/Standard/Advanced/Self-Hosted | 
| server.user_login.upgrade_bcrypt_stored_passwords_to_scram.enabled | boolean | true | if server.user_login.password_encryption=scram-sha-256, this controls whether to automatically re-encode stored passwords using crdb-bcrypt to scram-sha-256 | Basic/Standard/Advanced/Self-Hosted | 
| server.web_session.purge.ttl | duration | 1h0m0s | if nonzero, entries in system.web_sessions older than this duration are periodically purged | Basic/Standard/Advanced/Self-Hosted | 
| server.web_session.timeout | duration | 168h0m0s | the duration that a newly created web session will be valid | Basic/Standard/Advanced/Self-Hosted | 
| spanconfig.bounds.enabled | boolean | true | dictates whether span config bounds are consulted when serving span configs for secondary tenants | Advanced/Self-Hosted | 
| spanconfig.range_coalescing.system.enabled | boolean | true | collapse adjacent ranges with the same span configs, for the ranges specific to the system tenant | Advanced/Self-Hosted | 
| spanconfig.range_coalescing.application.enabled | boolean | true | collapse adjacent ranges with the same span configs across all secondary tenant keyspaces | Advanced/Self-Hosted | 
| sql.auth.change_own_password.enabled | boolean | false | controls whether a user is allowed to change their own password, even if they have no other privileges | Basic/Standard/Advanced/Self-Hosted | 
| sql.auth.grant_option_for_owner.enabled | boolean | true | determines whether the GRANT OPTION for privileges is implicitly given to the owner of an object | Basic/Standard/Advanced/Self-Hosted | 
| sql.auth.grant_option_inheritance.enabled | boolean | true | determines whether the GRANT OPTION for privileges is inherited through role membership | Basic/Standard/Advanced/Self-Hosted | 
| sql.auth.public_schema_create_privilege.enabled | boolean | true | determines whether to grant all users the CREATE privileges on the public schema when it is created | Basic/Standard/Advanced/Self-Hosted | 
| sql.catalog.allow_leased_descriptors.enabled | boolean | false | if true, catalog views (crdb_internal, information_schema, pg_catalog) can use leased descriptors for improved performance | Basic/Standard/Advanced/Self-Hosted | 
| sql.closed_session_cache.capacity | integer | 1000 | the maximum number of sessions in the cache | Basic/Standard/Advanced/Self-Hosted | 
| sql.closed_session_cache.time_to_live | integer | 3600 | the maximum time to live, in seconds | Basic/Standard/Advanced/Self-Hosted | 
| sql.contention.event_store.capacity | byte size | 64 MiB | the in-memory storage capacity per-node of contention event store | Basic/Standard/Advanced/Self-Hosted | 
| sql.contention.event_store.duration_threshold | duration | 0s | minimum contention duration to cause the contention events to be collected into crdb_internal.transaction_contention_events | Basic/Standard/Advanced/Self-Hosted | 
| sql.contention.record_serialization_conflicts.enabled | boolean | true | enables recording 40001 errors with conflicting txn meta as SERIALIZATION_CONFLICTcontention events into crdb_internal.transaction_contention_events | Basic/Standard/Advanced/Self-Hosted | 
| sql.contention.txn_id_cache.max_size | byte size | 64 MiB | the maximum byte size TxnID cache will use (set to 0 to disable) | Basic/Standard/Advanced/Self-Hosted | 
| sql.cross_db_fks.enabled | boolean | false | if true, creating foreign key references across databases is allowed | Basic/Standard/Advanced/Self-Hosted | 
| sql.cross_db_sequence_owners.enabled | boolean | false | if true, creating sequences owned by tables from other databases is allowed | Basic/Standard/Advanced/Self-Hosted | 
| sql.cross_db_sequence_references.enabled | boolean | false | if true, sequences referenced by tables from other databases are allowed | Basic/Standard/Advanced/Self-Hosted | 
| sql.cross_db_views.enabled | boolean | false | if true, creating views that refer to other databases is allowed | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.cost_scans_with_default_col_size.enabled | boolean | false | setting to true uses the same size for all columns to compute scan cost This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.datestyle | enumeration | iso, mdy | default value for DateStyle session setting [iso, mdy = 0, iso, dmy = 1, iso, ymd = 2] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.default_hash_sharded_index_bucket_count | integer | 16 | used as bucket count if bucket count is not specified in hash sharded index definition This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.default_int_size | integer | 8 | the size, in bytes, of an INT type This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.disallow_full_table_scans.enabled | boolean | false | setting to true rejects queries that have planned a full table scan; set large_full_scan_rows > 0 to allow small full table scans estimated to read fewer than large_full_scan_rows This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.distsql | enumeration | auto | default distributed SQL execution mode [off = 0, auto = 1, on = 2, always = 3] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.experimental_alter_column_type.enabled | boolean | false | default value for experimental_alter_column_type session setting; enables the use of ALTER COLUMN TYPE for general conversions This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.experimental_distsql_planning | enumeration | off | default experimental_distsql_planning mode; enables experimental opt-driven DistSQL planning [off = 0, on = 1] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.experimental_enable_unique_without_index_constraints.enabled | boolean | false | default value for experimental_enable_unique_without_index_constraints session setting;disables unique without index constraints by default This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.experimental_implicit_column_partitioning.enabled | boolean | false | default value for experimental_enable_temp_tables; allows for the use of implicit column partitioning This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.experimental_temporary_tables.enabled | boolean | false | default value for experimental_enable_temp_tables; allows for use of temporary tables by default This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.foreign_key_cascades_limit | integer | 10000 | default value for foreign_key_cascades_limit session setting; limits the number of cascading operations that run as part of a single query This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.idle_in_session_timeout | duration | 0s | default value for the idle_in_session_timeout; default value for the idle_in_session_timeout session setting; controls the duration a session is permitted to idle before the session is terminated; if set to 0, there is no timeout This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.idle_in_transaction_session_timeout | duration | 0s | default value for the idle_in_transaction_session_timeout; controls the duration a session is permitted to idle in a transaction before the session is terminated; if set to 0, there is no timeout This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.implicit_select_for_update.enabled | boolean | true | default value for enable_implicit_select_for_update session setting; enables FOR UPDATE locking during the row-fetch phase of mutation statements This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.insert_fast_path.enabled | boolean | true | default value for enable_insert_fast_path session setting; enables a specialized insert path This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.intervalstyle | enumeration | postgres | default value for IntervalStyle session setting [postgres = 0, iso_8601 = 1, sql_standard = 2] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.large_full_scan_rows | float | 0 | default value for large_full_scan_rows session variable which determines the table size at which full scans are considered large and disallowed when disallow_full_table_scans is set to true; set to 0 to reject all full table or full index scans when disallow_full_table_scans is true This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.locality_optimized_partitioned_index_scan.enabled | boolean | true | default value for locality_optimized_partitioned_index_scan session setting; enables searching for rows in the current region before searching remote regions This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.lock_timeout | duration | 0s | default value for the lock_timeout; default value for the lock_timeout session setting; controls the duration a query is permitted to wait while attempting to acquire a lock on a key or while blocking on an existing lock in order to perform a non-locking read on a key; if set to 0, there is no timeout This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.on_update_rehome_row.enabled | boolean | true | default value for on_update_rehome_row; enables ON UPDATE rehome_row() expressions to trigger on updates This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.optimizer_use_histograms.enabled | boolean | true | default value for optimizer_use_histograms session setting; enables usage of histograms in the optimizer by default This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.optimizer_use_multicol_stats.enabled | boolean | true | default value for optimizer_use_multicol_stats session setting; enables usage of multi-column stats in the optimizer by default This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.override_alter_primary_region_in_super_region.enabled | boolean | false | default value for override_alter_primary_region_in_super_region; allows for altering the primary region even if the primary region is a member of a super region This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.override_multi_region_zone_config.enabled | boolean | false | default value for override_multi_region_zone_config; allows for overriding the zone configs of a multi-region table or database This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.prefer_lookup_joins_for_fks.enabled | boolean | false | default value for prefer_lookup_joins_for_fks session setting; causes foreign key operations to use lookup joins when possible This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.primary_region | string |  | if not empty, all databases created without a PRIMARY REGION will implicitly have the given PRIMARY REGION This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.reorder_joins_limit | integer | 8 | default number of joins to reorder This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.require_explicit_primary_keys.enabled | boolean | false | default value for requiring explicit primary keys in CREATE TABLE statements This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.results_buffer.size | byte size | 512 KiB | default size of the buffer that accumulates results for a statement or a batch of statements before they are sent to the client. This can be overridden on an individual connection with the 'results_buffer_size' parameter. Note that auto-retries generally only happen while no results have been delivered to the client, so reducing this size can increase the number of retriable errors a client receives. On the other hand, increasing the buffer size can increase the delay until the client receives the first result row. Updating the setting only affects new connections. Setting to 0 disables any buffering. This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.serial_normalization | enumeration | rowid | default handling of SERIAL in table definitions [rowid = 0, virtual_sequence = 1, sql_sequence = 2, sql_sequence_cached = 3, unordered_rowid = 4, sql_sequence_cached_node = 5] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.statement_timeout | duration | 0s | default value for the statement_timeout; default value for the statement_timeout session setting; controls the duration a query is permitted to run before it is canceled; if set to 0, there is no timeout This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.stub_catalog_tables.enabled | boolean | true | default value for stub_catalog_tables session setting This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.super_regions.enabled | boolean | false | default value for enable_super_regions; allows for the usage of super regions This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.transaction_rows_read_err | integer | 0 | the limit for the number of rows read by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.transaction_rows_read_log | integer | 0 | the threshold for the number of rows read by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.transaction_rows_written_err | integer | 0 | the limit for the number of rows written by a SQL transaction which - once exceeded - will fail the transaction (or will trigger a logging event to SQL_INTERNAL_PERF for internal transactions); use 0 to disable This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.transaction_rows_written_log | integer | 0 | the threshold for the number of rows written by a SQL transaction which - once exceeded - will trigger a logging event to SQL_PERF (or SQL_INTERNAL_PERF for internal transactions); use 0 to disable This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.use_declarative_schema_changer | enumeration | on | default value for use_declarative_schema_changer session setting;disables new schema changer by default [off = 0, on = 1, unsafe = 2, unsafe_always = 3] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.vectorize | enumeration | on | default vectorize mode [on = 0, on = 1, on = 2, experimental_always = 3, off = 4] This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.defaults.zigzag_join.enabled | boolean | false | default value for enable_zigzag_join session setting; disallows use of zig-zag join by default This cluster setting is being kept to preserve backwards-compatibility. This session variable default should now be configured using ALTER ROLE... SET | Basic/Standard/Advanced/Self-Hosted | 
| sql.distsql.temp_storage.workmem | byte size | 64 MiB | maximum amount of memory in bytes a processor can use before falling back to temp storage | Basic/Standard/Advanced/Self-Hosted | 
| sql.guardrails.max_row_size_err | byte size | 512 MiB | maximum size of row (or column family if multiple column families are in use) that SQL can write to the database, above which an error is returned; use 0 to disable | Basic/Standard/Advanced/Self-Hosted | 
| sql.guardrails.max_row_size_log | byte size | 64 MiB | maximum size of row (or column family if multiple column families are in use) that SQL can write to the database, above which an event is logged to SQL_PERF (or SQL_INTERNAL_PERF if the mutating statement was internal); use 0 to disable | Basic/Standard/Advanced/Self-Hosted | 
| sql.hash_sharded_range_pre_split.max | integer | 16 | max pre-split ranges to have when adding hash sharded index to an existing table | Basic/Standard/Advanced/Self-Hosted | 
| sql.index_recommendation.drop_unused_duration | duration | 168h0m0s | the index unused duration at which we begin to recommend dropping the index | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.anomaly_detection.enabled | boolean | true | enable per-fingerprint latency recording and anomaly detection | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.anomaly_detection.latency_threshold | duration | 50ms | statements must surpass this threshold to trigger anomaly detection and identification | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.anomaly_detection.memory_limit | byte size | 1.0 MiB | the maximum amount of memory allowed for tracking statement latencies | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.execution_insights_capacity | integer | 1000 | the size of the per-node store of execution insights | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.high_retry_count.threshold | integer | 10 | the number of retries a slow statement must have undergone for its high retry count to be highlighted as a potential problem | Basic/Standard/Advanced/Self-Hosted | 
| sql.insights.latency_threshold | duration | 100ms | amount of time after which an executing statement is considered slow. Use 0 to disable. | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.redact_names.enabled | boolean | false | if set, schema object identifers are redacted in SQL statements that appear in event logs | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.scan_row_count_misestimate.enabled | boolean | false | when set to true, log a warning when a scan's actual row count differs significantly from the optimizer's estimate | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.slow_query.experimental_full_table_scans.enabled | boolean | false | when set to true, statements that perform a full table/index scan will be logged to the slow query log even if they do not meet the latency threshold. Must have the slow query log enabled for this setting to have any effect. | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.slow_query.internal_queries.enabled | boolean | false | when set to true, internal queries which exceed the slow query log threshold are logged to a separate log. Must have the slow query log enabled for this setting to have any effect. | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.slow_query.latency_threshold | duration | 0s | when set to non-zero, log statements whose service latency exceeds the threshold to a secondary logger on each node | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.user_audit | string |  | user/role-based audit logging configuration. An enterprise license is required for this cluster setting to take effect. | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.user_audit.reduced_config.enabled | boolean | false | enables logic to compute a reduced audit configuration, computing the audit configuration only once at session start instead of at each SQL event. The tradeoff with the increase in performance (~5%), is that changes to the audit configuration (user role memberships/cluster setting) are not reflected within session. Users will need to start a new session to see these changes in their auditing behaviour. | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.application_name.enabled | boolean | false | when enabled, SQL metrics would export application name as and additional label as part of child metrics. The number of unique label combinations is limited to 5000 by default. | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.database_name.enabled | boolean | false | when enabled, SQL metrics would export database name as and additional label as part of child metrics. The number of unique label combinations is limited to 5000 by default. | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.index_usage_stats.enabled | boolean | true | collect per index usage statistics | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.max_mem_reported_stmt_fingerprints | integer | 100000 | the maximum number of reported statement fingerprints stored in memory | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.max_mem_reported_txn_fingerprints | integer | 100000 | the maximum number of reported transaction fingerprints stored in memory | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.max_mem_stmt_fingerprints | integer | 7500 | the maximum number of statement fingerprints stored in memory | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.max_mem_txn_fingerprints | integer | 7500 | the maximum number of transaction fingerprints stored in memory | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.dump_to_logs.enabled | boolean | false | dump collected statement statistics to node logs when periodically cleared | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.enabled | boolean | true | collect per-statement query statistics | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.gateway_node.enabled | boolean | false | save the gateway node for each statement fingerprint. If false, the value will be stored as 0. | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.index_recommendation_collection.enabled | boolean | true | generate an index recommendation for each fingerprint ID | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.max_mem_reported_idx_recommendations | integer | 5000 | the maximum number of reported index recommendation info stored in memory | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.statement_details.threshold | duration | 0s | minimum execution time to cause statement statistics to be collected. If configured, no transaction stats are collected. | Basic/Standard/Advanced/Self-Hosted | 
| sql.metrics.transaction_details.enabled | boolean | true | collect per-application transaction statistics | Basic/Standard/Advanced/Self-Hosted | 
| sql.multiple_modifications_of_table.enabled | boolean | false | if true, allow statements containing multiple INSERT ON CONFLICT, UPSERT, UPDATE, or DELETE subqueries modifying the same table, at the risk of data corruption if the same row is modified multiple times by a single statement (multiple INSERT subqueries without ON CONFLICT cannot cause corruption and are always allowed) | Basic/Standard/Advanced/Self-Hosted | 
| sql.multiregion.drop_primary_region.enabled | boolean | true | allows dropping the PRIMARY REGION of a database if it is the last region | Basic/Standard/Advanced/Self-Hosted | 
| sql.notices.enabled | boolean | true | enable notices in the server/client protocol being sent | Basic/Standard/Advanced/Self-Hosted | 
| sql.optimizer.uniqueness_checks_for_gen_random_uuid.enabled | boolean | false | if enabled, uniqueness checks may be planned for mutations of UUID columns updated with gen_random_uuid(); otherwise, uniqueness is assumed due to near-zero collision probability | Basic/Standard/Advanced/Self-Hosted | 
| sql.schema.approx_max_object_count | integer | 20000 | approximate maximum number of schema objects allowed in the cluster; the check uses cached statistics, so the actual count may slightly exceed this limit; set to 0 to disable | Basic/Standard/Advanced/Self-Hosted | 
| sql.schema.telemetry.recurrence | string | @weekly | cron-tab recurrence for SQL schema telemetry job | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| sql.spatial.experimental_box2d_comparison_operators.enabled | boolean | false | enables the use of certain experimental box2d comparison operators | Basic/Standard/Advanced/Self-Hosted | 
| sql.sqlcommenter.enabled | boolean | false | enables support for sqlcommenter. Key value parsed from sqlcommenter comments will be included in sql insights and sql logs. See https://google.github.io/sqlcommenter/ for more details. | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.activity.persisted_rows.max | integer | 200000 | maximum number of rows of statement and transaction activity that will be persisted in the system tables | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_collection.enabled | boolean | true | automatic statistics collection mode | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_collection.fraction_stale_rows | float | 0.2 | target fraction of stale rows per table that will trigger a statistics refresh | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_collection.min_stale_rows | integer | 500 | target minimum number of stale rows per table that will trigger a statistics refresh | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_full_collection.enabled | boolean | true | automatic full statistics collection mode | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_partial_collection.enabled | boolean | true | automatic partial statistics collection mode | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_partial_collection.fraction_stale_rows | float | 0.05 | target fraction of stale rows per table that will trigger a partial statistics refresh | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.automatic_partial_collection.min_stale_rows | integer | 100 | target minimum number of stale rows per table that will trigger a partial statistics refresh | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.cleanup.recurrence | string | @hourly | cron-tab recurrence for SQL Stats cleanup job | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.detailed_latency_metrics.enabled | boolean | false | label latency metrics with the statement fingerprint. Workloads with tens of thousands of distinct query fingerprints should leave this setting false. (experimental, affects performance for workloads with high fingerprint cardinality) | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.error_on_concurrent_create_stats.enabled | boolean | false | set to true to error on concurrent CREATE STATISTICS jobs, instead of skipping them | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.flush.enabled | boolean | true | if set, SQL execution statistics are periodically flushed to disk | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.flush.interval | duration | 10m0s | the interval at which SQL execution statistics are flushed to disk, this value must be less than or equal to 1 hour | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.forecasts.enabled | boolean | true | when true, enables generation of statistics forecasts by default for all tables | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.forecasts.max_decrease | float | 0.3333333333333333 | the most a prediction is allowed to decrease, expressed as the minimum ratio of the prediction to the lowest prior observation | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.forecasts.min_goodness_of_fit | float | 0.95 | the minimum R² (goodness of fit) measurement required from all predictive models to use a forecast | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.forecasts.min_observations | integer | 3 | the mimimum number of observed statistics required to produce a statistics forecast | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.histogram_buckets.count | integer | 200 | maximum number of histogram buckets to build during table statistics collection | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.histogram_buckets.include_most_common_values.enabled | boolean | true | whether to include most common values as histogram buckets | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.histogram_buckets.max_fraction_most_common_values | float | 0.1 | maximum fraction of histogram buckets to use for most common values | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.histogram_collection.enabled | boolean | true | histogram collection mode | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.histogram_samples.count | integer | 0 | number of rows sampled for histogram construction during table statistics collection. Not setting this or setting a value of 0 means that a reasonable sample size will be automatically picked based on the table size. | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.multi_column_collection.enabled | boolean | true | multi-column statistics collection mode | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.non_default_columns.min_retention_period | duration | 24h0m0s | minimum retention period for table statistics collected on non-default columns | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.non_indexed_json_histograms.enabled | boolean | false | set to true to collect table statistics histograms on non-indexed JSON columns | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.persisted_rows.max | integer | 1000000 | maximum number of rows of statement and transaction statistics that will be persisted in the system tables before compaction begins | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.post_events.enabled | boolean | false | if set, an event is logged for every successful CREATE STATISTICS job | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.response.max | integer | 20000 | the maximum number of statements and transaction stats returned in a CombinedStatements request | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.response.show_internal.enabled | boolean | false | controls if statistics for internal executions should be returned by the CombinedStatements and if internal sessions should be returned by the ListSessions endpoints. These endpoints are used to display statistics on the SQL Activity pages | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.system_tables.enabled | boolean | true | when true, enables use of statistics on system tables by the query optimizer | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.system_tables_autostats.enabled | boolean | true | when true, enables automatic collection of statistics on system tables | Basic/Standard/Advanced/Self-Hosted | 
| sql.stats.virtual_computed_columns.enabled | boolean | true | set to true to collect table statistics on virtual computed columns | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.query_sampling.enabled | boolean | false | when set to true, executed queries will emit an event on the telemetry logging channel | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.query_sampling.internal.enabled | boolean | false | when set to true, internal queries will be sampled in telemetry logging | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.query_sampling.max_event_frequency | integer | 8 | the max event frequency (events per second) at which we sample executions for telemetry, note that it is recommended that this value shares a log-line limit of 10 logs per second on the telemetry pipeline with all other telemetry events. If sampling mode is set to 'transaction', this value is ignored. | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.query_sampling.mode | enumeration | statement | the execution level used for telemetry sampling. If set to 'statement', events are sampled at the statement execution level. If set to 'transaction', events are sampled at the transaction execution level, i.e. all statements for a transaction will be logged and are counted together as one sampled event (events are still emitted one per statement). [statement = 0, transaction = 1] | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.transaction_sampling.max_event_frequency | integer | 8 | the max event frequency (events per second) at which we sample transactions for telemetry. If sampling mode is set to 'statement', this setting is ignored. In practice, this means that we only sample a transaction if 1/max_event_frequency seconds have elapsed since the last transaction was sampled. | Basic/Standard/Advanced/Self-Hosted | 
| sql.telemetry.transaction_sampling.statement_events_per_transaction.max | integer | 50 | the maximum number of statement events to log for every sampled transaction. Note that statements that are logged by force do not adhere to this limit. | Basic/Standard/Advanced/Self-Hosted | 
| sql.temp_object_cleaner.cleanup_interval | duration | 30m0s | how often to clean up orphaned temporary objects | Basic/Standard/Advanced/Self-Hosted | 
| sql.temp_object_cleaner.wait_interval | duration | 30m0s | how long after creation a temporary object will be cleaned up | Basic/Standard/Advanced/Self-Hosted | 
| sql.log.all_statements.enabled | boolean | false | set to true to enable logging of all executed statements | Basic/Standard/Advanced/Self-Hosted | 
| sql.trace.stmt.enable_threshold | duration | 0s | enables tracing on all statements; statements executing for longer than this duration will have their trace logged (set to 0 to disable); note that enabling this may have a negative performance impact; this setting applies to individual statements within a transaction and is therefore finer-grained than sql.trace.txn.enable_threshold | Basic/Standard/Advanced/Self-Hosted | 
| sql.trace.txn.enable_threshold | duration | 0s | enables transaction traces for transactions exceeding this duration, used with `sql.trace.txn.sample_rate` | Basic/Standard/Advanced/Self-Hosted | 
| sql.trace.txn.include_internal.enabled | boolean | true | enables tracing internal transactions as well as external workload using sample rate and threshold settings | Basic/Standard/Advanced/Self-Hosted | 
| sql.trace.txn.jaeger_json_output.enabled | boolean | false | enables Jaeger JSON output for transaction traces in logs | Basic/Standard/Advanced/Self-Hosted | 
| sql.trace.txn.sample_rate | float | 1 | enables probabilistic transaction tracing. It should be used in conjunction with `sql.trace.txn.enable_threshold`. A percentage of transactions between 0 and 1.0 will have tracing enabled, and only those which exceed the configured threshold will be logged. | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.changefeed_replication.disabled | boolean | false | if true, deletes issued by TTL will not be replicated via changefeeds (this setting will be ignored by changefeeds that have the ignore_disable_changefeed_replication option set; such changefeeds will continue to replicate all TTL deletes) | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.default_delete_batch_size | integer | 100 | default amount of rows to delete in a single query during a TTL job | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.default_delete_rate_limit | integer | 100 | default delete rate limit (rows per second) per node for each TTL job. Use 0 to signify no rate limit. | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.default_select_batch_size | integer | 500 | default amount of rows to select in a single query during a TTL job | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.default_select_rate_limit | integer | 0 | default select rate limit (rows per second) per node for each TTL job. Use 0 to signify no rate limit. | Basic/Standard/Advanced/Self-Hosted | 
| sql.ttl.job.enabled | boolean | true | whether the TTL job is enabled | Basic/Standard/Advanced/Self-Hosted | 
| sql.txn.read_committed_isolation.enabled | boolean | true | set to true to allow transactions to use the READ COMMITTED isolation level if specified by BEGIN/SET commands | Basic/Standard/Advanced/Self-Hosted | 
| sql.txn.repeatable_read_isolation.enabled | boolean | false | set to true to allow transactions to use the REPEATABLE READ isolation level if specified by BEGIN/SET commands | Basic/Standard/Advanced/Self-Hosted | 
| sql.txn_fingerprint_id_cache.capacity | integer | 100 | the maximum number of txn fingerprint IDs stored | Basic/Standard/Advanced/Self-Hosted | 
| sql.vecindex.stalled_op.timeout | duration | 100ms | amount of time before other vector index workers will assist with a stalled background fixup | Basic/Standard/Advanced/Self-Hosted | 
| storage.delete_compaction_excise.enabled | boolean | true | set to false to direct Pebble to not partially excise sstables in delete-only compactions | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| storage.ingest_split.enabled | boolean | true | set to false to disable ingest-time splitting that lowers write-amplification | Advanced/Self-Hosted | 
| storage.ingestion.value_blocks.enabled | boolean | true | set to true to enable writing of value blocks in ingestion sstables | Basic/Standard/Advanced/Self-Hosted | 
| storage.max_sync_duration | duration | 20s | maximum duration for disk operations; any operations that take longer than this setting trigger a warning log entry or process crash | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| storage.max_sync_duration.fatal.enabled | boolean | true | if true, fatal the process when a disk operation exceeds storage.max_sync_duration | Basic/Standard/Advanced/Self-Hosted | 
| storage.sstable.compression_algorithm | enumeration | fastest | determines the compression algorithm to use when compressing sstable data blocks for use in a Pebble store (balanced,good are experimental); [snappy = 1, zstd = 2, none = 3, minlz = 4, fastest = 5, balanced = 6, good = 7] | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| storage.sstable.compression_algorithm_backup_storage | enumeration | fastest | determines the compression algorithm to use when compressing sstable data blocks for backup row data storage (fast,balanced,good are experimental); [snappy = 1, zstd = 2, none = 3, minlz = 4, fastest = 5, fast = 6, balanced = 7, good = 8] | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| storage.sstable.compression_algorithm_backup_transport | enumeration | fastest | determines the compression algorithm to use when compressing sstable data blocks for backup transport (fast,balanced,good are experimental); [snappy = 1, zstd = 2, none = 3, minlz = 4, fastest = 5, fast = 6, balanced = 7, good = 8] | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| storage.unhealthy_write_duration | duration | 20s | duration for disk write operations, beyond which the disk will be reported as unhealthy for higher layer actions | Advanced/Self-Hosted | 
| storage.wal_failover.unhealthy_op_threshold | duration | 100ms | the latency of a WAL write considered unhealthy and triggers a failover to a secondary WAL location | Advanced/Self-Hosted | 
| timeseries.storage.enabled | boolean | true | if set, periodic timeseries data is stored within the cluster; disabling is not recommended unless you are storing the data elsewhere | Advanced/Self-Hosted | 
| timeseries.storage.resolution_10s.ttl | duration | 240h0m0s | the maximum age of time series data stored at the 10 second resolution. Data older than this is subject to rollup and deletion. | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| timeseries.storage.resolution_30m.ttl | duration | 2160h0m0s | the maximum age of time series data stored at the 30 minute resolution. Data older than this is subject to deletion. | Advanced/Self-hosted (read-write); Basic/Standard (read-only) | 
| trace.debug_http_endpoint.enabled | boolean | false | if set, traces for recent requests can be seen at https://<ui>/debug/requests | Basic/Standard/Advanced/Self-Hosted | 
| trace.opentelemetry.collector | string |  | address of an OpenTelemetry trace collector to receive traces using the otel gRPC protocol, as <host>:<port>. If no port is specified, 4317 will be used. | Basic/Standard/Advanced/Self-Hosted | 
| trace.snapshot.rate | duration | 0s | if non-zero, interval at which background trace snapshots are captured | Basic/Standard/Advanced/Self-Hosted | 
| trace.span_registry.enabled | boolean | false | if set, ongoing traces can be seen at https://<ui>/#/debug/tracez | Basic/Standard/Advanced/Self-Hosted | 
| trace.zipkin.collector | string |  | the address of a Zipkin instance to receive traces, as <host>:<port>. If no port is specified, 9411 will be used. | Basic/Standard/Advanced/Self-Hosted | 
| ui.database_locality_metadata.enabled | boolean | true | if enabled shows extended locality data about databases and tables in DB Console which can be expensive to compute | Basic/Standard/Advanced/Self-Hosted | 
| ui.default_timezone | string |  | the default timezone used to format timestamps in the ui | Basic/Standard/Advanced/Self-Hosted | 
| ui.display_timezone | enumeration | etc/utc | the timezone used to format timestamps in the ui. This setting is deprecatedand will be removed in a future version. Use the 'ui.default_timezone' setting instead. 'ui.default_timezone' takes precedence over this setting. [etc/utc = 0, america/new_york = 1] | Basic/Standard/Advanced/Self-Hosted | 
| version | version | 25.4 | set the active cluster version in the format '<major>.<minor>' | Basic/Standard/Advanced/Self-Hosted | 
View current cluster settings
Use the SHOW CLUSTER SETTING statement.
Change a cluster setting
Cluster settings can be updated via SQL command while the cluster is running. Use the SET CLUSTER SETTING statement.
Before changing a cluster setting, note the following:
- Changing a cluster setting is not instantaneous, as the change must be propagated to other nodes in the cluster. 
- Do not change cluster settings while upgrading to a new version of CockroachDB. Wait until all nodes have been upgraded before you make the change. 
Sensitive settings
You can prevent users without sufficient permissions from viewing the values of cluster settings that CockroachDB classifies as sensitive.
By default, users with the VIEWCLUSTERSETTING privilege can view the values of all settings displayed when using the SHOW CLUSTER SETTING statement and the DB Console Advanced Debug > Cluster Settings page.
If you enable the option to redact sensitive settings, the sensitive setting values are hidden from those users, and visible only to users with the admin role or the MODIFYCLUSTERSETTING privilege.
To enable this redaction of sensitive setting values, set the cluster setting server.redact_sensitive_settings.enabled to true:
SET CLUSTER SETTING server.redact_sensitive_settings.enabled = 'true';
The table summarizes when sensitive setting values are visible or redacted:
| User attribute | Redaction disabled | Redaction enabled | 
|---|---|---|
| adminrole | visible | visible | 
| MODIFYCLUSTERSETTINGsystem-level privilege | visible | visible | 
| VIEWCLUSTERSETTINGsystem-level privilege | visible | redacted | 
| None of the above attributes | not visible | not visible | 
The following are sensitive settings whose values are redacted:
- server.host_based_authentication.configuration
- server.identity_map.configuration
- server.jwt_authentication.issuers.custom_ca
- server.ldap_authentication.domain.custom_ca
- server.ldap_authentication.client.tls_certificate
- server.ldap_authentication.client.tls_key
- server.oidc_authentication.client_id
- server.oidc_authentication.client_secret