package
23.2.20+incompatible
Repository: https://github.com/cockroachdb/cockroach.git
Documentation: pkg.go.dev

# Functions

AssertInitialized checks whether Initialize() has been called yet.
ByKey returns the roachpb.Version for a given key.
EncodingFromVersionStr is a shorthand to generate an encoded cluster version from a version string.
Initialize initializes the global cluster version.
ListBetween returns the list of cluster versions in the range (from, to].
MakeMetrics is a function that creates the metrics defined in the Metrics struct.
MakeVersionHandle returns a Handle that has its binary and minimum supported versions initialized to this binary's build and it's minimum supported versions respectively.
MakeVersionHandleWithOverride returns a Handle that has its binary and minimum supported versions initialized to the provided versions.
RegisterOnVersionChangeCallback is a callback function that updates the cluster.preserve-downgrade-option.last-updated when the cluster.preserve_downgrade_option settings is changed.

# Constants

No description provided by the author
Offset every version +1M major versions into the future if this is a dev branch.
KeyVersionSetting is the "version" settings key.
v22.2 versions.
Permanent_V23_1_CreateAutoConfigRunnerJob is the version where the auto config runner persistent job has been created.
Permanent_V23_1_CreateJobsMetricsPollingJob creates the permanent job responsible for polling the jobs table for metrics.
Permanent_V23_1ChangeSQLStatsTTL is the version where the gc TTL was updated to all SQL Stats tables.
Permanent_V23_1CreateSystemActivityUpdateJob is the version at which Cockroach adds a job that periodically updates the statement_activity and transaction_activity tables.
Permanent_V23_1KeyVisualizerTablesAndJobs adds the system tables that support the key visualizer.
Permanent_V23_2_MVCCStatisticsTable adds the system.mvcc_statistics table and update job.
V22_2 is CockroachDB v22.2.
V23_1 is CockroachDB v23.1.
V23_1_AlterSystemStatementStatisticsAddIndexesUsage creates indexes usage virtual column based on (statistics->>'indexes') with inverted index on table system.statement_statistics.
V23_1_ChangefeedExpressionProductionReady marks changefeed expressions (transformation) as production ready.
Version constants.
V23_1_KVDirectColumnarScans introduces the support of the "direct" columnar scans in the KV layer.
V23_1_MVCCRangeTombstonesUnconditionallyEnabled is a version gate after which Cockroach will always write MVCC Range Tombstones, regardless of the value of the storage.mvcc.range_tombstones.enabled cluster setting.
V23_1_SchemaChangerDeprecatedIndexPredicates is the version where the declarative schema changer no longer produces scpb.SecondaryIndexPartial elements.
V23_1_SystemRbrCleanup is used to gate an upgrade job that cleans up old keys that are not regional by row compatible.
V23_1_SystemRbrDualWrite indicates regional by row compatible system tables should write to the old and new indexes.
V23_1_SystemRbrReadNew indicates regional by row compatible system tables should read from the new index.
V23_1_SystemRbrReadNew indicates regional by row compatible system tables no longer need to write to the old index.
V23_1_TaskSystemTables is the version where the system tables task_payloads and tenant_tasks have been created.
V23_1_TenantIDSequence is the version where system.tenant_id_seq was introduced.
V23_1_UseDelRangeInGCJob enables the use of the DelRange operation in the GC job.
V23_1AddPartialStatisticsColumns adds two columns: one to store the predicate for a partial statistics collection, and another to refer to the full statistic it was collected from.
V23_1AddSQLStatsComputedIndexes is the version at which Cockroach adds new computed columns and indexes to the statement_statistics and transaction_statistics system tables.
V23_1AddSystemActivityTables is the version at which Cockroach adds system tables statement_activity and transaction_activity.
V23_1AddTypeColumnToJobsTable adds the nullable job_type column to the system.jobs table.
V23_1AllocatorCPUBalancing adds balancing CPU usage among stores using the allocator and store rebalancer.
V23_1AllowNewSystemPrivileges is the version at which we allow the new MODIFYSQLCLUSTERSETTING abd VIEWJOB system privileges to be used.
V23_1AlterSystemPrivilegesAddIndexOnPathAndUsername adds a covering secondary index to system.privileges, on the path and username columns.
V23_1AlterSystemSQLInstancesAddSqlAddr adds a sql_addr column to the system.sql_instances table.
V23_1BackfillTypeColumnInJobsTable backfills the job_type column in the system.jobs table.
V23_1_CreateSystemJobInfoTable creates the system.job_info table.
V23_1DatabaseRoleSettingsHasRoleIDColumn is the version where the role_id column has been added to the system.database_role_settings table.
V23_1DatabaseRoleSettingsRoleIDColumnBackfilled is the version where the role_id column in the system.database_role_settings table has been backfilled.
V23_1DeprecateClusterVersionKey is the version where we no longer write cluster version keys to engines.
V23_1DescIDSequenceForSystemTenant migrates the descriptor ID generator counter from a meta key to the system.descriptor_id_seq sequence for the system tenant.
V23_1EnableFlushableIngest upgrades the Pebble format major version to FormatFlushableIngest, which enables use of flushable ingestion.
V23_1EnablePebbleFormatSSTableValueBlocks is the second step of the two-part migration.
V23_1EnsurePebbleFormatSSTableValueBlocks upgrades the Pebble format major version to FormatSSTableValueBlocks, which supports writing sstables in a new format containing value blocks (sstable.TableFormatPebblev3).
V23_1ExternalConnectionsTableHasOwnerIDColumn is the version where the owner_id column has been added to the system.external_connections table.
V23_1ExternalConnectionsTableOwnerIDColumnBackfilled is the version where the owner_id column in the system.external_connections table has been backfilled.
V23_1JobInfoTableIsBackfilled is a version gate after which the system.job_info table has been backfilled with rows for the payload and progress of each job in the system.jobs table.
V23_1RoleMembersIDColumnsBackfilled is the version where the columns for ids in the role_members system table have been backfilled.
V23_1RoleMembersTableHasIDColumns is the version where the role_members system table has columns for ids.
V23_1ScheduledChangefeeds is the version where scheduled changefeeds are supported through `CREATE SCHEDULE FOR CHANGEFEED` statement.
V23_1SetPebbleCreatorID is a version gate after which we set the Creator ID on Pebble stores that have shared storage configured.
V23_1_Start demarcates the start of cluster versions stepped through during the process of upgrading from 22.2 to 23.1.
V23_1StopWritingPayloadAndProgressToSystemJobs is the version where the payload and progress columns are no longer written to system.jobs.
V23_1SystemPrivilegesTableHasUserIDColumn is the version where the user_id column has been added to the system.privileges table.
V23_1SystemPrivilegesTableUserIDColumnBackfilled is the version where the user_id column in the system.privileges table has been backfilled.
V23_1TenantCapabilities is the version where tenant capabilities can be set.
V23_1TenantNamesStateAndServiceMode adds columns to system.tenants.
V23_1WaitedForDelRangeInGCJob corresponds to the migration which waits for the GC jobs to adopt the use of DelRange with tombstones.
V23_1WebSessionsTableHasUserIDColumn is the version where the user_id column has been added to the system.web_sessions table.
V23_1WebSessionsTableUserIDColumnBackfilled is the version where the user_id column in the system.web_sessions table has been backfilled.
V23_2 is CockroachDB v23.2.
V23_2_AddSystemExecInsightsTable is the version at which Cockroach creates {statement|transaction}_execution_insights system tables.
V23_2_ChangefeedLaggingRangesOpts is used to version gate the changefeed options lagging_ranges_threshold and lagging_ranges_polling_interval.
V23_2_EnablePebbleFormatVirtualSSTables enables the Pebble FormatMajorVersion for virtual sstables.
V23_2_EnableRangeCoalescingForSystemTenant enables range coalescing for the system tenant.
V23_2_GrantExecuteToPublic is no longer used.
V23_2_PebbleFormatDeleteSizedAndObsolete upgrades Pebble's format major version to FormatDeleteSizedAndObsolete, allowing use of a new sstable format version Pebblev4.
V23_2_PebbleFormatVirtualSSTables upgrades Pebble's format major version to FormatVirtualSSTables, allowing use of virtual sstables in Pebble.
V23_2_RegionaLivenessTable guarantees the regional liveness table exists and its ready for use.
V23_2_RemoveLockTableWaiterTouchPush simplifies the push logic in lock_table_waiter by passing the wait policy of the pusher as part of the push request and leaving the push outcome to the server-side logic.
V23_2_StmtDiagForPlanGist enables statement diagnostic feature to collect the bundle for particular plan gist.
V23_2_UseACRaftEntryEntryEncodings gates the use of raft entry encodings that (optionally) embed below-raft admission data.
V23_2_UseSizedPebblePointTombstones enables the use of Pebble's new DeleteSized operations.
V23_2Start demarcates the start of cluster versions stepped through during the process of upgrading from previous supported releases to 23.2.
VCurrent_Start is an alias for last Start version key (i.e the first internal version of the release in development).
Version constants.
Version constants.
Version constants.
Version constants.
Version constants.
Version constants.
Version constants.

# Variables

AutoUpgradeEnabled is used to enable and disable automatic upgrade.
TODO(irfansharif): clusterversion.binary{,MinimumSupported}Version feels out of place.
DoctorBinaryVersion level used by the debug doctor when validating any files.
No description provided by the author
TestingBinaryMinSupportedVersion is a minimum supported version that tests can use when they don't want to go through a Settings object.
TestingBinaryVersion is a binary version that tests can use when they don't want to go through a Settings object.
TestingClusterVersion is a ClusterVersion that tests can use when they don't want to go through a Settings object.

# Structs

Metrics defines the settings tracked in prometheus.

# Interfaces

Handle is the interface through which callers access the active cluster version and this binary's version details.

# Type aliases

Key is a unique identifier for a version of CockroachDB.