Skip to content

Commit a00f09d

Browse files
authored
DOC-15108: Phase 4: Update the Cluster Virtualization metrics and cluster settings pages for v25.4.0 (#20951)
- Updated cluster-settings.csv, ran `cockroach gen settings-list --show-class --format=csv > cluster-settings.csv` with v25.4.0-rc.1 binary and manually lower-cased headers. - In cluster-virtualization-metric-scopes.md, fixed version variable. - In cluster-virtualization-setting-scopes.md, (a) fixed version variable, (b) fixed link to cluster-virtualization-metric-scopes.md.
1 parent 0a51df4 commit a00f09d

File tree

5 files changed

+23
-15
lines changed

5 files changed

+23
-15
lines changed

src/current/_data/v25.4/cluster-settings.csv

Lines changed: 11 additions & 7 deletions
Original file line numberDiff line numberDiff line change
@@ -7,7 +7,6 @@ admission.epoch_lifo.queue_delay_threshold_to_switch_to_lifo,duration,105ms,"the
77
admission.kv.enabled,boolean,true,"when true, work performed by the KV layer is subject to admission control",system-only
88
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",application
99
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",application
10-
bulkio.backup.deprecated_full_backup_with_subdir.enabled,boolean,false,"when true, a backup command with a user specified subdirectory will create a full backup at the subdirectory if no backup already exists at that subdirectory",application
1110
bulkio.backup.file_size,byte size,128 MiB,target size for individual data files produced during BACKUP,application
1211
bulkio.backup.read_timeout,duration,5m0s,"amount of time after which a read attempt is considered timed out, which causes the backup to fail",application
1312
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,application
@@ -25,6 +24,7 @@ changefeed.kafka_v2_error_details.enabled,boolean,true,"if enabled, Kafka v2 sin
2524
changefeed.memory.per_changefeed_limit,byte size,512 MiB,controls amount of data that can be buffered per changefeed,application
2625
changefeed.resolved_timestamp.min_update_interval (alias: changefeed.min_highwater_advance),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,application
2726
changefeed.node_throttle_config,string,,specifies node level throttling configuration for all changefeeeds,application
27+
changefeed.progress.frontier_persistence.interval,duration,30s,minimum amount of time that must elapse before a changefeed will persist its entire span frontier again,application
2828
changefeed.protect_timestamp.max_age,duration,96h0m0s,fail the changefeed if the protected timestamp age exceeds this threshold; 0 disables expiration,application
2929
changefeed.protect_timestamp_interval,duration,10m0s,controls how often the changefeed forwards its protected timestamp to the resolved timestamp,application
3030
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,application
@@ -80,11 +80,11 @@ feature.infer_rbr_region_col_using_constraint.enabled,boolean,false,"set to true
8080
feature.restore.enabled,boolean,true,"set to true to enable restore, false to disable; default is true",application
8181
feature.schema_change.enabled,boolean,true,"set to true to enable schema changes, false to disable; default is true",application
8282
feature.stats.enabled,boolean,true,"set to true to enable CREATE STATISTICS/ANALYZE, false to disable; default is true",application
83-
feature.vector_index.enabled,boolean,false,"set to true to enable vector indexes, false to disable; default is false",application
83+
feature.vector_index.enabled,boolean,true,"set to true to enable vector indexes, false to disable; default is true",application
8484
jobs.retention_time,duration,336h0m0s,the amount of time for which records for completed jobs are retained,application
8585
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,system-only
8686
kv.allocator.load_based_lease_rebalancing.enabled,boolean,true,set to enable rebalancing of range leases based on load and latency,system-only
87-
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]",system-only
87+
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]",system-only
8888
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]",system-only
8989
kv.allocator.load_based_rebalancing_interval,duration,1m0s,the rough interval at which each store will check for load-based lease / replica rebalancing opportunities,system-only
9090
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,system-only
@@ -127,14 +127,13 @@ kv.transaction.max_intents_bytes,integer,4194304,maximum number of bytes used to
127127
kv.transaction.max_refresh_spans_bytes,integer,4194304,maximum number of bytes used to track refresh spans in serializable transactions,application
128128
kv.transaction.randomized_anchor_key.enabled,boolean,false,dictates whether a transactions anchor key is randomized or not,application
129129
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",application
130-
kv.transaction.write_buffering.enabled,boolean,false,"if enabled, transactional writes are buffered on the client",application
131-
kv.transaction.write_buffering.max_buffer_size,byte size,4.0 MiB,"if non-zero, defines that maximum size of the buffer that will be used to buffer transactional writes per-transaction",application
132130
kv.transaction.write_pipelining.locking_reads.enabled,boolean,true,"if enabled, transactional locking reads are pipelined through Raft consensus",application
133131
kv.transaction.write_pipelining.ranged_writes.enabled,boolean,true,"if enabled, transactional ranged writes are pipelined through Raft consensus",application
134132
kv.transaction.write_pipelining.enabled (alias: kv.transaction.write_pipelining_enabled),boolean,true,"if enabled, transactional writes are pipelined through Raft consensus",application
135133
kv.transaction.write_pipelining.max_batch_size (alias: kv.transaction.write_pipelining_max_batch_size),integer,128,"if non-zero, defines that maximum size batch that will be pipelined through Raft consensus",application
136134
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",system-only
137135
kvadmission.store.snapshot_ingest_bandwidth_control.enabled,boolean,true,"if set to true, snapshot ingests will be subject to disk write control in AC",system-only
136+
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",application
138137
obs.tablemetadata.automatic_updates.enabled,boolean,false,enables automatic updates of the table metadata cache system.table_metadata,application
139138
obs.tablemetadata.data_valid_duration,duration,20m0s,the duration for which the data in system.table_metadata is considered valid,application
140139
schedules.backup.gc_protection.enabled,boolean,true,enable chaining of GC protection across backups run as part of a schedule,application
@@ -211,6 +210,7 @@ sql.auth.change_own_password.enabled,boolean,false,"controls whether a user is a
211210
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,application
212211
sql.auth.grant_option_inheritance.enabled,boolean,true,determines whether the GRANT OPTION for privileges is inherited through role membership,application
213212
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,application
213+
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",application
214214
sql.closed_session_cache.capacity,integer,1000,the maximum number of sessions in the cache,application
215215
sql.closed_session_cache.time_to_live,integer,3600,"the maximum time to live, in seconds",application
216216
sql.contention.event_store.capacity,byte size,64 MiB,the in-memory storage capacity per-node of contention event store,application
@@ -356,6 +356,7 @@ sql.insights.execution_insights_capacity,integer,1000,the size of the per-node s
356356
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,application
357357
sql.insights.latency_threshold,duration,100ms,amount of time after which an executing statement is considered slow. Use 0 to disable.,application
358358
sql.log.redact_names.enabled,boolean,false,"if set, schema object identifers are redacted in SQL statements that appear in event logs",application
359+
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",application
359360
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.",application
360361
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.",application
361362
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",application
@@ -379,6 +380,7 @@ sql.multiple_modifications_of_table.enabled,boolean,false,"if true, allow statem
379380
sql.multiregion.drop_primary_region.enabled,boolean,true,allows dropping the PRIMARY REGION of a database if it is the last region,application
380381
sql.notices.enabled,boolean,true,enable notices in the server/client protocol being sent,application
381382
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",application
383+
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",application
382384
sql.schema.telemetry.recurrence,string,@weekly,cron-tab recurrence for SQL schema telemetry job,system-visible
383385
sql.spatial.experimental_box2d_comparison_operators.enabled,boolean,false,enables the use of certain experimental box2d comparison operators,application
384386
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.,application
@@ -425,6 +427,8 @@ sql.temp_object_cleaner.wait_interval,duration,30m0s,how long after creation a t
425427
sql.log.all_statements.enabled (alias: sql.trace.log_statement_execute),boolean,false,set to true to enable logging of all executed statements,application
426428
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,application
427429
sql.trace.txn.enable_threshold,duration,0s,"enables transaction traces for transactions exceeding this duration, used with `sql.trace.txn.sample_rate`",application
430+
sql.trace.txn.include_internal.enabled,boolean,true,enables tracing internal transactions as well as external workload using sample rate and threshold settings,application
431+
sql.trace.txn.jaeger_json_output.enabled,boolean,false,enables Jaeger JSON output for transaction traces in logs,application
428432
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.",application
429433
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)",application
430434
sql.ttl.default_delete_batch_size,integer,100,default amount of rows to delete in a single query during a TTL job,application
@@ -436,7 +440,6 @@ sql.txn.read_committed_isolation.enabled,boolean,true,set to true to allow trans
436440
sql.txn.repeatable_read_isolation.enabled (alias: sql.txn.snapshot_isolation.enabled),boolean,false,set to true to allow transactions to use the REPEATABLE READ isolation level if specified by BEGIN/SET commands,application
437441
sql.txn_fingerprint_id_cache.capacity,integer,100,the maximum number of txn fingerprint IDs stored,application
438442
sql.vecindex.stalled_op.timeout,duration,100ms,amount of time before other vector index workers will assist with a stalled background fixup,application
439-
storage.columnar_blocks.enabled,boolean,true,set to true to enable columnar-blocks to store KVs in a columnar format,system-visible
440443
storage.delete_compaction_excise.enabled,boolean,true,set to false to direct Pebble to not partially excise sstables in delete-only compactions,system-visible
441444
storage.ingest_split.enabled,boolean,true,set to false to disable ingest-time splitting that lowers write-amplification,system-only
442445
storage.ingestion.value_blocks.enabled,boolean,true,set to true to enable writing of value blocks in ingestion sstables,application
@@ -445,6 +448,7 @@ storage.max_sync_duration.fatal.enabled,boolean,true,"if true, fatal the process
445448
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]",system-visible
446449
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]",system-visible
447450
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]",system-visible
451+
storage.unhealthy_write_duration,duration,20s,"duration for disk write operations, beyond which the disk will be reported as unhealthy for higher layer actions",system-only
448452
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,system-only
449453
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",system-only
450454
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.,system-visible
@@ -457,4 +461,4 @@ trace.zipkin.collector,string,,"the address of a Zipkin instance to receive trac
457461
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,application
458462
ui.default_timezone,string,,the default timezone used to format timestamps in the ui,application
459463
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]",application
460-
version,version,25.3,set the active cluster version in the format '<major>.<minor>',application
464+
version,version,25.4,set the active cluster version in the format '<major>.<minor>',application

src/current/v25.3/cluster-virtualization-metric-scopes.md

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -27,7 +27,7 @@ STORAGE: Scoped to the system virtual cluster
2727
SERVER: n/a
2828
{% endcomment %}
2929

30-
{% assign version = site.current_cloud_version | replace: ".", "" %}
30+
{% assign version = page.version.version | replace: ".", "" %}
3131
{% comment %}version: {{ version }}{% endcomment %}
3232

3333
## Metrics scoped to a virtual cluster

src/current/v25.3/cluster-virtualization-setting-scopes.md

Lines changed: 5 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -18,7 +18,9 @@ When [cluster virtualization]({% link {{ page.version.version }}/cluster-virtual
1818
- When a cluster setting is system-visible, it can be set only from the system virtual cluster but can be queried from any virtual cluster. For example, a virtual cluster can query a system-visible cluster setting's value, such as `storage.max_sync_duration`, to help adapt to the CockroachDB cluster's configuration.
1919

2020
{% comment %}
21-
Src: `cockroach gen settings-list --show-class --format=csv > cluster-settings.csv` against cockroach-v25.3.0-rc.1.darwin-11.0-arm64;
21+
Src: `cockroach gen settings-list --show-class --format=csv > cluster-settings.csv` against cockroach-{version}.darwin-11.0-arm64;
22+
lower-case headers of cluster-settings.csv: setting,type,default,description,class
23+
copy cluster-settings.csv to _data/{version}/
2224

2325
Also saved in https://docs.google.com/spreadsheets/d/1HIalzAhwU0CEYzSuG2m1aXSJRpiIyQPJdt8SusHpJ_U/edit?usp=sharing
2426
(shared CRL-internal). Sort by the Class column, then Settings column, and paste into the correct section below.
@@ -28,7 +30,7 @@ system-only: Scoped to the system virtual cluster
2830
system-visible: Can be set / modified only from the system virtual cluster, but can be viewed from a VC
2931
{% endcomment %}
3032

31-
{% assign version = site.current_cloud_version | replace: ".", "" %}
33+
{% assign version = page.version.version | replace: ".", "" %}
3234
{% comment %}version: {{ version }}{% endcomment %}
3335

3436
## Cluster settings scoped to a virtual cluster
@@ -100,5 +102,5 @@ system-visible: Can be set / modified only from the system virtual cluster, but
100102
## See also
101103

102104
- [Cluster Virtualization Overview]({% link {{ page.version.version }}/cluster-virtualization-overview.md %})
103-
- [Cluster Metric Scopes with Cluster Virtualization Enabled]({% link {{ page.version.version }}/cluster-virtualization-setting-scopes.md %})
105+
- [Cluster Metric Scopes with Cluster Virtualization Enabled]({% link {{ page.version.version }}/cluster-virtualization-metric-scopes.md %})
104106
- [Physical Cluster Replication]({% link {{ page.version.version }}/physical-cluster-replication-overview.md %})

src/current/v25.4/cluster-virtualization-metric-scopes.md

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -27,7 +27,7 @@ STORAGE: Scoped to the system virtual cluster
2727
SERVER: n/a
2828
{% endcomment %}
2929

30-
{% assign version = site.current_cloud_version | replace: ".", "" %}
30+
{% assign version = page.version.version | replace: ".", "" %}
3131
{% comment %}version: {{ version }}{% endcomment %}
3232

3333
## Metrics scoped to a virtual cluster

0 commit comments

Comments
 (0)