On this page, you can read about changes and find downloads for all production and testing releases of CockroachDB v21.2.
- For key feature enhancements in v21.2 and other upgrade considerations, refer to the notes for v21.2.0.
- For details about release types, naming, and licensing, refer to the Releases page.
- Be sure to also review the Release Support Policy.
- After downloading a supported CockroachDB binary, learn how to install CockroachDB or upgrade your cluster.
Get future release notes emailed to you:
v21.2.17
Release Date: October 17, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.17
Changelog
View a detailed changelog on GitHub: v21.2.16...v21.2.17
Bug fixes
- Fixed a rare internal error that could occur during planning when a query predicate included values close to the maximum or minimum
int64
value. The error,estimated row count must be non-zero
, has now been fixed. #88955 - Fixed a longstanding bug that could cause the optimizer to produce an incorrect plan when aggregate functions
st_makeline
orst_extent
were called with invalid-type and empty inputs respectively. #88954 - Fixed a bug that caused high SQL tail latencies during background rebalancing in the cluster. #88738
- Fixed a bug where draining or drained nodes could re-acquire leases during an import or an index backfill. #88725
- Fixed a bug that caused incorrect evaluation of expressions in the form
col +/- const1 ? const2
, whereconst1
andconst2
are constant values and?
is any comparison operator. The bug was caused by operator overflow when the optimizer attempted to simplify these expressions to have a single constant value. #88971 - Fixed a bug that has existed since v2.1.0 where queries containing a subquery with
EXCEPT
could produce incorrect results. This could happen if the optimizer could guarantee that the left side of theEXCEPT
always returned more rows than the right side. In this case, the optimizer made a faulty assumption that theEXCEPT
subquery always returned at least one row, which could cause the optimizer to perform an invalid transformation, possibly causing the full query to return incorrect results. #89132 - CockroachDB will now flush the write-ahead log on consistency checker failures when writing storage checkpoints. #89401
- Fixed a bug that could cause incorrect results from the floor division operator,
//
, when the numerator is non-constant and the denominator is the constant1
. #89264 - Fixed a source of internal connectivity problems that would resolve after restarting the affected node. #89618
- Fixed errors that may occur in automatic statistics collection when the cluster setting
sql.stats.automatic_collection.min_stale_rows
is set to0
. #89706 - Fixed a bug that caused spurious failures when running a restore. #89019
Contributors
This release includes 17 merged PRs by 13 authors.
v21.2.16
Release Date: September 29, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.16
Changelog
View a detailed changelog on GitHub: v21.2.15...v21.2.16
SQL language changes
EXPLAIN ANALYZE
output now contains a warning when the estimated row count for scans is inaccurate. It includes a hint to collect the table statistics manually. #86873- Added a cluster setting
sql.metrics.statement_details.gateway_node.enabled
that controls if the gateway node ID should be persisted to thesystem.statement_statistics
table as is or as a0
, to decrease cardinality on the table. The node ID is still available on the statistics column. #88636
Command-line changes
- The
\c
metacommand in thecockroach sql
shell no longer shows the password in plaintext. #87550
Bug fixes
- Fixed a crash that could happen when formatting queries that have placeholder
BitArray
arguments. #86886 - Previously, queries with many joins and projections of multi-column expressions, e.g.,
col1 + col2
, either present in the query or within a virtual column definition, could experience very long optimization times or hangs, where the query is never sent for execution. This has now been fixed. #85872 - Fixed a bug that caused some special characters to be misread if
COPY ... FROM
into aTEXT[]
column was reading them. #86888 - Fixed a crash/panic that could occur if placeholder arguments were used with the
with_min_timestamp
orwith_max_staleness
functions. #86882 - Previously, escaping a double quote (
"
) withCOPY
inCSV
mode could ignore all subsequent lines in the sameCOPY
if anESCAPE
clause were specified. This is now resolved. #86976 - Previously, CockroachDB would return an internal error when evaluating the
json_build_object
built-in when an enum datum was passed as the first argument. This is now fixed. #86850 - Fixed a vulnerability in the optimizer that could cause a panic in rare cases when planning complex queries with
ORDER BY
. #86807 - An active replication report update could prevent a node from shutting down until it completed. The report update is now cancelled on node shutdown instead. #87923
- Fixed an issue where imports and rebalances were being slowed down due to the accumulation of empty directories from range snapshot applications. #88142
- Fixed a bug where CockroachDB could incorrectly not fetch rows with
NULL
values when reading from the unique secondary index when multiple column families were defined for the table, and the index didn't store some of theNOT NULL
columns. #88207 - Fixed a bug where if telemetry is enabled,
COPY
can sometimes cause the server to crash. #88326 - Fixed a bug that could cause nodes to crash in rare cases when executing apply joins in query plans. #88518
- Fixed a bug that caused errors in rare cases when executing queries with correlated
WITH
expressions. This bug was present since correlatedWITH
expressions were introduced in v21.2.0. #88518
Performance improvements
- Long-running SQL sessions are now less likely to maintain large allocations for long periods of time, which decreases the risk of OOM and improves memory utilization. #86798
- Made sending and receiving Raft queue sizes match. Previously the receiver could unnecessarily drop messages in situations when the sending queue is bigger than the receiving one. cockroachdb/cockroach#88447
Contributors
This release includes 37 merged PRs by 20 authors.
v21.2.15
Release Date: August 29, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.15
Changelog
View a detailed changelog on GitHub: v21.2.14...v21.2.15
Command-line changes
- The CLI now contains a flag (
--log-config-vars
) that allows for environment variables to be specified for expansion within the logging configuration file. This allows a single logging configuration file to service an array of sinks without further manipulation of the configuration file. #85172 cockroach debug zip
now includes all system tables by default, except for a few (a deny list). #86142
Bug fixes
- Fixed incorrect error handling that could cause casts to OID types to fail in some cases. #85125
- Fixed a bug introduced in v20.2 that could cause a panic when an expression contained a geospatial comparison like
~
that was negated. #84629 - Nodes no longer gossip information about table statistics once all nodes in the cluster are upgraded to v21.2. #85494
- Fixed an error that could occur when a query included a limited reverse scan and some rows needed to be retrieved by
GET
requests. #85583 - Fixed a bug where clients could sometimes receive errors due to lease acquisition timeouts of the form
operation "storage.pendingLeaseRequest: requesting lease" timed out after 6s
. #85429 - Fixed a bug that could cause union queries to return incorrect results in rare cases. #85653
- Fixed a bug that could cause a panic in rare cases when the unnest() function was used with a
tuple
return type. #85347 - Fixed an issue where the
NO_INDEX_JOIN
hint could be ignored by the optimizer in some cases, causing it to create a query plan with an index join. #86089 - Previously, an empty column in the input to
COPY ... FROM CSV
would be treated as an empty string. Now, this is treated asNULL
. The quoted empty string can still be used to input an empty string. Similarly, if a differentNULL
token is specified in the command options, it can be quoted in order to be treated as the equivalent string value. #86148
Contributors
This release includes 26 merged PRs by 17 authors.
v21.2.14
Release Date: August 1, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.14
Changelog
View a detailed changelog on GitHub: v21.2.13...v21.2.14
Security updates
- Added access control checks to three multi-region related built-in functions. #83987
SQL language changes
- The error code reported when trying to use a system or virtual column in the
STORING
clause of an index has been changed fromXXUUU (internal error)
to0A000 (feature not supported)
. #83649 - The error code reported when attempting to use a system column in an index as a key column has been changed from
XXUUU (internal error)
to0A000 (feature not supported)
. #83649 AS OF SYSTEM TIME
now takes the time zone into account when converting to UTC. For example:2022-01-01 08:00:00-04:00
is treated the same as2022-01-01 12:00:00
instead of2022-01-01 08:00:00
#84665- Added additional logging for
COPY
statements to theSQL_EXEC
channel if thesql.trace.log_statement_execute
cluster setting is set. #84679 - An error message is now logged to the
SQL_EXEC
channel when parsing fails. #84679
Operational changes
- The application name that is part of a SQL session is no longer considered
redactable
information #83558 - The
cockroach debug zip
andcockroach debug merge-logs
commands will now work with JSON formatted logs. #83147
DB Console changes
- Updated the message when there is no data on the selected time interval on the Statements and Transactions pages. #84624
Bug fixes
- Fixed a bug in transaction lifetime management where a lock could be held for a long period of time when adding a new column to a table (or altering a column type). This contention could make the Jobs page non-responsive and job adoption slow. #83475
- Fixed a bug that prevented partial indexes from being used in some query plans. For example, a partial index with a predicate
WHERE a IS NOT NULL
was not previously used ifa
was aNOT NULL
column. #83240 - CockroachDB now treats
node unavailable
errors as retry-able changefeed errors. #82876 - CockroachDB now ensures running changefeeds do not inhibit node shutdown. #82876
- Index joins now consider functional dependencies from their input when determining equivalent columns instead of returning an internal error. #83550
- Fixed a bug where using
ADD COLUMN
orDROP COLUMN
with the legacy schema changer could fail on tables with large rows due to exceeding the Raft command max size. #83817 - Fixed a bug that may have caused a panic if a Kafka server being written to by a changefeed failed at the wrong moment. #83922
- The
cockroach debug merge-logs
command no longer returns an error when the log decoder attempts to parse older logs. #83748 - A flush message sent during portal execution in the
pgwire
extended protocol no longer results in an error. #83954 - Previously, virtual computed columns which were marked as
NOT NULL
could be added to new secondary indexes. Now, attempts to add such columns to a secondary index will result in an error. Note that such invalid columns can still be added to tables. Work to resolve that bug is tracked in #81675. #83552 - Fixed a rare issue where the failure to apply a Pebble manifest change (typically due to block device failure or unavailability) could result in an incorrect LSM state. Such a state would likely result in a panic soon after the failed application. This change alters the behavior of Pebble to panic immediately in the case of a failure to apply a change to the manifest. #83734
- Moved connection OK log and metric to the same location after authentication completes for consistency. This resolves an inconsistency (see linked issue) in the DB Console where the log and metric did not match. #84175
- Previously, CockroachDB would not normalize
timestamp/timestamptz - timestamp/timestamptz
like PostgreSQL does in some cases (depending on the query). This is now fixed. #84002 - Fixed an internal error
node ... with MaxCost added to the memo
that could occur during planning when calculating the cardinality of an outer join when one of the inputs had 0 rows. #84381 - Fixed a bug in transaction conflict resolution which could allow backups to wait on long-running transactions. #83905
- Fixed a "fake" memory accounting leak that in rare cases could result in
memory budget exceeded
errors even if the actual RAM usage is within--max-sql-memory
limit. #84325 - Fixed the following built-in functions so that users can only run them if they have
SELECT
privileges on the relevant tables:crdb_internal.revalidate_unique_constraints_in_all_tables
,crdb_internal.revalidate_unique_constraints_in_table
, andcrdb_internal.revalidate_unique_constraint
. #84272 - Fixed a bug that could cause existing secondary indexes to be unexpectedly dropped after running an
ALTER PRIMARY KEY
statement, if the new primary key column set is a subset of the old primary key column set. #84578 - Fixed a bug that was introduced in release 21.2.0 that could cause increased memory usage when scanning a table with wide rows. #84921
Contributors
This release includes 41 merged PRs by 26 authors.
v21.2.13
Release Date: July 5, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.13
Changelog
View a detailed changelog on GitHub: v21.2.12...v21.2.13
SQL language changes
- Fixed a small typo when using DateStyle and IntervalStyle. #81547
- Implemented the
COPY FROM ... ESCAPE ...
syntax. #82636 - Fixed an issue where
SHOW BACKUP with privileges
output grant statements with incorrect syntax (specifically, without the object type). For example, previouslySHOW BACKUP with privileges
output:GRANT ALL ON status TO j4;
Now it correctly outputs:GRANT ALL ON TYPE status TO j4;
. #82831 - The log fields for captured index usage statistics are no longer redacted. #83294
Bug fixes
- Raft snapshots no longer risk starvation under very high concurrency. Before this fix, it was possible that many of Raft snapshots could be starved and prevented from succeeding due to timeouts, which were accompanied by errors like
error rate limiting bulk io write: context deadline exceeded
. #81335 ST_MinimumBoundingCircle
no longer panics withNaN
coordinates. #81461- Fixed an issue where the
encryptionStatus
field on the Stores debug page of the DB Console would display an error instead of displaying encryption details when encryption-at-rest is enabled. #81525 - Fixed a panic that was caused by setting the
tracing
session variable usingSET LOCAL
orALTER ROLE ... SET
.#81507 - Previously, cancelling
COPY
commands would show anXXUUU
error, instead of57014
. This is now fixed. #81604 - Fixed a bug that caused errors with the message
unable to vectorize execution plan: unhandled expression type
in rare cases. This bug had been present since v21.2.0. #81589 - Fixed a bug where changefeeds could fail permanently if encountering an error while planning their distribution, even though such errors are usually transient. #81691
- Fixed a gap in disk-stall detection. Previously, disk stalls during filesystem metadata operations could go undetected, inducing deadlocks. Now stalls during these types of operations will correctly kill the process. #81769
- Fixed an issue where CockroachDB would encounter an internal error when executing queries with
lead
orlag
window functions when the default argument had a different type than the first argument. #81758 - Fixed a bug where queries from a table with a
CHECK
constraint could error out if the query hadORDER BY
andLIMIT
clauses. #81957 - Fixed a nil pointer exception during the cleanup of a failed or cancelled
RESTORE
job. #79032 - The Statements and Transactions pages no longer crash when a search term includes
*
. #82084 - The special characters
*
and^
are no longer highlighted when searching on the Statements and Transactions pages. #82084 - Previously, if materialized view creation failed during the backfill stage, CockroachDB would properly clean up the view but not any of the back references. Back and forward references for materialized views are now cleaned up. #82100
- Fixed a bug introduced in v21.2 where the
sql-stats-compaction
job had a chance of not being scheduled during an upgrade from v21.1 to v21.2, causing persisted statement and transaction statistics to be enabled without memory accounting. #82282 - The
--user
argument is no longer ignored when usingcockroach sql
in--insecure
mode. #82300 - The
SHOW STATISTICS
output no longer displays statistics involving dropped columns. #82318 - Fixed the
identity_generation
column in theinformation_schema.columns
table so its value is eitherBY DEFAULT
,ALWAYS
, orNULL
.#82183 - Disk write probes during node liveness heartbeats will no longer get stuck on stalled disks, instead returning an error once the operation times out. Additionally, disk probes now run in parallel on nodes with multiple stores. #81514
- Fixed a bug where an unresponsive node (e.g., a node with a stalled disk) could prevent other nodes from acquiring its leases, effectively stalling these ranges until the node was shut down or recovered. #81816
- Previously, when adding a column to a pre-existing table and adding a partial index referencing that column in the transaction, DML operations against the table while the schema change was ongoing would fail. Now these hazardous schema changes are not allowed. #82670
- In v21.1, a bug was introduced whereby default values were recomputed when populating data in new secondary indexes for columns which were added in the same transaction as the index. This would arise, for example, in cases like
ALTER TABLE t ADD COLUMN f FLOAT8 UNIQUE DEFAULT (random())
. If the default expression was not volatile, then the recomputation was harmless. If, however, the default expression was volatile, the data in the secondary index would not match the data in the primary index: a corrupt index would have been created. This bug has now been fixed. #83223 - Previously, a user could be connected to a database but unable to see the metadata for that database in
pg_catalog
if the user did not have privileges for the database. Now, users can always see thepg_catalog
metadata for a database they are connected to. #83359 - Fixed a bug where it was possible to have a virtual computed column with an active
NOT NULL
constraint despite having rows in the table for which the column wasNULL
. #83355 - Fixed an issue with the
soundex
function where certain unicode inputs could result in crashes, errors, or incorrect outputs. #83434 - Fixed a bug where it was possible to accrue MVCC garbage for much longer than needed. #82969
Contributors
This release includes 56 merged PRs by 29 authors.
v21.2.12
Release Date: June 6, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.12
Changelog
View a detailed changelog on GitHub: v21.2.11...v21.2.12
Miscellaneous
- Fixed an internal logging bug that affected the stability of the server. #4f97a101e
Contributors
This release includes 2 commits by 2 authors.
v21.2.11
Release Date: May 23, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.11
Changelog
View a detailed changelog on GitHub: v21.2.10...v21.2.11
Enterprise edition changes
- Fixed a bug where backups in the base directory of a Google Storage bucket would not be discovered by
SHOW BACKUPS
. These backups will now appear correctly. #80510
SQL language changes
- When using Azure Cloud Storage for data operations, CockroachDB now calculates the Storage Account URL from the provided
AZURE_ENVIRONMENT
query parameter. This defaults toAzurePublicCloud
if not specified to maintain backwards compatibility. This parameter should not be used when the cluster is in a mixed version or upgrading state, as nodes that have not been upgraded will continue to send requests to theAzurePublicCloud
even in the presence of this parameter. #80800 - Added a new session variable,
enable_multiple_modifications_of_table
, which can be used instead of the cluster variablesql.multiple_modifications_of_table.enabled
to allow statements containing multipleINSERT ON CONFLICT
,UPSERT
,UPDATE
, orDELETE
subqueries to modify the same table. The underlying issue #70731 is not fixed: table corruption remains possible if the same row is modified multiple times by different subqueries of a single statement, regardless of the value of the newenable_multiple_modifications_of_table
session variable or the existingsql.multiple_modifications_of_table.enabled
cluster variable. Cockroach Labs recommends rewriting these statements, but the session variable is provided as an aid if this is not possible. #81016
DB Console changes
- Added an alert banner on the Overview list page to warn users when staggered node versions are detected in a cluster. #80742
Bug fixes
- Fixed a rare crash which can occur when restarting a node after dropping tables. #80571
- Fixed a bug where in very rare circumstances CockroachDB could incorrectly evaluate queries with
ORDER BY
clauses when the prefix of ordering was already provided by the index ordering of the scanned table. #80731 - The list of recently decommissioned nodes and the historical list of decommissioned nodes now correctly displays decommissioned nodes. #80747
- Fixed a goroutine leak when internal rangefeed clients received certain kinds of retryable errors. #80797
- Fixed a bug in which some prepared statements could result in incorrect results when executed. This could occur when the prepared statement included an equality comparison between an index column and a placeholder, and the placeholder was cast to a type that was different from the column type. For example, if column a was of type
DECIMAL
, the following prepared query could produce incorrect results when executed:SELECT * FROM t_dec WHERE a = $1::INT8;
#81364
Contributors
This release includes 22 merged PRs by 20 authors. We would like to thank the following contributors from the CockroachDB community:
- Nathan Lowe (first-time contributor)
v21.2.10
Release Date: May 2, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.10
Changelog
View a detailed changelog on GitHub: v21.2.9...v21.2.10
Security updates
- The
crdb_internal.reset_sql_stats()
andcrdb_internal.reset_index_usage_stats()
built-in functions now check if user has the admin role. #80277
Enterprise edition changes
- Added a
changefeed.backfill.scan_request_size
cluster setting to control scan request size during backfill. #79709
SQL language changes
- A
pgerror
with code22P02
is now returned when an invalid cast toOID
is made. #79849 - An incremental backup now fails if the
AS OF SYSTEM TIME
is less than the previous backup's end time. #80287
DB Console changes
- Filtering by column is added to Hot Ranges page. #79645
- Added dropdown filter on the Node Diagnostics page to view by active, decommissioned, or all nodes. #80336
Bug fixes
- The execution time as reported on
DISTSQL
diagrams within the statement bundle collected viaEXPLAIN ANALYZE (DEBUG)
is no longer negative when the statement encountered an error. #79369 - An internal error when the inner expression of a column access expression evaluated to
NULL
no longer occurs. For example, evaluation of the expression(CASE WHEN b THEN ((ROW(1) AS a)) ELSE NULL END).a
would error whenb
isfalse
. #79528 - An error when accessing a named column of a labelled tuple no longer occurs. The error occurred when an expression could produce one of several different tuples. For example,
(CASE WHEN true THEN (ROW(1) AS a) ELSE (ROW(2) AS a) END).a
would fail to evaluate. #79528 - Pebble compaction heuristics no longer allow a large compaction backlog to accumulate, eventually triggering high read amplification. #79611
- HTTP 304 responses no longer result in error logs. #79860
- A custom time series metric
sql.distsql.queries.spilled
is no longer computed incorrectly leading to an exaggerated number. #79881 nextval
andsetval
are non-transactional except when they is called in the same transaction that the sequence was created in. Creating a sequence and callingnextval
orsetval
on it within a transaction no longer causes the query containingnextval
to hang. #79866- The SQL Activity page no longer returns a "descriptor not found" error in a v21.1-v21.2 mixed version state. #79795
- Resetting SQL statistics in v21.1-v21.2 mixed version state no longer causes a "descriptor not found" error. #79795
- In a v21.1-v21.2 mixed version state CockroachDB no longer attempts to flush statistics to disk. It also does not log a "descriptor not found" error messages. #79795
- Added a detailed error message for index out of bounds when decoding a binary tuple datum. #79963
- CockroachDB no longer encounters an internal error when evaluating queries with
OFFSET
andLIMIT
clauses when the addition of theoffset
and thelimit
value would be larger thanint64
range. #79924 - Automatic encryption-at-rest data key rotation is no longer disabled after a node restart without a store key rotation. #80170
- When using
ST_Intersects
,ST_Within
, orST_Covers
spatial functions,NaN
coordinates no longer returntrue
for point in polygon operations. #80201 ST_MinimumBoundingCircle
no longer panics with infinite coordinates and anum_segs
argument. #80346- The formatting/printing behavior for
ALTER DEFAULT PRIVILEGES
was fixed, which corrects some mistaken error messages. #80326 - Bulk data sent to the KV storage layer is now sent at reduced admission control priority. #80387
Performance improvements
- Rollback of
CREATE TABLE AS
with large quantities of data now has similar performance toDROP TABLE
. #79603
Contributors
This release includes 38 merged PRs by 26 authors.
v21.2.9
Release Date: April 13, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.9
Changelog
View a detailed changelog on GitHub: v21.2.8...v21.2.9
SQL language changes
SHOW BACKUP
now reports accurate row and byte size counts on backups created by a tenant. #79347EXPLAIN ANALYZE
now reports memory and disk usage for lookup joins. #79353
Operational changes
DB Console changes
- Minor styling changes on the DB Console's Hot Ranges page to follow the same style as other pages. #79498
Bug fixes
- Fixed
num_runs
being incremented twice for certain jobs upon being started. #79051 - Index usage stats are now properly captured for index joins. #79240
ALTER TABLE ADD COLUMN
andALTER TABLE DROP COLUMN
are now both subject to admission control, which will prevent these operations from overloading the storage engine. #79211- Fixed a performance regression released in v21.1.7 that reverted
BACKUP
to its pre-v21.2.5 memory usage and runtime during planning of larger backups with many prior incremental layers. #79267 - Fixed a bug where
SHOW SCHEMAS FROM <schema>
would not include user-defined schemas. #79307 - Previously,
IMPORT INTO
could create duplicate entries forUNIQUE
constraints inREGIONAL BY ROW
tables and tables utilizingUNIQUE WITHOUT INDEX
constraints. This fix introduces a new validation step after theIMPORT INTO
for those tables, which will cause theIMPORT INTO
to fail and be rolled back in such cases. #79326 - Fixed a bug in I/O admission control that could result in admission control failing to rate-limit when traffic was stalled such that no work was admitted, despite the store's being in an unhealthy state. #79342
- Previously, CockroachDB could run into
memory budget exceeded
errors when performing lookup joins under certain memory conditions. This fix causes such operations to now more reliably spill to disk, which should reduce these errors for larger joins. #79353 BACKUP
read requests are now sent with lower admission control priority than normal traffic.#79367- Previously,
LIMIT
queries with anORDER BY
clause which scan the index of virtual system tables, such aspg_type
, could return incorrect results. This is corrected by teaching the optimizer thatLIMIT
operations cannot be pushed into ordered scans of virtual indexes. #79464 - Fixed a bug that caused the optimizer to generate query plans with logically incorrect lookup joins. The bug, present since v21.2.0, can only occur in queries with an inner join, e.g.,
t1 JOIN t2
, if all of the following are true:- The join contains an equality condition between columns of both tables, e.g.,
t1.a = t2.a
. - A query filter or
CHECK
constraint constrains a column to a set of specific values, e.g.,t2.b IN (1, 2, 3)
. In the case of aCHECK
constraint, the column must beNOT NULL
. - A query filter or
CHECK
constraint constrains a column to a range, e.g.,t2.c > 0
. In the case of aCHECK
constraint, the column must beNOT NULL
. - An index contains a column from each of the criteria above, e.g.,
INDEX t2(a, b, c)
. #79505
- The join contains an equality condition between columns of both tables, e.g.,
- Fixed a bug that caused the optimizer to generate invalid query plans that could result in incorrect query results. The bug, present since version v21.1.0, can appear if all of the following conditions are true:
- The query contains a semi-join, e.g., with the format
SELECT * FROM a WHERE EXISTS (SELECT * FROM b WHERE a.a @> b.b)
. - The inner table has a multi-column inverted index containing the inverted column in the filter.
- The index prefix columns are constrained to a set of values via the filter or a
CHECK
constraint, e.g., with anIN
operator. In the case of aCHECK
constraint, the column isNOT NULL
. #79505
- The query contains a semi-join, e.g., with the format
- Fixed a bug preventing DB Console from properly loading static assets, causing the interface to appear blank. #79662
Performance improvements
- The DB Console no longer downloads unused JS files on load. #78668
- The DB Console now supports caching of files in the web browser. #79394
Contributors
This release includes 31 merged PRs by 19 authors.
v21.2.8
Release Date: April 4, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.8
Changelog
View a detailed changelog on GitHub: v21.2.7...v21.2.8
Security updates
- Users can enable HSTS headers to be set on all HTTP requests, which force browsers to upgrade to HTTPS without a redirect. This is controlled by setting the
server.hsts.enabled
cluster setting, which isfalse
by default, totrue
. #77845 - Added a new flag
--external-io-enable-non-admin-implicit-access
that can remove the admin-only restriction on interacting with arbitrary network endpoints and using implicit authentication in operations such asBACKUP
,IMPORT
, orEXPORT
. #78599
Enterprise edition changes
- Changefeeds running on tables with a low value for the
gc.ttlseconds
cluster setting will function more reliably due to protected timestamps being maintained for the changefeed targets at the resolved timestamp of the changefeed. The frequency at which the protected timestamp is updated to the resolved timestamp can be configured through thechangefeed.protect_timestamp_interval
cluster setting. If the changefeed lags too far behind such that storage of old data becomes an issue, cancelling the changefeed will release the protected timestamps and allow garbage collection to resume. Ifprotect_data_from_gc_on_pause
is unset, pausing the changefeed will release the existing protected timestamp record. #77589 - Added the
changefeed.backfill_pending_ranges
prometheus metric to track the ongoing backfill progress of a changefeed. #77383 - Changefeeds now record message size histograms. #77932
- The number of concurrent catchup scan requests issued by a rangefeed client is now limited. #77932
- Removed the expensive and unnecessary
schedules.round.schedules-ready-to-run
andschedules.round.num-jobs-running
metrics from job schedulers. #78583
SQL language changes
- Added a
sql.auth.resolve_membership_single_scan.enabled
cluster setting, which changes the query for an internal role membership cache. Previously the code would recursively look up each role in the membership hierarchy, leading to multiple queries. With the setting on, it uses a single query. This setting isfalse
by default. #77631 - When users run
SHOW BACKUP
on an encrypted incremental backup, they must now set theencyrption_info_dir
directory to the full backup directory in order forSHOW BACKUP
to work. #78141 - The stats compaction scheduled job no longer causes intent buildup. #78583
- Implemented a scheduled logger used to capture index usage statistics to the telemetry logging channel. #78522
Operational changes
- The setting
kv.bulk_io_write.min_capacity_remaining_fraction
can now be set to cause bulk ingest operations likeIMPORT
,RESTORE
, orCREATE INDEX
to fail rather than write to a node that is running out of disk space. #78575 - Improved jobs system resilience to scheduled jobs that may lock up the scheduled jobs table for long periods of time. Each schedule now has a limited amount of time to complete its execution. The timeout is controlled via the
jobs.scheduler.schedule_execution.timeout
cluster setting. #77620
Command-line changes
- The
cockroach debug tsdump
command now allows viewing timeseries data even in cases of node failure by allowing users to rerun the command with the import filename set to"-"
. #77976 - Fixed a bug where running
cockroach demo
with the--global
flag would not simulate latencies correctly when combined with the--insecure
flag. #78170
DB Console changes
- Added a Hot Ranges page and linked to it in the sidebar. #77594
- The
_status/nodes
endpoint is now available to all users with theVIEWACTIVITY
role option, not justadmin
users. In the DB Console, the Nodes Overview and Node Reports pages will now display unredacted information containing node hostnames and IP addresses for all users with theVIEWACTIVITY
role option. #78275 - Fixed a bug where a node in the
UNAVAILABLE
state would not have latency defined and caused the network page to crash. #78627
Bug fixes
- Fixed a bug that caused errors when attempting to create table statistics (with
CREATE STATISTICS
orANALYZE
) for a table containing an index that indexed only virtualcomputed columns
. This bug has been present since v21.1.0. #77565 - Fixed a bug when adding a
hash-sharded index
to a table watched by a changefeed. #77739 - Fixed successive schema change backfills from skipping spans that were checkpointed by an initial backfill that was restarted. #77829
- Attempting to run concurrent profiles now works up to a concurrency limit of two. This will remove the occurrence of
profile id not found
errors while running up to two profiles concurrently. When a profile is not found, the error message has been updated to suggest troubleshooting steps. #77977 - Fixed an optimizer bug that prevented expressions of the form
(NULL::STRING[] <@ ARRAY['x'])
from being folded toNULL
. This bug was introduced in v21.2.0. #78039 - Added a limit of seven concurrent asynchronous consistency checks per store, with an upper timeout of one hour. This prevents abandoned consistency checks from building up in some circumstances, which could lead to increasing disk usage as they held onto Pebble snapshots. #77611
- Fixed a bug where the Statement Details page fails to load query plan even after when the plan has been sampled. #78105
- Fixed a memory leak in the Pebble block cache. #78257
- Fixed a bug that caused internal errors when
COALESCE
andIF
expressions had inner expressions with different types that could not be cast to a common type. #78342 - CockroachDB might now fetch fewer rows when performing lookup and index joins on queries with the
LIMIT
clause. #78474 - A zone config change event now includes the correct details of what was changed instead of incorrectly displaying
undefined
. #78634 - Fixed a bug that prevented a table created on a 22.1 node to be queried on a 21.2 node in a mixed-version cluster. #78657
- Fixed a bug that caused errors when trying to evaluate queries with
NULL
values annotated as a tuple type, such asNULL:::RECORD
. This bug was present since v19.1. #78635 - Fixed a bug where CockroachDB could lose
INT2VECTOR
andOIDVECTOR
types of some arrays. #78630 - Fixed a bug that caused the optimizer to generate invalid query plans which could result in incorrect query results. The bug, which has been present since v21.1.0, can appear if all of the following conditions are true: 1) the query contains a semi-join, such as queries in the form:
SELECT * FROM t1 WHERE EXISTS (SELECT * FROM t2 WHERE t1.a = t2.a);
, 2) the inner table has an index containing the equality column, liket2.a
in the example query, 3) the index contains one or more columns that prefix the equality column, and 4) the prefix columns areNOT NULL
and are constrained to a set of constant values via aCHECK
constraint or anIN
condition in the filter. #78975 - Fixed a bug where
IMPORT INTO
could create duplicate entries violatingUNIQUE
constraints inREGIONAL BY ROW
tables and tables utilizingUNIQUE WITHOUT INDEX
constraints. A new post-IMPORT
validation step for those tables now fails and rolls back theIMPORT
in such cases. #78975
Contributors
This release includes 54 merged PRs by 33 authors.
v21.2.7
Release Date: March 14, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.7
Changelog
View a detailed changelog on GitHub: v21.2.6...v21.2.7
Security updates
- When the
sql.telemetry.query_sampling.enabled
cluster setting is enabled, SQL names and client IP addresses are no longer redacted in telemetry logs. #77072
Enterprise edition changes
- Currently executing schedules are cancelled immediately when the jobs scheduler is disabled. #77313
SQL language changes
- When dropping a user that has default privileges, the error message now includes which database and schema the default privileges are defined in. Additionally, a hint is now given to show exactly how to remove the default privileges. #77142
- Fixed a bug where
crdb_internal.default_privileges
would incorrectly show default privileges for databases where the default privilege was not actually defined. #77304
Operational changes
- Operators who wish to access HTTP endpoints of a cluster through a proxy can now request specific node IDs through a
remote_node_id
query parameter or cookie with the value set to the node IDs they would like to proxy the connection to. #76694 - Added the cluster setting
bulkio.backup.resolve_destination_in_job.enabled
, which can be used to delay resolution of a backup's destination until the job starts running. #76816
DB Console changes
- Open SQL Transactions and Active SQL Transactions are now downsampled using
MAX
instead ofAVG
and will more accurately reflect narrow spikes in transaction counts when looking at downsampled data. #76688 - DB Console requests can be routed to arbitrary nodes in the cluster. Users can select a node from a dropdown in the Advanced Debug page of the DB Console UI to route their UI to that node. Manually initiated requests can either add a
remote_node_id
query param to their request or set aremote_node_id
HTTP cookie in order to manage the routing of their request. #76694 - Add long loading messages to SQL Activity pages. #77008
- Removed stray parenthesis at the end of the duration time for a succeeded job. It had been accidentally introduced to unreleased master and a 21.2 backport. Release justification: Category 2, UI bug fix #77444
Bug fixes
- Fixed a bug which caused the optimizer to omit join filters in rare cases when reordering joins, which could result in incorrect query results. This bug was present since v20.2. #76619
- Fixed a bug where certain
crdb_internal
tables could return incorrect information due to cached table descriptor information. #76520 - Fixed a bug where CockroachDB could incorrectly not return a row from a table with multiple column families when that row contains a
NULL
value when a composite type (FLOAT
,DECIMAL
,COLLATED STRING
, or an array of these types) is included in thePRIMARY KEY
. #76636 - Fixed a bug where a
RESTORE
job could hang if it encountered an error when ingesting restored data. #76509 - Fixed a race condition that in rare circumstances could cause a node to panic with
unexpected Stopped processor
during shutdown. #76827 - There is now a 1 hour timeout when sending Raft snapshots, to avoid stalled snapshot transfers preventing Raft log truncation and growing the Raft log very large. This is configurable via the
COCKROACH_RAFT_SEND_SNAPSHOT_TIMEOUT
environment variable. #76829 - Fixed an error that could sometimes occur when sorting the output of the
SHOW CREATE ALL TABLES
statement. #76698 - Fixed a bug where
CASE
expressions with branches that result in types that cannot be cast to a common type caused internal errors. They now result in a user-facing error. #76616 - Error messages produced during import are now truncated. Previously,
IMPORT
could potentially generate large error messages that could not be persisted to the jobs table, resulting in a failed import never entering the failed state and instead retrying repeatedly. #76980 - Fixed a bug that could corrupt indexes containing virtual columns or expressions. The bug only occurred when the index's table had a foreign key reference to another table with an
ON DELETE CASCADE
action, and a row was deleted in the referenced table. This bug was present since virtual columns were added in version v21.1.0. #77053 - Changefeeds retry instead of fail on RPC send failure. #77069
- Fixed a bug that caused the Open Transactions chart on the Metrics page to constantly increase for empty transactions. #77236
- Fixed a bug that could interfere with a system table migration. #77309
- The content type header for the HTTP log sink is now set to
application/json
if the format of the log output isJSON
. #77341 - Fixed a bug where draining nodes in a cluster without shutting them down could stall foreground traffic in the cluster. #77490
Performance improvements
- Fixed a bug in the histogram estimation code that could cause the optimizer to think a scan of a multi-column index would produce 0 rows, when in fact it would produce many rows. This could cause the optimizer to choose a suboptimal plan. It is now less likely for the optimizer to choose a suboptimal plan when multiple multi-column indexes are available. #76555
- The accuracy of histogram calculations for
BYTES
types has been improved. As a result, the optimizer should generate more efficient query plans in some cases. #76796
Contributors
This release includes 34 merged PRs by 24 authors.
v21.2.6
Release date: February 22, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.6
Changelog
View a detailed changelog on GitHub: v21.2.5...v21.2.6
Enterprise edition changes
- Kafka sink supports larger messages, up to 2GB in size. #76321
SQL language changes
- Added new built-in functions called
crdb_internal.revalidate_unique_constraint
,crdb_internal.revalidate_unique_constraints_in_table
, andcrdb_internal.revalidate_unique_constraints_in_all_tables
, which can be used to revalidate existing unique constraints. The different variations support validation of a single constraint, validation of all unique constraints in a table, and validation of all unique constraints in all tables in the current database, respectively. If any constraint fails validation, the functions will return an error with a hint about which data caused the constraint violation. These violations can then be resolved manually by updating or deleting the rows in violation. This will be useful to users who think they may have been affected by #73024. #75858 - S3 URIs used in
BACKUP
,EXPORT
, orCREATE CHANGEFEED
statements can now include the query parameterS3_STORAGE_CLASS
to configure the storage class used when that job creates objects in the designated S3 bucket. #75608 - Non-admin users can now use the
SHOW RANGES
statement if theZONECONFIG
privilege is granted. #76071 ST_MakePolygon
is now disallowed from making empty polygons from empty linestrings. This is not allowed in PostGIS. #76255
Bug fixes
- Fixed a bug where ownership information for sequence descriptors and column descriptors was incorrect. To elaborate, a sequence is created when a column is defined as the
SERIAL
type and theserial_normalization
session variable is set tosql_sequence
. In this case, the sequence is owned by the column and the table where the column exists. The sequence should be dropped when the owner table/column is dropped, which is the PostgreSQL behavior. The bug caused CockroachDB never to set ownership information correctly, only the dependency relationship, which caused the sequence to stay even though the owner table/column did not exist anymore. This is now fixed. #75704 - Fixed a bug that could cause nodes to crash when truncating abnormally large Raft logs. #75979
- The DB Console Databases page now shows stable, consistent values for database sizes. #76324
Performance improvements
- Sorting data with bytes-like types (
BYTES
,STRING
,JSON
/JSONB
,UUID
) when theLIMIT
clause is specified has now become more predictable. #75847
Contributors
This release includes 25 merged PRs by 21 authors.
v21.2.5
Release date: February 7, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.5
Changelog
View a detailed changelog on GitHub: v21.2.4...v21.2.5
Enterprise edition changes
- Redacted more potentially-sensitive URI elements from changefeed job descriptions. This is a breaking change for workflows involving copying URIs. As an alternative, the unredacted URI may be accessed from the jobs table directly. #75187
SQL language changes
- New role
VIEWACTIVITYREDACTED
that works similar asVIEWACTIVITY
but restricts the usage of the statements diagnostics bundle. It is possible for a user to have both roles (VIEWACTIVITY
andVIEWACTIVITYREDACTED
), but the roleVIEWACTIVITYREDACTED
takes precedent on restrictions. #74862 - New role
NOSQLLOGIN
(and its inverseSQLLOGIN
), which restricts SQL CLI login ability for a user while retaining their ability to log in to the DB Console (as opposed toNOLOGIN
which restricts both SQL and DB Console). Without any role options all login behavior remains permitted as it does today. OIDC logins to the DB Console continue to be permitted withNOSQLLOGIN
set. #75185 - The default SQL stats flush interval is now 10 minutes. #75524
Operational changes
- The meaning of
sql.distsql.max_running_flows
cluster setting has been extended so that when the value is negative, it would be multiplied by the number of CPUs on the node to get the maximum number of concurrent remote flows on the node. The default value is -128, meaning that on a 4 CPU machine we will have up to 512 concurrent remote DistSQL flows, but on a 8 CPU machine up to 1024. The previous default was 500. #75509
Command-line changes
- Not finding the right certs in the certs dir or not specifying a certs dir or certificate path now falls back on checking server CA using Go's TLS code to find the certificates in the OS trust store. If no matching certificate is found, an x509 error will occur announcing that the certificate is signed by an unknown authority. #74544
- Fixed the CLI help text for
ALTER DATABASE
to show correct options forADD REGION
andDROP REGION
, and include some missing options such asCONFIGURE ZONE
. #75067 - The
debug zip
now scrapes the cluster-wide KV replication reports in the output. #75794 - The
debug zip
now includes theraw system.settings
table. This table makes it possible to determine whether a cluster setting has been explicitly set. #75794
DB Console changes
- The clear SQL stats links on the Statements and Transactions pages were relabeled reset SQL stats, for consistency with the language in the SQL shell. #74417
- The Terminate Session and Terminate Statement buttons are available to be enabled in the DB Console. #74530
- In the Statement Details page, replaced raw statement with statement ID in the page URL. #75463
- Removed
$ internal
as one of the app filter options under the Statements and Transactions page filters. #75485 - Changed the order of tabs under SQL Activity page to be Statements, Transactions, and Sessions. #75503
- If the user has the role
VIEWACTIVITYREDACTED
, the statement diagnostics bundle info on Statements page (Diagnostics column), Statement Details page (diagnostics tab) and Advanced Debug page (diagnostics history) is hidden. #75521 - In the Statements and Transactions pages, loading and error pages no longer obscure the page filter controls. #75527
Bug fixes
- Fixed a panic when attempting to access the hottest ranges (e.g., via the
/_status/hotranges
endpoint) before initial statistics had been gathered. #74515 - A doubly nested enum in a DistSQL query no longer causes node crashing panic. #74490
- Servers no longer crash due to panics in HTTP handlers. #74539
- When foreign keys are included inside an
ADD COLUMN
statement and multiple columns were added in a single statement, the first added column no longer has the foreign key applied or an error is no longer generated based on the wrong column. #74528 - When
sslmode=require
is set in a connection string certificate path checking is now bypassed. #74544 - Uninitialized replicas that are abandoned after an unsuccessful snapshot no longer perform periodic background work, so they no longer have a non-negligible cost. #74185
- Fixed a bug where a backed up
defaultdb
that is configured to be MR, is not restored as a multi-region database on cluster restore. #74607 - Fixed a bug where deleting data via schema changes (e.g., when dropping an index or table) could fail with a "command too large" error. #74798
- CockroachDB no longer returns incorrect results or internal errors on queries with window functions returning
INT
,FLOAT
,BYTES
,STRING
,UUID
, orJSON
type when the disk spilling occurred. #74589 - CockroachDB no longer incorrectly calculates
MIN
/MAX
when used as window functions in some cases after spilling to disk. #74589 - Fixed panics possible in some distributed queries using enums in join predicates. #74733
- CockroachDB no longer encounters an internal error when performing
UPSERT
orINSERT ... ON CONFLICT
queries in some cases when the new rows containedNULL
values (eitherNULL
s explicitly specified orNULL
s used since some columns were omitted). #74872 - Internal errors when altering the primary key of a table no longer occur. The bug was only present if the table had a partial index with a predicate that referenced a virtual computed column. #75183
- Fixed a bug that caused errors in rare cases when trying to divide
INTERVAL
values byINT4
orINT2
values. #75079 - Fixed a bug that could occur when a
TIMETZ
column was indexed, and a query predicate constrained that column using a < or > operator with aTIMETZ
constant. If the column contained values with time zones that did not match the time zone of theTIMETZ
constant, it was possible that not all matching values could be returned by the query. Specifically, the results may not have included values within one microsecond of the predicate's absolute time. This bug exists on all versions of 20.1, 20.2, 21.1, and 21.2 prior to this release. #75172 - Fixed an internal error, "estimated row count must be non-zero", that could occur during planning for queries over a table with a
TIMETZ
column. This error was due to a faulty assumption in the statistics estimation code about ordering ofTIMETZ
values, which has now been fixed. The error could occur whenTIMETZ
values used in the query had a different time zone offset than theTIMETZ
values stored in the table. #75172 RESTORE
now inserts asystem.namespace
entry for synthetic public schemas. #74759- A bug has been fixed that caused internal errors in queries with set operations, like
UNION
, when corresponding columns on either side of the set operation were not the same. This error only occurred with a limited set of types. This bug is present in versions 20.2.6+, 21.1.0+, and 21.2.0+. #75276 - Fixed SQL Activity pages crashing when a column was sorted by the 3rd time. #75486
- Updated the
String()
function ofroleOption
to add a space on the roleVALID UNTIL
. #75494 - In particular cases, some queries that involve a scan that returns many results and which includes lookups for individual keys were not returning all results from the table. #75512
- When adding a hash-sharded index to an existing table, traffic could overwhelm a single range of the index before it is split into more ranges for shards as range size grows. The schema changer now pre-splits ranges on shard boundaries before the index becomes writable. The
sql.hash_sharded_range_pre_split.max
cluster setting is the upper bound on the number of ranges to have. If the bucket count of the defined index is less than the cluster setting, the bucket count will be the number of pre-split ranges. #75474 - If multiple columns are added to a table inside a transaction, then none of the columns are backfilled if the last column did not require a backfill. #75507
crdb_internal.deserialize_session
now checks that thesession_user
has the privilege toSET ROLE
to thecurrent_user
before changing the session settings. #75600- CockroachDB no longer incorrectly reports the
KV bytes read
statistic inEXPLAIN ANALYZE
output. The bug is present only in 21.2.x versions. #75260 - The
options
query parameter is no longer removed when using the\c
command in the SQL shell to reconnect to the cluster. #75765 - The
CancelSession
endpoint now correctly propagates gateway metadata when forwarding requests. #75832 - Fixed a bug when granting incompatible database privilege to default privilege with non-lowercase database names. #75580
Performance improvements
- Rangefeed streams now use separate HTTP connections when
kv.rangefeed.use_dedicated_connection_class.enabled
cluster setting is turned on. Using a separate connection class reduces the possibility of out of memory errors when running rangefeeds against very large tables. The connection window size for rangefeed can be adjusted viaCOCKROACH_RANGEFEED_INITIAL_WINDOW_SIZE
environment variable, whose default is 128KB. #74456 - Incremental
BACKUP
s now use less memory to verify coverage of prior backups. #74588 - The merging of incremental backup layers during
RESTORE
now uses a simpler and less memory intensive algorithm. #74593
Contributors
This release includes 75 merged PRs by 35 authors.
v21.2.4
Release Date: January 10, 2022
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.4
Changelog
View a detailed changelog on GitHub: v21.2.3...v21.2.4
Security updates
- It is now possible to pre-compute the hash of the password credentials of a SQL user client-side, and set the SQL user's password using the hash, so that CockroachDB never sees the password string in the clear in the SQL session. This auto-detection is subject to the new cluster setting
server.user_login.store_client_pre_hashed_passwords.enabled
. This setting defaults totrue
(i.e., feature enabled). This feature is meant for use in automation/orchestration, when the control plane constructs passwords for users outside of CockroachDB, and there is an architectural desire to ensure that cleartext passwords are not transmitted/stored in-clear. Note: when the client provides the password hash, CockroachDB cannot carry any checks on the internal structure of the password, such as minimum length, special characters, etc. Should a deployment require such checks to be performed database-side, the operator would need to disable the mechanism via the cluster setting named above. When upgrading a cluster from a previous version, to ensure that the feature remains disabled throughout the upgrade, use the following statement prior to the upgrade:INSERT INTO system.settings(name, value, "valueType") VALUES('server.user_login.store_client_pre_hashed_passwords.enabled', 'false', 'b');
. (We do not recommend relying on the database to perform password checks. Our recommended deployment best practice is to implement credential definitions in a control plane / identity provider that is separate from the database.) #73855 - The
server.identity_map.configuration
cluster setting allows apg_ident.conf
file to be uploaded to support dynamically remapping system identities (e.g., Kerberos or X.509 principals) to database usernames. This supports use cases where X.509 certificates must conform to organizational standards that mandate the use of Common Names that are not valid SQL usernames (e.g.,CN=carl@example.com
=>carl
). Mapping rules that result in theroot
,node
, or other reserved usernames will result in an error when the client attempts to connect. #74459 - The
client_authentication_info
structured log message provides a new"SystemIdentity"
field with the client-provided system identity. The existing"User"
field will be populated after any Host-Based Authentication (HBA) rules have been selected and applied, which may include a system-identity to database-username mapping. #74459 - GSSAPI-based authentication can now use either the HBA
"map"
option or"include_realm=0"
to map the incoming principal to a database username. Existing configurations will operate unchanged, however operators are encouraged to migrate from"include_realm=0"
to"map"
to avoid ambiguity in deployments where multiple realms are present. #74459 - Incoming system identities are normalized to lower-case before they are evaluated against any active identity-mapping HBA configuration. For example, an incoming GSSAPI principal
"carl@EXAMPLE.COM"
would only be matched by rules such as"example carl@example.com carl"
or"example /^(.*)@example.com$ \1"
. #74459
Enterprise edition changes
- Changefeeds can be created with a new option called
metrics_label
which lets operators configure changefeeds to use a dedicated set of metrics for those changefeed(s) so that they can be monitored independently of other changefeed(s) in the system. #73014
SQL language changes
- The
create_type_statements
table now has an index ondescriptor_id
. #73669 - Added the new column
stmt
to thecrdb_internal.(cluster|node)_distsql_flows
virtual table. It is populated on a best effort basis. #73581 - Table backups of
REGIONAL BY ROW
,REGIONAL BY TABLE
, andGLOBAL
tables are now supported. #73087 - The cluster setting called
sql.defaults.reorder_joins_limit
that controls the default for the session settingreorder_joins_limit
is now public and included in the cluster setting docs. #73889 - The
RULE
privilege was added for compatibility with PostgreSQL. It is impossible to grant it, but it is supported as a parameter of thehas_table_privilege
function. #74065 The
CREATE ROLE
andALTER ROLE
statements now accept password hashes computed by the client app. For example:CREATE USER foo WITH PASSWORD 'CRDB-BCRYPT$2a$10$.....'
. This feature is not meant for use by human users / in interactive sessions; it is meant for use in programs, using the computation algorithm described below. This auto-detection can be disabled by changing the cluster settingserver.user_login.store_client_pre_hashed_passwords.enabled
tofalse
. This design mimics the behavior of PostgreSQL, which recognizes pre-computed password hashes when presented to the regularPASSWORD
option. The password hashes are auto-detected based on their lexical structure. For example, any password that starts with the prefixCRDB-BCRYPT$
, followed by a valid encoding of a bcrypt hash (as detailed below), is considered a candidate password hash. To ascertain whether a password hash will be recognized as such, orchestration code can use the new built-in functioncrdb_internal.check_password_hash_format()
. #73855CockroachDB only recognizes password hashes computed using bcrypt, as follows (we detail this algorithm so that orchestration software can implement their own password hash computation, separate from the database):
- Take the cleartext password string.
- Append the following byte array to the password:
e3b0c44298fc1c149afbf4c8996fb92427ae41e4649b934ca495991b7852b855
(These are 32 hex-encoded bytes.) - Choose a bcrypt cost. (CockroachDB servers use cost 10 by default.)
- Generate a bcrypt hash of the string generated at step 2 with the cost chosen at step 3, as per https://wikipedia.org/wiki/Bcrypt or https://bcrypt.online/ Note that CockroachDB only supports hashes computed using bcrypt version 2a.
Encode the hash into the format recognized by CockroachDB: the string
CRDB-BCRYPT
, followed by the standard bcrypt hash encoding ($2a$...
).Summary:
Hash method Recognized by check_password_hash_format()
ALTER/CREATE USER WITH PASSWORD crdb-bcrypt
yes ( CRDB-BCRYPT$2a$...
)recognized if enabled via cluster setting scram-sha-256
yes ( SCRAM-SHA-256$4096:...
)not implemented yet (issue #42519) md5
yes ( md5...
)obsolete, will likely not be implemented
Backported the
server.user_login.store_client_pre_hashed_passwords.enabled
cluster setting to v21.2. The backported default value in v21.2 isfalse
. In v22.1 the default will betrue
. #73855
Operational changes
- Added a new cluster setting
bulkio.ingest.flush_delay
to act as a last-resort option to manually slow bulk-writing processes if needed for cluster stability. This should only be used if there is no better suited back-pressure mechanism available for the contended resource. #73758 - The license expiry metric is now available in the DB Console and includes the expected
HELP
andTYPE
annotations in the Prometheus output on_status/vars
. #73859
DB Console changes
- Added new formatting functions to create summarized queries for
SELECT
,INSERT
, andUPDATE
statements. Also added new metadata fields, which will later be used to pass this information to the front-end Statements page. #73661 - The jobs overview table in DB Console now shows when jobs have the status "reverting", and shows the badge "retrying" when running or reverting jobs are also retrying. Hovering over the status for a "retrying" job will show the "Next execution time" in UTC. Two new columns, "Last Execution Time (UTC)" and "Execution Count", were also added to the jobs overview table in DB Console, and the "Status" column was moved left to the second column in the table. The
status
query parameter in the/jobs
endpoint now supports the valuesreverting
andretrying
. #73624 - Added new statement summaries to the Statements page. This applies for
SELECT
,INSERT
/UPSERT
, andUPDATE
statements, and will enable them to be more detailed and less ambiguous than our previous formats. #73661 - Added new summarized formats for
SELECT
,INSERT
/UPSERT
, andUPDATE
statements on the Sessions page and the Transactions page, to be consistent with the Statements page. Show "Mean rows written" as a metric for all statement types on the Statements page, instead of hiding this metric forSELECT
statements. #73661 - Made visual improvements to the DB Console. #73386
- Updated text of filter drop-downs in the DB Console, replacing "usage" with "statement" for consistency. #74421
Bug fixes
- Fixed a bug which caused corruption of partial indexes, which could cause incorrect query results. The bug was only present when two or more partial indexes in the same table had identical
WHERE
clauses. This bug has been present since v21.1.0. For more information, see Technical Advisory 74385. #74471 - Fixed an internal error
"empty Datums being compared to other"
that could occur during planning for someSELECT
queries over tables that included aDEFAULT
partition value in aPARTITION BY LIST
clause. This bug was present since v21.1.0. This bug does not exist in CockroachDB v20.2.x and earlier. #73664 - Fixed a bug that could cause a CockroachDB node to deadlock upon startup in extremely rare cases. If encountered, a stack trace generated by
SIGQUIT
would show the functionmakeStartLine()
near the top. This bug had existed since v21.1.0. #71407 - Fixed a bug where CockroachDB could crash when reading a secondary index with a
STORING
clause in reverse direction (i.e., withORDER BY col DESC
). This bug was introduced in v21.2.0. #73699 - Fixed a bug where the correct index count was not displayed in the Indexes column on the Databases page of the DB Console. #73747
- Fixed a bug where a failed
IMPORT INTO
to a non-empty table would be unable to clean up the partially imported data when run in a serverless cluster because the operation to do so was incorrectly denied for tenants. #73541 - Fixed a bug in database and schema restore cleanup that results in a dangling descriptor entry on job failure. #73411
- Fixed a bug which allowed queries to reference internal columns created by the system for expression indexes. These columns, which had names prefixed with
crdb_internal_idx_expr
, can no longer be referenced in queries. This bug was present since version v21.2.0 when expression indexes were released. #74285 - Fixed a bug with ungraceful shutdown of distributed queries in some rare cases. "Ungraceful" here means due to a
statement_timeout
(most likely) or because a node crashed. #73958 - Fixed a bug where CockroachDB could return a spurious "context canceled" error for a query that actually succeeded in extremely rare cases. #73958
- Fixed a bug where CockroachDB could encounter an internal error when executing queries with multiple window functions and one of those functions returned an
INT2
orINT4
type. #74311 - Fixed a bug where it was possible for
cockroach debug zip
and the log file viewer in the DB Console to observe incomplete log entries at the end of log files—especially the log file currently being written to by the CockroachDB process. This bug was introduced in a very early version of CockroachDB. #74153 - Fixed a bug where Changefeeds would emit NULL values for virtual computed columns. Previously, the changefeeds would crash if these were set to
NOT NULL
. #74095 - Internal columns created by the system to support expression indexes are now omitted from the output of
SHOW COLUMNS
statements and theinformation_schema.columns
table. #73540 - Fixed a bug where
IMPORT TABLE ... PGDUMP DATA
with aCOPY FROM
statement in the dump file that had fewer target columns than the inline table definition would result in a nil pointer exception. #74435 - Fixed a bug where escape character processing was missing from constraint span generation, which resulted in incorrect results when doing escaped
LIKE
lookups. #74259 - Fixed a bug affecting the redactability of logging tags in output log entries. This bug was introduced in the v21.2.0 release. #74155
Performance improvements
- Bulk ingestion of small write batches (e.g., index backfill into a large number of ranges) is now throttled, to avoid buildup of read amplification and associated performance degradation. Concurrency is controlled by the new cluster setting
kv.bulk_io_write.concurrent_addsstable_as_writes_requests
. #74071
Miscellaneous
- Added admit and commit latency metrics to changefeeds. #73014
- Updated and improved the set of sink specific changefeed metrics. #73014
Contributors
This release includes 57 merged PRs by 31 authors.
v21.2.3
Release Date: December 14, 2021
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.3
Changelog
View a detailed changelog on GitHub: v21.2.2...v21.2.3
Enterprise edition changes
- Fixed a limitation of
IMPORT
for tables using user-defined types whereby any change to the set of tables or views which reference the type or any changes to privileges on the type during theIMPORT
would lead to failure. Now, new references to the type orGRANT
orREVOKE
operations performed while theIMPORT
is ongoing will not cause failure. #71500 - Fixed a bug where
RESTORE
could sometimes map OIDs to invalid types in certain circumstances containing user-defined types. #73119
SQL language changes
- The experimental
ALTER COLUMN TYPE
statement is no longer permitted when the column is stored in a secondary index. Prior to this change, that was the only sort of secondary index membership which was allowed, but the result of the operation was a subtly corrupted table. #72797 Statements containing multiple
INSERT ON CONFLICT
,UPSERT
,UPDATE
, orDELETE
subqueries can cause data corruption if they modify the same row multiple times. For example, the followingSELECT 1
statement will cause corruption of tablet
:CREATE TABLE t (i INT, j INT, PRIMARY KEY (i), INDEX (j)); INSERT INTO t VALUES (0, 0); WITH cte1 AS (UPDATE t SET j = 1 WHERE i = 0 RETURNING *), cte2 AS (UPDATE t SET j = 2 WHERE i = 0 RETURNING *) SELECT 1;
Until this is fixed, this change disallows statements with multiple subqueries that modify the same table. Applications can work around this by rewriting problematic statements. For example, the query above can be rewritten as an explicit multi-statement transaction:
BEGIN; UPDATE t SET j = 1 WHERE i = 0; UPDATE t SET j = 2 WHERE i = 0; SELECT 1; COMMIT;
Or, if it doesn't matter which update "wins", it can be written as multiple non-mutating CTEs on an
UPDATE
statement:WITH cte1 AS (SELECT 1), cte2 AS (SELECT 2) UPDATE t SET j = x.j FROM (SELECT * FROM cte1 UNION ALL SELECT * FROM cte2) AS x (j) WHERE i = 0 RETURNING 1;
Which in this case could be written more simply as:
UPDATE t SET j = x.j FROM (VALUES (1), (2)) AS x (j) WHERE i = 0 RETURNING 1;
Note that in these last two rewrites the first update will win, rather than the last. None of these rewrites suffer from the corruption problem. To override this change and allow these statements in spite of the risk of corruption, applications can:
SET CLUSTER SETTING sql.multiple_modifications_of_table.enabled = true
However, with the
sql.multiple_modifications_of_table.enabled
cluster setting enabled, there is nothing to prevent this type of corruption from occurring if the same row is modified multiple times by a single statement. To check for corruption, use theEXPERIMENTAL SCRUB
command:EXPERIMENTAL SCRUB TABLE t WITH OPTIONS INDEX ALL;
RESTORE TABLE
for a regional by row table into a multiregion database with the same regions as the backed up database is now allowed. The user must ensure that the regions in the backed up database and the database being restored into match, and are added in the same order, for theRESTORE
to work. #72088The structured payloads used for telemetry logs now include two new fields:
CostEstimate
andDistribution
.CostEstimate
is the cost of the query as estimated by the optimizer, andDistribution
is the distribution of the DistSQL query plan (local, full, or partial). #73410Fixed a bug which allowed computed columns to also have
DEFAULT
expressions. #73190
DB Console changes
- When requesting the
pprofui
endpoints from the Advanced Debug page in DB Console, operators can now query by node ID in order to requestpprofui
data from any node in the cluster without having to connect to its DB Console directly. Profiling UI links are in a separate section along with anodeID
selector to allow for easy targeting. #71103 - The absolute links on the Advanced Debug page in DB Console have been updated to relative links. This will enable these links to work with the superuser dashboard in Cloud Console. #73067
- When an error is encountered in the Statements, Transactions, or Sessions page, the user can now click on a reload button to reload the page. #73115
Bug fixes
- Fixed a bug where
GENERATED ... IDENTITY
would panic when using a non-INT
value during table creation. #73029 - Fixed a bug whereby setting the
CACHE
for a sequence to1
was ignored. Before this changeALTER SEQUENCE ... CACHE 1
would succeed but would not modify the cache value. #71449 - Fixed a bug where a crash during startup may cause all subsequent starts to fail. #73124
- Fixed an internal error that could occur during planning for some set operations (i.e.,
UNION
,INTERSECT
, orEXCEPT
) when at least one side of the set operation was ordered on a column that was not output by the set operation. This bug was first introduced in v21.2.0 and does not exist in prior versions. #73147 - Manually enqueueing ranges via the DB Console will no longer crash nodes that contain an uninitialized replica for the enqueued range. #73039
- Fixed a crash with message "attempting to propose command writing below closed timestamp" that could occur, typically on overloaded systems experiencing non-cooperative lease transfers. #73165
- Fixed two bugs in the logic that optimized the number of spans to backup. #73176
- Transactions now using the correct selector for sort setting and filters. #73291
- The GC queue now respects the
kv.queue.process.guaranteed_time_budget
cluster setting. #70126 - The
cockroach debug unsafe-remove-dead-replicas
tool was improved to handle the existence of learners. It will now produce the desired results in more circumstances. The tool remains dangerous and can irrevocably corrupt a cluster. #70756 - Fixed a rare internal error ("estimated row count must be non-zero"), which could occur when planning queries using a GIN index. This error could occur if the histogram on the GIN index showed that there were no rows. #73354
- Fixed a bug where
SHOW CREATE SCHEDULES
was not redacting sensitive fields before displaying theCREATE SCHEDULE
query. #71362 - The
txnwaitqueue.pusher.waiting
metric no longer over-reports the number of pushing transactions in some cases. #71744 - Fixed a rare condition that could cause a range merge to get stuck waiting on itself. The symptom of this deadlock was a goroutine stuck in
handleMergeInProgressError
for tens of minutes. #72050 RESTORE ... FROM LATEST IN
now works to restore the latest backup from a collection without needing to first inspect the collection to supply its actual path. #73454- Prevent a panic in the parser when trying to parse the
.@n
tuple field deference syntax in the (invalid) n=0 case. #73545 - Fixed a bug where CockroachDB did not exit with the correct exit code when it ran out of disk space while the node was running. This behavior was new in v21.2 and was not behaving as intended. #70853
- Fixed certain bugs where
CREATE TABLE AS
orCREATE MATERIALIZED VIEW
may panic if theSELECT
query is an internal table requiring internal database state. #73593
Performance improvements
- The performance of transaction deadlock detection is now more stable even with significant transaction contention. #71744
- Follower reads that encounter many abandoned intents are now able to efficiently resolve those intents. This resolves an asymmetry where follower reads were previously less efficient at resolving abandoned intents than regular reads evaluated on a leaseholder. #71884
Contributors
This release includes 61 merged PRs by 30 authors.
v21.2.2
Release Date: December 1, 2021
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.2
Changelog
View a detailed changelog on GitHub: v21.2.1...v21.2.2
SQL language changes
- Fixed an oversight in which a full scan of a partial index could be rejected due to the
disallow_full_table_scans
setting. Full scans of partial indexes will no longer be rejected ifdisallow_full_table_scans
is true, since a full scan of a partial index must be a constrained scan of the table. #71437 - The optimizer has been updated so that if
disallow_full_table_scans
is true, it will never plan a full table scan with an estimated row count greater thanlarge_full_scan_rows
. If no alternative plan is possible, an error will be returned, just as it was before. However, cases where an alternative plan is possible will no longer produce an error, since the alternative plan will be chosen. As a result, users should see fewer errors due todisallow_full_table_scans
. A side effect of this change is that ifdisallow_full_table_scans
is set along with statement-level hints such as an index hint, the optimizer will try to avoid a full table scan while also respecting the index hint. If this is not possible, the optimizer will return an error and might not log the attempted full table scan or update thesql.guardrails.full_scan_rejected.count
metric. If no index hint is used, the full scan will be logged and the metric updated. #71437 - Added support for a new
index hint
,NO_FULL_SCAN
, which will prevent the optimizer from planning a full scan for the specified table. The hint can be used in the same way as other existing index hints. For example,SELECT * FROM table_name@{NO_FULL_SCAN};
. Note that a full scan of a partial index may still be planned, unlessNO_FULL_SCAN
is forced in combination with a specific partial index viaFORCE_INDEX=index_name
. #71437 EXPLAIN ANALYZE (DEBUG)
can now be used by Serverless clusters. #71969- The session variables
LC_COLLATE
,LC_CTYPE
,LC_MESSAGES
,LC_MONETARY
,LC_NUMERIC
, andLC_TIME
were added for compatibility with PostgreSQL. They only support theC.UTF-8
locale. #72260 - Fixed an issue where the error message when creating the wrong type of forward index on a JSONB column was not clear. It now suggests creating a GIN index. #72361
- Changed the
pgerror
code fromCD
toXC
for CockroachDB-specific errors. This is because the "C" class is reserved for the SQL standard. Thepgcode
CDB00
used for unsatisfiable bounded staleness is nowXCUBS
. #70448 - The
CREATE TABLE ... LIKE ...
statement now copiesON UPDATE
definitions forINCLUDING DEFAULTS
. #70537 - CockroachDB now shows
indpred
on thepg_index
table for partial indexes. This was previouslyNULL
for partial indexes. #70884 - Fixed a bug where
LINESTRINGZ
,LINESTRINGZM
, andLINESTRINGM
could not be used as a column type. #70747 - Added the
crdb_internal.reset_index_usage_stats()
function to clear index usage stats. This can be invoked from the SQL shell. #72843 - The string "visible" is now usable as a table or column name without extra quoting. #70563
- The
aggregation_interval
column has been added to the crdb_internal.statement_statistics and crdb_internal.transaction_statistics tables, representing the aggregation duration of the respective statistics. #72941 - The
diagnostics.sql_stats_reset.interval
cluster setting was removed. In previous version of CockroachDB, in-memory SQL statistics were reset periodically. This behavior is now removed since persisted SQL Statistics were introduced in v21.2. Thediagnostics.forced_sql_stats_reset.interval
cluster setting now only controls the reset of the reported SQL statistics if it is not collected by the telemetry reporter. #72941
Operational changes
- Job IDs and Session IDs are no longer redacted. These values do not represent sensitive or identifiable data, but do aid in debugging problems with the jobs system. #72975
Command-line changes
- The SQL shell now supports a
\statement-diag
command for listing and downloading statement diagnostics bundles. #71969
API endpoint changes
- The
aggregationInterval
field has been added to combined statements response. #72941
DB Console changes
- The Session, Statements, and Transactions pages are now grouped inside the new SQL Activity page. #72052
- The Statement Details page and Transaction Details page now show the mean rows written metric. #72006
- A new Rows Written column has been added to the Statements and Transactions tables. This column will not show up by default, but can be selected from the column selector. #72006
- The tooltip text on the Statement column of the Sessions table was edited to clarify that we show only currently active statements. #72100
- The Not Found page was updated. #72758
- The Statements page now uses
$ internal
on the filter to align with the Transactions page. #72755 - The Application filter on the Transactions and Statement pages is now multi-select. #72755
- The default value when no Application is selected on the Transactions and Statements filter now excludes internal transactions and statements. #72755
- There is now a new page that is displayed when something goes wrong and the page crashes. #72796
- Fixed an issue on the Metrics pages where graphs didn't show data for date ranges older than 10 days. #72864
- Metrics pages now show gaps instead of data interpolation. #72864 and #72744
- Node events now display a permission error rather than an internal server error when the user does not have
ADMIN
privileges to view events. #72792 - Fixed an issue with drag-to-zoom granularity. #72855
- The
Interval Start Time (UTC)
column on the Statements and Transactions pages has been renamedAggregation Interval (UTC)
and is the interval of aggregation. The Statement Details page now also displays the interval for which the user is viewing statement details. #72941 - The Transaction Details page now shows statement statistics scoped by the transaction fingerprint. #72941
Bug fixes
- When using the
json-fluent
andjson-fluent-compact
logging formats, thetag
field now uses the same normalization algorithm as used for output to files. That is, if the CockroachDB executable is renamed to contain periods (e.g.,cockroach.testbinary
), the periods are now eliminated instead of replaced by_
. This is the behavior that was originally intended. This change does not affect deployments that use the standard executable namecockroach
. #71075 - The
cockroach debug zip
command, thecockroach debug list-files
command, and the Advanced Debug page that enables log file access, are now able to gather log files stored across all configured logging directories. Prior to this patch, only log files from the directory associated with theDEV
file sink were visible. This bug had existed since CockroachDB v19.x. Note that the behavior remains incomplete if two or more file groups in the logging configuration use similar names that only differ in their use of periods (e.g., a file group namedone.two
and another one namedonetwo
). To avoid any issue related to this situation, use more distinct file group names. #71075 - Fixed a bug where usernames in
ALTER TABLE ... OWNER TO
would not be normalized to lower case. #72470 - Fixed a bug where the Show All filter on the Statements page didn't display all the statements when with an empty string in the search box. #72052
- Fixed a bug in prior betas of v21.2 where some error codes returned when looking for a descriptor in a non-existent database were changed from
UndefinedDatabase (3D000)
toUndefinedObject (42704)
. Name resolution when the current database is undefined will now returnUndefinedDatabase
. #71566 - Fixed an incorrect
no data source matches prefix
error for queries that use a set-returning function on the right-hand side of aJOIN
unlessLATERAL
is explicitly specified. #71445 - Fixed a bug where using
CREATE TABLE AS ....
with a source query that referred to a sequence would not work. #71541 - Support was added for the
"{}"
format for array columns inCOPY FROM STDIN WITH CSV
. #72693 - Fixed a bug which caused
ALTER COLUMN TYPE
statements to incorrectly fail. #71165 - Fixed potential descriptor corruption bug for tables with a column with a
DEFAULT
expression referencing aSEQUENCE
and with anON UPDATE
expression. #72362 - Fixed a bug where schema changes running during node shutdown could sometimes fail permanently when they should not. #72333
- Fixed a panic that could occur with invalid GeoJSON input using
ST_GeomFromGeoJSON/ST_GeogFromGeoJSON
. #71309 - Fixed a bug where specifying
IntervalStyle
orDateStyle
onoptions=-c...
in a connection string would fail, even if thesql.defaults.datestyle.enabled
andsql.defaults.intervalstyle.enabled
cluster settings were set. #72067 - Fixed a bug where session variables passed in the connection string were case-sensitive. Now they are all correctly normalized to lower case. #72067
- Fixed a bug where
atttypmod
inpg_catalog.pg_attributes
forDECIMAL
types with precision but no width was incorrectly-1
. #72074 - Fixed a bug where the
setval
function did not invalidate cached sequence values. #71821 - Fixed a bug where when creating an object default privileges from users that were not the user creating the object would be added to the privileges of the object. This fix ensures only the relevant default privileges are applied. #72410
- Fixed a bug where Z and M coordinate columns caused a panic for
geometry_columns
andgeography_columns
. #70814 - Fixed a bug where certain schema changes (e.g., SET NULL) did not work if there was an expression index on the table. #72024
- The connect timeout for
grpc
connections is set to 20s to match the pre-v20.2 default value. #71517 IMPORT INTO
no longer crashes when encountering unresolved write intents. #71983- Fixed an incorrect bug hint for the
sql.defaults.datestyle.enabled
cluster setting. #70900 - Fixed a bug which caused internal errors when collecting statistics on tables with virtual computed columns. #71234
- Fixed a bug that incorrectly populated the
indkey
column ofpg_catalog.pg_index
for expression indexes. This bug was present since the introduction of expression indexes in version 21.2.0. #72064 - Fixed a bug where some queries against the
pg_catalog.pg_type
could throw an error if they looked up a non-existent ID. #72885 - Corrected how the
type
displays for ZM shapesgeometry_columns
to match PostGIS output. This previously incorrectly included the Z/M lettering. #72809 - Corrected how
type
displays ingeometry_columns
to better match PostGIS. This previously used the wrong case. #72809 - Fixed a bug where CockroachDB could encounter an internal error when executing a zigzag join in some cases (when there are multiple filters present and at least one filter refers to the column that is part of
STORING
clause of the secondary index that is used by the zigzag join). #71253 - Fixed a bug where CockroachDB could not set the
TableOID
andTableAttributeNumber
attributes of theRowDescription
message of thepgwire
protocol in some cases (these values would be left as 0). #72450 - Fixed a bug where CockroachDB could encounter an internal error or crash when some queries involving tuples with
ENUMs
were executed in a distributed manner. #72482 - Fixed a bug where if tracing (the
sql.trace.txn.enable_threshold
cluster setting) was enabled on the cluster, the statement diagnostics collection (EXPLAIN ANALYZE (DEBUG)
) wouldn't work. #70023 - Fixed a bug causing tracing to external tracers to inadvertently stop after the Enqueue Range or the Allocator debug pages was used. #72465
- Fixed a bug preventing tuple type labels from being propagated across queries when run under DistSQL. #70392
- CockroachDB is now less likely to OOM when queries reading a lot of data are issued with high concurrency (these queries are likely to hit the memory budget determined by
--max-sql-memory
startup parameter). #70809 - The
indexprs
column ofpg_catalog.pg_index
is now populated with string representations of every expression element in the index. If the index is not an expression index,indexprs
isNULL
. Theindexdef
column ofpg_catalog.pg_indexes
and theindpred
column ofpg_catalog.pg_index
now correctly display user-defined types. #72870 - Fixed a bug where introspection tables and error messages would not correctly display intervals according to the
intervalstyle
session variable. #72690 - Fixed a bug where index definitions in
pg_catalog.pg_indexes
would not format intervals according to theintervalstyle
session variable. #72903 - Statement statistics are now grouped by the statement's corresponding transaction fingerprints. #72941
- The query backing
crdb_internal.cluster_contended_indexes
improperly assumed that index IDs were unique across the database. This change adds the proper scoping by table descriptor ID, truing up the contents of that view. #73025
Performance improvements
- Fixed a performance regression in planning that could occur for simple queries on schemas with a large number of indexes. #72240
- The conversion of Well Known Text to a spatial type is improved. #70182
- Improved
IMPORT INTO
performance in cases where it encounters large numbers of unresolved write intents. #72271 - Fixed a limitation that made creating partial indexes inefficient. #70205
- Backfills initiated by schema changes now periodically checkpoint progress to avoid excessive re-emitting of already emitted spans. #72788
Contributors
This release includes 133 merged PRs by 45 authors. We would like to thank the following contributors from the CockroachDB community:
- neeral
v21.2.1
Release Date: November 29, 2021
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.1
Changelog
View a detailed changelog on GitHub: v21.2.0...v21.2.1
Bug fixes
- The timeout check of Raft application during upgrade migrations has been increased from 5 seconds to 1 minute and is now controllable via the cluster setting
kv.migration.migrate_application.timeout
. This makes migrations less likely to fail in clusters with ongoing rebalancing activity during upgrade migrations. #73061 - Fixed a bug where
BACKUP ... with revision_history
would fail on an upgraded, but un-finalized cluster. It will now succeed. #73050 - Fixed a bug that could cause some semi lookup joins on
REGIONAL BY ROW
tables to return early before finding all data. This bug is currently only present in v21.2.0. This problem only manifested if there was anON
condition on top of the equality condition used for the lookup join, and the lookup columns did not form a key in the index being looked up. The primary impact of this issue for most users relates to uniqueness checks on mutations ofREGIONAL BY ROW
tables, since uniqueness checks are implemented with a semi lookup join with anON
condition. The result of this bug was that uniqueness checks were not comprehensive, and could miss an existing duplicate key on a remote node. This could cause data to be erroneously inserted with a duplicate key when it should have failed the uniqueness check. #73063 - Backups taken while a cluster contains a mix of v21.2 and v21.1 nodes may fail. Upgrading the entire cluster to v21.2 should resolve the issues. The technical advisory 72839 provides more information about possible remediations. The error returned after a backup failure in this case now also directs the user to the technical advisory. #72880
- Fixed a bug that caused a full-cluster backup to fail while upgrading from v21.1 to v21.2. This caused an error, because the
system.tenant_usage
table, which is present in v21.2, is not present in v21.1. #72840 - Fixed a bug where cluster backups were backing up opt-out system tables unexpectedly. #71368
Contributors
This release includes 6 merged PRs by 6 authors.
v21.2.0
Release Date: November 16, 2021
With the release of CockroachDB v21.2, we've made a variety of management, performance, and compatibility improvements. Check out a summary of the most significant user-facing changes and then upgrade to CockroachDB v21.2.
To learn more:
- Read the v21.2 blog post.
- Watch the live demo and Q&A session recorded on Tuesday, December 7.
During an upgrade of a CockroachDB cluster from v21.1.x → v21.2.0, backups will fail until the upgrade is finalized. After the upgrade is complete and finalized, backups will continue as normal.
This issue will only occur if the upgrade coincides with a backup. For small clusters, where the upgrade is quick, there may be no overlap, and you will not experience this issue.
For more information, including mitigation, see Technical Advisory 72389.
Downloads
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach:v21.2.0
Changelog
View a detailed changelog on GitHub: v21.2.0-rc.3...v21.2.0
CockroachDB Cloud
- Get a free v21.2 cluster on CockroachDB Serverless.
- Learn about recent updates to CockroachDB Cloud in the CockroachDB Cloud Release Notes.
Feature summary
This section summarizes the most significant user-facing changes in v21.2.0. For a complete list of features and changes, including bug fixes and performance improvements, see the release notes for previous testing releases. You can also search for what's new in v21.2 in our docs.
"Core" features are freely available in the core version of CockroachDB and do not require an enterprise license. "Enterprise" features require an enterprise license. CockroachDB Cloud clusters include all enterprise features. You can also use cockroach demo
to test enterprise features in a local, temporary cluster.
- SQL
- Recovery and I/O
- Database operations
- Backward-incompatible changes
- Deprecations
- Known limitations
- Education
SQL
Version | Feature | Description |
---|---|---|
Enterprise | Multi-region observability | You can now surface region information by using the EXPLAIN ANALYZE statements. This information is also now available in the DB Console. |
Enterprise | Restricted and default placement | You can now use the ALTER DATABASE ... PLACEMENT RESTRICTED statement to constrain the replica placement for a multi-region database's regional tables to the home regions associated with those tables. |
Enterprise | Bounded staleness reads | Bounded staleness reads are now available in CockroachDB. These use a dynamic, system-determined timestamp to minimize staleness while being more tolerant to replication lag than exact staleness reads. This dynamic timestamp is returned by the with_min_timestamp() or with_max_staleness() functions. In addition, bounded staleness reads provide the ability to serve reads from local replicas even in the presence of network partitions or other failures. |
Core | Privilege inheritance | CockroachDB's model for inheritance of privileges that cascade from schema objects now matches PostgreSQL. Added support for ALTER DEFAULT PRIVILEGES and SHOW DEFAULT PRIVILEGES . |
Core | ON UPDATE expressions |
An ON UPDATE expression can now be added to a column to update column values when an UPDATE or UPSERT statement modifies a different column value in the same row, or when an ON UPDATE CASCADE expression on a different column modifies an existing value in the same row. |
Core | More granular controls for session variables | There are now more ways to control CockroachDB's behavior through session variables. You can now set user or role-level defaults by using the ALTER ROLE statement. CockroachDB also now supports setting session variables for the duration of a single transaction, using the LOCAL keyword. |
Core | Transaction guardrails | Transaction guardrails have been added to CockroachDB to improve production stability. These can help prevent cluster unavailability and protect the cluster against multiple developer workloads with problematic SQL statements. |
Core | Expression indexes | Indexes on expressions can now be created. These indexes speed up queries that filter on the result of that expression, and are especially useful for indexing only a specific field of a JSON object. |
Core | Correlated CTEs | Correlated common table expressions (CTEs) are now supported in CockroachDB. A correlated CTE is a common table expression that is contained in a subquery and references columns defined outside of the subquery. |
Core | Admission control | A new admission control system has been added. CockroachDB implements this optional admission control system to maintain cluster performance and availability when some nodes experience high load. Admission control is disabled by default. Additionally, an Overload dashboard has been added to the DB Console. Use this dashboard to monitor the performance of the parts of your cluster relevant to the cluster's admission control system. This includes CPU usage, the runnable goroutines waiting per CPU, the health of the persistent stores, and the performance of admission control system when it is enabled. |
Core | Persistent statement and transaction statistics | Statistics information on the Statements and Transactions pages within the DB Console can now be persisted for longer than one hour. |
Core | Index usage statistics | Index usage statistics are now supported for CockroachDB to help identify unused indexes causing unnecessary performance overhead for your workload. Index read statistics are available in the crdb_internal schema for programmatic access using SQL. |
Core | Third-party tool support | Sequelize, a Javascript object-relational mapper (ORM), and Alembic, a schema migration tool for SQLAlchemy users, are now fully supported. We have also improved testing for PgBouncer, an external connection pooler for PostgreSQL. |
Core | Contention views | You can now use pre-built contention views in crdb_internal to quickly identify the top contending indexes. These views can be used to understand where and avoid contention happening in your workload. |
Recovery and I/O
Version | Feature | Description |
---|---|---|
Enterprise | BACKUP / RESTORE scalability |
BACKUP and RESTORE performance has been improved for larger data volumes, more frequent backups, and clusters with more or larger nodes. |
Enterprise | Webhook changefeed sink | You can now stream individual changefeed messages as webhook messages to a newly supported webhook-https sink. The webhook sink is a flexible, general-purpose sink solution that does not require managing a Kafka cluster or cloud storage sink. |
Enterprise | Multi-region bulk operations improvements | The following bulk operations are now supported:
|
Enterprise | Changefeeds for regional by row tables | Changefeeds are now supported on regional by row tables. |
Enterprise | Changefeed observability | You can now display specific fields related to changefeed jobs by running SHOW CHANGEFEED JOBS . |
Database operations
Version | Feature | Description |
---|---|---|
Enterprise | Kubernetes Operator on Amazon EKS | The Kubernetes Operator is now supported on Amazon EKS (Elastic Kubernetes Service). |
Enterprise | Extend the Kubernetes Operator API | The Kubernetes Operator API has been extended to a state where it can support the various types of single-region deployments the Helm chart currently supports. This includes:
|
Enterprise | Multi-region in the DB Console | The DB Console now surfaces multi-region information to provide observability into global databases and their workloads. You can view multi-region details on the Databases, Statements, and Transactions pages. |
Core | Automatic ballast files | CockroachDB now automatically creates an emergency ballast file at startup time. The cockroach debug ballast command is still available but deprecated. For more information about how automatic ballast file creation works, see automatic ballast files. |
Backward-incompatible changes
Before upgrading to CockroachDB v21.2, be sure to review the following backward-incompatible changes and adjust your deployment as necessary.
- Interleaved tables and interleaved indexes have been removed. Before upgrading to v21.2, convert interleaved tables and replace interleaved indexes. Clusters with interleaved tables and indexes cannot finalize the v21.2 upgrade.
- Previously, CockroachDB only supported the YMD format for parsing timestamps from strings. It now also supports the MDY format to better align with PostgreSQL. A timestamp such as
1-1-18
, which was previously interpreted as2001-01-18
, will now be interpreted as2018-01-01
. To continue interpreting the timestamp in the YMD format, the first number can be represented with 4 digits,2001-1-18
. - The deprecated cluster setting
cloudstorage.gs.default.key
has been removed, and the behavior of theAUTH
parameter in Google Cloud StorageBACKUP
andIMPORT
URIs has been changed. The default behavior is now that ofAUTH=specified
, which uses the credentials passed in theCREDENTIALS
parameter, and the previous default behavior of using the node's implicit access (via its machine account or role) now requires explicitly passingAUTH=implicit
. - Switched types from
TEXT
to"char"
for compatibility with PostgreSQL in the following columns:pg_constraint
(confdeltype
,confmatchtype
,confudptype
,contype
)pg_operator
(oprkind
),pg_prog
(proargmodes
),pg_rewrite
(ev_enabled
,ev_type
), andpg_trigger
(tgenabled
).
Deprecations
- The
kv.closed_timestamp.closed_fraction
andkv.follower_read.target_multiple
settings are now deprecated and turned into no-ops. They had already stopped controlling the closing of timestamps in v21.1, but were still influencing thefollower_read_timestamp()
computation for a timestamp that is likely to be closed on all followers. To replace them, a simplerkv.closed_timestamp.propagation_slack
setting is introduced, modeling the delay between when a leaseholder closes a timestamp and when all the followers become aware of it (defaults conservatively to 1s).follower_read_timestamp()
is now computed askv.closed_timestamp.target_duration
+kv.closed_timestamp.side_transport_interval
+kv.closed_timestamp.propagation_slack
, which defaults to 4.2s (instead of the previous default of 4.8s). - Because the
SELECT
database privilege is being deprecated, CockroachDB now additionally checks for theCONNECT
privilege on the database to allow for backing up the database. Existing users withSELECT
on the database can still back up the database, but it is now recommended toGRANT
CONNECT
on the database. IMPORT TABLE
will be deprecated in v21.2 and removed in a future release. Users should create a table usingCREATE TABLE
and thenIMPORT INTO
the newly created table.- Granting
SELECT
,UPDATE
,INSERT
, andDELETE
on databases is being deprecated. The syntax is still supported, but is automatically converted to the equivalentALTER DEFAULT PRIVILEGES FOR ALL ROLES
command. The user is given a notice that the privilege is incompatible and automatically being converted to anALTER DEFAULT PRIVILEGE FOR ALL ROLES
command.
Known limitations
For information about new and unresolved limitations in CockroachDB v21.2, with suggested workarounds where applicable, see Known Limitations.
Education
Area | Topic | Description |
---|---|---|
Cockroach University | New Serverless course | Introduction to Serverless Databases and CockroachDB Serverless teaches you the core concepts behind serverless databases and gives you the tools you need to get started with CockroachDB Serverless. |
Cockroach University | New Schema Design Course | Foundations of Schema Design in CockroachDB teaches you CockroachDB's rich data types and the best practices and anti-patterns to consider when designing schema for CockroachDB. |
Cockroach University | New Node.js Course | Fundamentals of CockroachDB for Node.js Developers guides you through building a full-stack vehicle-sharing app in Typescript using Node.js with TypeORM and a CockroachCloud Free cluster as the backend. |
Docs | CockroachDB Cloud Guidance | Added Node.js, Go, Python, and Java sample app code and connection guidance to the CockroachDB Serverless Quickstart, as well as docs explaining the CockroachDB Serverless Architecture, important concepts for planning/managing a Serverless cluster (e.g., request units, cluster scaling), and how to run customer-owned backups on CockroachDB Dedicated and CockroachDB Serverless clusters. |
Docs | Multi-Region Guidance | Added docs on transitioning to the new multi-region SQL abstractions from the legacy zone-configuration-based workflows, and on data domiciling in multi-region clusters. |
Docs | Performance Tuning Recipes | Added solutions for common performance issues. |
Docs | New Developer Tutorials | Added tutorials on using Google Cloud Run to deploy a containerized Django application and using the Alembic schema migration module with a simple Python application. |
Docs | Changefeed Tuning Guidance | Added guidance on tuning changefeeds for high-durability delivery, high throughput, and Kafka sinks. |
Docs | Sample App Specifications | Added a README with specifications for future sample apps built by external partners or contributors. |
Docs | Disk Stall Troubleshooting | Added docs explaining the symptoms, causes, and mitigations for disk stalls. |
Docs | Network Logging with Fluentd | Added an example configuration for network logging with Fluentd. |
v21.2.0-rc.3
Release Date: November 1, 2021
Downloads
CockroachDB v21.2.0-rc.3 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-rc.3
Changelog
View a detailed changelog on GitHub: v21.2.0-rc.2...v21.2.0-rc.3
Bug fixes
- Previously, CockroachDB could incorrectly read the data of a unique secondary index that used to be a primary index created by an
ALTER PRIMARY KEY
command in v21.1.x or prior versions. This is now fixed. #71586 - Previously, CockroachDB could crash if network connectivity was impaired. The stack trace (in
cockroach-stderr.log
) would containserver.(*statusServer).NodesUI
in that case. This is now fixed. #71756 - A bug has been fixed which caused incorrect results for some queries that utilized a zig-zag join. The bug could only reproduce on tables with at least two multi-column indexes with nullable columns. The bug was present since v19.2.0. #71824
- Fixed a rare deadlock on system ranges that could happen when an internal transaction
COMMIT
/ROLLBACK
that was a no-op (did not make any writes) triggered gossip data propagation. #71978 - Previously, some instances of a broken client connection could cause an infinite loop while processing commands from the client. This is now fixed. #72004
Contributors
This release includes 10 merged PRs by 6 authors.
v21.2.0-rc.2
Release Date: October 25, 2021
Downloads
CockroachDB v21.2.0-rc.2 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-rc.2
Changelog
View a detailed changelog on GitHub: v21.2.0-rc.1...v21.2.0-rc.2
Bug fixes
- The Transaction page no longer crashes when a statement is not found. #71599
- Fixed certificate bundle building logic. #71593
- Fixed an internal error with joins that are both
LATERAL
andNATURAL
/USING
. #70801
Contributors
This release includes 5 merged PRs by 5 authors.
v21.2.0-rc.1
Release Date: October 18, 2021
Downloads
CockroachDB v21.2.0-rc.1 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-rc.1
Changelog
View a detailed changelog on GitHub: v21.2.0-beta.4...v21.2.0-rc.1
Security updates
- It is no longer possible to use node TLS certificates to establish a SQL connection with any username other than
node
. This had existed as a way for an operator to use the node certificate to perform operations on behalf of another SQL user. However, this isn't necessary: an operator with access to a node cert can log in asnode
directly and create new credentials for another user. By removing this facility, we tighten the guarantee that the principal in the TLS client cert always matches the SQL identity. #71188 - Multi-tenant SQL servers now reuse the tenant client certificate (
client-tenant.NN.crt
) for SQL-to-SQL communication. Existing deployments must regenerate the certificates with dual purpose (client and server authentication). #71402
SQL language changes
- SQL tenants will now spill to disk by default when processing large queries, instead of to memory. #71218
Command-line changes
cockroach mt start-sql
will now support the following flags to configure ephemeral storage for SQL when processing large queries:--store
,--temp-dir
, and--max-disk-temp-storage
. #71218cockroach mt start-sql
will now support the--max-sql-memory
flag to configure maximum SQL memory capacity to store temporary data. #71276
DB Console changes
- Non-Admin users of the DB Console have regained the ability to view the Cluster Overview page. Users without the Admin role will still see most data about their nodes, but information such as command-line arguments, environment variables, and IP addresses and DNS names of nodes will be hidden. #71383
Bug fixes
- Fixed a bug that caused the optimizer to erroneously discard
WHERE
filters when executing prepared statements, causing incorrect results to be returned. This bug was present since version v21.1.9. #71118 - In Enterprise clusters that are upgraded to this version, fixed a bug that prevents changefeeds and backups from being exercised as of a point in time prior to the upgrade. #71319
- Fixed a bug from an earlier v21.2 beta whereby a migration to create the
system.statement_statistics
table was not run. #71477
Contributors
This release includes 18 merged PRs by 13 authors.
v21.2.0-beta.4
Release Date: October 11, 2021
Downloads
CockroachDB v21.2.0-beta.4 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-beta.4
Changelog
View a detailed changelog on GitHub: v21.2.0-beta.3...v21.2.0-beta.4
Enterprise edition changes
- Fixed a bug that could have led to duplicate instances of a single changefeed job running for prolonged periods of time. #70921
SQL language changes
- The cluster settings
sql.telemetry.query_sampling.qps_threshold
, andsql.telemetry.query_sampling.sample_rate
have been removed. A new setting,sql.telemetry.query_sampling.max_event_frequency
has been introduced, with a default value of 10 events per second. #70960 - EXPLAIN ANALYZE (DEBUG) now returns an error for non-system tenants, since we cannot yet support it correctly. #70949
Command-line changes
- Version details have been added to all JSON formatted log entries. Refer to the reference for details about the field. #70450
DB Console changes
- Removed the link to Statement Details on the Session table #70805
- A new column, Interval Start Time (UTC), has been added to both the Statements and Transactions tables. The column represents the start time in UTC of the statistics aggregation interval for a statement. By default, the aggregation interval is 1 hour. Interval Start Time has been added to the Statement details page. A new query parameter has been added to Statement details page. If the search param
aggregated_ts
is set, it will display the statement details for statements aggregated at that interval. If unset, it will display the statement details for the statement aggregated over the date range. #70895 - The Terminate Session and Terminate Statement buttons have been temporarily disabled on the Sessions page. #71014
- Updated color, fonts, and spaces on the Statements, Statements Details, Transactions, Transactions Details, and Sessions pages #71020
- Fixed a bug where the Clock Offset graph rendered incorrectly on nodes with multiple stores. #70468
- Fixed a bug where replicas awaiting to be garbage collected were causing the Range Report page to not load at all due to a JS error. The page will now load and display an empty Replica Type while in this state. #70211
Bug fixes
- The selected app name in the Statements page of the DB Console is now derived from the route parameters. #71024
- Fixed a bug that addresses an issue in Pebble where a key can be dropped from an LSM snapshot if the key was deleted by a range tombstone after the snapshot was acquired. #70969
- The Statement details page in the Cloud console now filters statements by the provided
aggregated_ts
query parameter. #71081 - The SQL layer no longer panics under memory pressure when the query profiler is enabled. #71007
Contributors
This release includes 29 merged PRs by 17 authors.
v21.2.0-beta.3
Release Date: October 4, 2021
Downloads
CockroachDB v21.2.0-beta.3 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-beta.3
Changelog
View a detailed changelog on GitHub: v21.2.0-beta.2...v21.2.0-beta.3
SQL language changes
SHOW JOBS
will now include the newly added columns fromcrdb_internal.jobs
(last_run
,next_run
,num_runs
, andexecution_errors
). The columns capture state related to retries, failures, and exponential backoff. #70791
DB Console changes
- On the Statement Details page, CockroachDB now shows info not yet sampled as unavailable, instead of with a value of
0
. #70569 - On the
EXPLAIN
plan tab in the Statement Details page, users can now hover over underlinedEXPLAIN
plan attributes to get tooltips with more information on the attribute. #70631 - Persisted statements are now enabled for tenants. In the Statements and Transactions pages, users now view the aggregated statistics for statements and transactions over a date range. A date range selector is present in both pages in order to select the range of persisted stats to view. Note that the two pages share a single date range. #70777
- Removed last cleared status from the Statements, Transactions, and Transaction Details pages and updated the tooltip on clear SQL stats to indicate it will also clear the persisted data. #70777
- For URLs on the Statement Details page, the app name and database name are now query string parameters. The route to statement details is now definitively
/statement/:implicitTxn/:statement?{queryStringParams}
, e.g.,statement/true/SELECT%20city%2C%20id%20FROM%20vehicles%20WHERE%20city%20%3D%20%241?database=movr&app=movr
#70804
Bug fixes
- Fixed a problem where the TPC-C workload, when used in a multi-region setup, did not properly assign workers to the local partitions. #70613
- Fixed styling issues in the tooltip text on the Statements and Transactions pages' table columns. #70650
- Fixed a bug where
EXPLAIN (VEC)
on some queries could lead to a crash. The bug was present only in v21.2 testing releases. #70524 - The Statements and Transactions pages are now able to display and reset persisted SQL stats. #70777
- Fixed a bug where the exit status of the
cockroach
command did not follow the previously-documented table of exit status codes when an error occurred during the command startup. Only errors occurring after startup were reported using the correct code. This bug had existed ever since reference exit status codes were introduced. #70676
Contributors
This release includes 26 merged PRs by 18 authors.
v21.2.0-beta.2
Release Date: September 27, 2021
Downloads
CockroachDB v21.2.0-beta.2 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-beta.2
Changelog
View a detailed changelog on GitHub: v21.2.0-beta.1...v21.2.0-beta.2
Security updates
- SQL tenant servers will now use a TLS certificate for their HTTP server when it's present. Previously this server never used TLS. #70056
SQL language changes
- The query logging enabled by
sql.telemetry.query_sampling.enabled
now avoids considering SQL statements issued internally by CockroachDB itself. #70358 IMPORT INTO
now supports UDT for default and computed columns. #70270IMPORT INTO
regional by row tables is now supported. #70270
Operational changes
- The meaning of the recently introduced
transaction_rows_written_err
andtransaction_rows_read_err
(as well as the corresponding_log
variables) have been adjusted to indicate the largest number of rows that is still allowed. In other words, originally reaching the limit would result in an error, and now only exceeding the limit would. #70014
Command-line changes
It is now possible to mix and match severity filters for different channels on a single log sink. For example:
file-groups: monitoring: channels: {WARNING: [OPS, STORAGE], INFO: HEALTH}
This defines a single file sink "monitoring" which captures all messages from the
HEALTH
channel, and only messages at severityWARNING
or higher from theOPS
andSTORAGE
channels.Another example:
file-groups: default: channels: {INFO: all except STORAGE, WARNING: STORAGE}
This captures all messages on all channels except the
STORAGE
channel, plus the messages at severityWARNING
or higher fromSTORAGE
. Note: the previous syntax remains supported. Whenchannel
is specified without explicit severities, thefilter
attribute is used as the default (like previously). #70411The default logging configuration now redirects the
HEALTH
logging channel to a distinct log file (cockroach-health.log
). #70411The default logging configuration now redirects the output on the
SQL_SCHEMA
channel to a new separate file groupsql-schema
(cockroach-sql-schema.log
), and thePRIVILEGES
andUSER_ADMIN
channels to a new separate file groupsecurity
(cockroach-security.log
). The newsecurity
group has theauditable
flag set. As previously, the administrator can inspect the default configuration withcockroach debug check-log-config
. #70411The server logging configuration now also includes a copy of messages from all logging channels at severity
WARNING
or higher into the default log file. This ensures that severe messages from all channels are also included in the main log file used during troubleshooting. #70411
DB Console changes
- Added tooltips on the Databases page and made the SQL box scrollable. #70070
- Added a column selector to the Transactions page. #70286
- Updated the Jobs table style to match all other tables on the Console and also updated the column name from
Users
toUser
. #70449
Bug fixes
- Columns that were hidden by default were not being displayed when selected. This commit fixes the behavior. #70054
- Fixed all broken links to documentation. #70063
- Temporary tables were not properly cleaned up for tenants. This is now fixed. #70129
- DNS unavailability during range 1 leaseholder loss will no longer cause significant latency increases for queries and other operations. #70135
- Last Execution Timestamp is now properly updating. #70297
- Fixed a bug in full cluster restores where dropped descriptor revisions would cause the restore to fail. #70368
- Default columns were displayed on the Statements page on the CockroachCloud console when the user never made any selection. This is now fixed. #70206
cockroach mt start-proxy
now appropriately sets the .ServerName member of outgoing TLS connections. This allows the proxy to function appropriately when the--insecure
and--skip-verify
CLI flags are omitted. #70290
Contributors
This release includes 44 merged PRs by 22 authors.
v21.2.0-beta.1
Release Date: September 24, 2021
This testing release includes a known bug. We do not recommend upgrading to this release. The v21.2.0-beta.2 release includes a fix for the bug.
Downloads
CockroachDB v21.2.0-beta.1 is a testing release. Testing releases are intended for testing and experimentation only, and are not qualified for production environments and not eligible for support or uptime SLA commitments.
Experimental downloads are not qualified for production use and not eligible for support or uptime SLA commitments, whether they are for testing releases or production releases.
Full CockroachDB executable
The CockroachDB executable for Windows is experimental and not suitable for production deployments. Windows 8 or higher is required.
Docker image
To download the Docker image (Intel-only):
docker pull cockroachdb/cockroach-unstable:v21.2.0-beta.1
Backward-incompatible changes
- Previously, CockroachDB only supported the YMD format for parsing timestamps from strings. It now also supports the MDY format to better align with PostgreSQL. A timestamp such as
1-1-18
, which was previously interpreted as2001-01-18
, will now be interpreted as2018-01-01
. To continue interpreting the timestamp in the YMD format, the first number can be represented with 4 digits,2001-1-18
. #64381 - The deprecated setting
cloudstorage.gs.default.key
has been removed, and the behavior of theAUTH
parameter in Google Cloud StorageBACKUP
andIMPORT
URIs has been changed. The default behavior is now that ofAUTH=specified
, which uses the credentials passed in theCREDENTIALS
parameter, and the previous default behavior of using the node's implicit access (via its machine account or role) now requires explicitly passingAUTH=implicit
. #64737 - Switched types from
TEXT
to"char"
for compatibility with postgres in the following columns:pg_constraint
(confdeltype
,confmatchtype
,confudptype
,contype
)pg_operator
(oprkind
),pg_prog
(proargmodes
),pg_rewrite
(ev_enabled
,ev_type
),pg_trigger
(tgenabled
) #65101
Security updates
- Certain HTTP debug endpoints reserved to
admin
users now return more details about range start/end keys, such as the "hot ranges" report. #63748 - The cluster setting
server.remote_debugging.mode
has been removed. The debug endpoints are now available to every client with access to the HTTP port. All the HTTP URLs previously affected by this setting already have user authentication and require a user to be logged in as a member of theadmin
role, so there was no need for an additional layer of security. #63748 - There is now a cache for per-user authentication-related information. The data in the cache is always kept up-to-date because it checks if any change to the underlying authentication tables has been made since the last time the cache was updated. The cached data includes the user's hashed password, the
NOLOGIN
role option, and theVALID UNTIL
role option. #66919 - The
--cert-principal-map
flag now allows the certificate principal name to contain colons. #67703 - Added the
admin
-only debugging built-in functionscrdb_internal.read_file
andcrdb_internal.write_file
to read/write bytes from/to external storage URIs used byBACKUP
orIMPORT
. #67427 - The certificate loader now allows the loading of
root
-owned private keys, provided the owning group matches the group of the (non-root
) user running CockroachDB. #68182 - Old authentication web session rows in the
system.web_sessions
table no longer accumulate indefinitely in the long run. These rows are periodically deleted. Refer to the documentation for details about the new cluster settings forsystem.web_sessions
. #67547 - The error returned during a failed authentication attempt will now include the
InvalidAuthorizationSpecification
PostgreSQL error code (28000
). #69106
General changes
- CockroachDB now supports new debug endpoints to help users with troubleshooting. #69594
- The
kv.closed_timestamp.closed_fraction
andkv.follower_read.target_multiple
settings are now deprecated and turned into no-ops. They had already stopped controlling the closing of timestamps in v21.1, but were still influencing thefollower_read_timestamp()
computation for a timestamp that's likely to be closed on all followers. To replace them, a simplerkv.closed_timestamp.propagation_slack
setting is introduced, modeling the delay between when a leaseholder closes a timestamp and when all the followers become aware of it (defaults conservatively to 1s).follower_read_timestamp()
is now computed askv.closed_timestamp.target_duration
+kv.closed_timestamp.side_transport_interval
+kv.closed_timestamp.propagation_slack
, which defaults to 4.2s (instead of the previous default of 4.8s). #69775 - Added documentation for Cluster API v2 endpoints. #62560
- Added
crdb_internal.create_join_token()
SQL built-in function to create join tokens for use when joining new nodes to a secure cluster. This functionality is hidden behind a feature flag. #62053 - Added Cluster API v2 endpoints for querying databases, tables, users, and events in a database. #63000
- All SQL-level cluster settings have been made public. #66688
- The setting
kv.transaction.write_pipelining_max_outstanding_size
is now a no-op. Its function is folded into thekv.transaction.max_intents_bytes
setting. #66915 - Introduced a
/_status/regions
endpoint which returns all regions along with their availability zones. #67098 crdb_internal.regions
is now accessible from a tenant. #67098- The behavior for retrying jobs, which fail due to a retryable error or due to job coordinator failure, is now delayed using exponential backoff. Before this change, jobs that failed in a retryable manner would be resumed immediately on a different coordinator. This change reduces the impact of recurrently failing jobs on the cluster. This change adds two new cluster settings that control this behavior:
jobs.registry.retry.initial_delay
andjobs.registry.retry.max_delay
, which respectively control initial delay and maximum delay between resumptions. #66889 - Previously, non-cancelable jobs, such as schema-change jobs, could fail while reverting due to transient errors, leading to unexpected results. Now, non-cancelable reverting jobs are retried instead of failing when transient errors are encountered. This mitigates the impact of temporary failures on non-cancelable reverting jobs. #69087
- Added new columns in the
crdb_internal.jobs
table that show the current backoff state of a job and its execution log. The execution log consists of a sequence of job start and end events and any associated errors that were encountered during each job's execution. Now users can query the internalcrdb_internal.jobs
table to get more insights about jobs through the following columns:last_run
shows the last execution time of a job;next_run
shows the next execution time of a job based on exponential-backoff delay;num_runs
shows the number of times the job has been executed; andexecution_log
provides a set of events that are generated when a job starts and ends its execution. #68995 - When jobs encounter retryable errors during execution, they will now record these errors into their state. The errors, as well as metadata about the execution, can be inspected via the newly added
execution_errors
field ofcrdb_internal.jobs
, which is aSTRING[]
column. #69370
Enterprise edition changes
- Added new
DEBUG_PAUSE_ON
option toRESTORE
jobs to allow for self pause on errors. #69422 - Changefeed option values are now case insensitive. #69217
- Performance for changefeeds during some range-split operations is now improved. #66312
- Cloud storage sinks for Enterprise changefeeds are no longer experimental. #69787
- Kafka sink URIs now accept the
topic_name
parameter to override per-table topic names. #62377 SHOW BACKUP
now shows whether the backup is full or incremental under thebackup_type
column. #63832- Previously, if a restore cluster mismatched the regions in backup cluster, the data would be restored as if the zone configuration did not exist. CockroachDB now checks the regions before restore, making users aware of mismatched regions between backup and restore clusters. If there is a mismatched region, users can either update cluster localities or restore with the
--skip-localities-check
option to continue. #64758 - Added
ca_cert
as a query parameter to the Confluent registry schema URL to trust custom certs on connection. #65431 - Changefeeds will now report more schema registry connection problems immediately at job creation time. #65775
- Changefeeds can now be started with the
mvcc_timestamp
option to emit the MVCC timestamp of each row being emitted. This option is similar to theupdated
option, but themvcc_timestamp
will always contain the row's MVCC timestamp, even during the changefeed's initial backfill. #65661 - Introduced a new webhook sink (prefix
webhook-https
) to send individual changefeed messages as webhook events. #66497 RESTORE
now supports restoring individual tables into a multi-region database. If the table being restored is also multi-region,REGIONAL BY ROW
tables cannot be restored, andREGIONAL BY TABLE
tables can only be restored if their localities match those of the database they're being restored into. #65015- Changefeeds don't attempt to use protected timestamps when running in a multi-tenant environment. #67285
- New 'on_error' option to pause on non-retryable errors instead of failing. #68176
- Changefeeds no longer fail when started on
REGIONAL BY ROW
tables. Note that inREGION BY ROW
tables, thecrdb_region
column becomes part of the primary index. Thus, changing an existing table toREGIONAL BY ROW
will trigger a changefeed backfill with new messages emitted using the new composite primary key. #68229 - Descriptor IDs of every object are now visible in
SHOW BACKUP
, along with the descriptor IDs of the object's database and parent schema.SHOW BACKUP
will display these IDs if theWITH debug_ids
option is specified. #68540 - The changefeed Avro format is no longer marked as experimental. #68818
- Changefeed statements now error if the provided sink URL does not contain a scheme. Such URLs are typically a mistake and will result in non-functional changefeeds. #68978
- Added
WITH REASON = <reason>
toPAUSE JOB
to gain visibility into why a job was paused by allowing pauses to be attached to a reason string. This reason is then persisted in the payload of the job and can be queried later. #68909 - Because the
SELECT
database privilege is being deprecated, CockroachDB now additionally checks for theCONNECT
privilege on the database to allow for backing up the database. Existing users withSELECT
on the database can still back up the database, but it is now recommended toGRANT
CONNECT
on the database. #68391 - Added a
webhook_sink_config
JSON option to configure batching and flushing behavior, along with retry behavior for webhook sink changefeed messages. #68633 - Changefeeds will now error if an option is used with an incompatible sink. #69173
- Fixed a bug where changefeeds would fail to correctly handle a primary key change. #69234
- Changefeeds now correctly account for memory during backfills and "pushback" under memory pressure—that is, slow down backfills. #69388
- Changefeeds will now slow down correctly whenever there is a slow-down in the system (i.e., downstream sink is slow). #68288
- Changefeeds will now flush the sink only when frontier advances. This eliminates unnecessary sink flushes. #67988
- Improved changefeed scalability, particularly when running against large tables, by reducing the rate of job progress updates. #67815
- Changefeeds can resume during backfill without losing too much progress. #66013
SQL language changes
- To perform
REASSIGN OWNED BY
, the current user running the command must now be a member of both the old and new roles. Previously the new owner would need: to be a member of theCREATEDB
role if the object being changed was a database,CREATE
privileges for the database if the object being changed was a schema, orCREATE
privileges for the schema if object being changed was a table or type. #69382 - The SQL stats compaction job now only shows up in the output of
SHOW AUTOMATIC JOBS
. #69641 DROP
s,RENAME
s, and other light schema changes are no longer user cancelable to avoid scenarios that do not properly rollback. #69328- Users can now opt to disable auto-rehoming for a session by setting
on_update_rehome_row_enabled = false
. This can be permanently unset by default using the cluster settingsql.defaults.on_update_rehome_row.enabled
. #69626 - It is now possible to alter the owner of the
crdb_internal_region
type, which is created by initiating a multi-region database. #69722 - Added more detail to the error message users receive when they call
SHOW BACKUP
with a path pointing to the root of the collection, rather than a specific backup in the collection. #69638 - Introduced a new cluster setting
sql.stats.persisted_rows.max
and increased its default value to1000000
(1,000,000 rows). #69667 - Previously, users had no way of determining which objects in their database utilized deprecated features like interleaved indexes/tables or cross-database references. Added crdb_internal tables
cross_db_references
,interleaved_indexes
, andinterleaved_tables
for detecting these deprecated features within a given database. #61629 - The
sql.defaults.vectorize_row_count_threshold
cluster setting, as well as the correspondingvectorize_row_count_threshold
session variable, have been removed. From now on, CockroachDB will behave exactly as if these were set to0
(last default value). #62164 - Updated
crdb_internal.interleaved
to add theparent_table_name
column replacing theparent_index_name
column. #62076 - CockroachDB now references sequences used in views by their IDs to allow these sequences to be renamed. #61439
- Added
SQLType
to classifyDDL
,DML
,DCL
, orTCL
statement types. #62989 - Implemented the geometry-based built-in
ST_IsValidTrajectory
. #63072 - CockroachDB now accepts UUID inputs that have a hyphen after any group of four digits. This aligns with the UUID format used by PostgreSQL. For example,
a0ee-bc99-9c0b-4ef8-bb6d-6bb9-bd38-0a11
is now considered a valid UUID. #63137 - The
gen_ulid
anduuid_ulid_to_string
built-ins are now available for use. #62440 - Single-key spans in
EXPLAIN
andEXPLAIN (DISTSQL)
are now shown without a misleading dash after them. #61583 - Enabled locality-optimized search in the row execution engine. #63384
- CockroachDB now should be more stable when executing queries with subqueries producing many rows (previously it could OOM crash; it wil now use the temporary disk storage). #63900
- Correlated common table expressions (CTEs) can now be used. #63956
- Introduced a new session variable
distsql_workmem
that determines how much RAM a single operation of a single query can take before the operation must spill to disk. This is identical to thesql.distsql.temp_storage.workmem
cluster setting but has the session-level scope. #63959 crdb_internal.node_statement_statistics
now storesstatement_id
. #64076- Added line to the
EXPLAIN ANALYZE
output to show disk spill usage to make it clear when disk spilling occurs executing a query. This output is only shown when the disk usage is greater than zero. The verbiage in the DistSQLEXPLAIN
diagrams changed frommax scratch disk allocated
tomax sql temp disk usage
for consistency and to match the way we talk about SQL spill disk usage elsewhere. #64137 - Previously, committing a transaction when a portal was suspended would cause a "multiple active portals not supported" error. Now, the portal is automatically destroyed. #63677
- Bulk IO operations are no longer included in service latency metrics. #64442
- Collated strings may now have a locale that is a language tag, followed by a
-u-
suffix, followed by anything else. For example, any locale with a prefix ofen-US-u-
is now considered valid. #64695 - Added new tables to
pg_catalog
:pg_partitioned_table
,pg_replication_origin_status
,pg_init_privs
,pg_replication_slots
,pg_policy
,pg_sequences
,pg_subscription_rel
,pg_largeobject_metadata
. #64035 - Added new columns to
pg_catalog
tables:pg_class
(relminmxid
),pg_constraint
(conparentid
). #64035 - Using the table name as a projection now works, e.g.,
SELECT table_name FROM table_name
orSELECT row_to_json(table_name) FROM table_name
. #64748 - Added
generate_series
forTIMESTAMPTZ
values. #64887 - Added the
sql.defaults.require_explicit_primary_keys.enabled
cluster setting for requiring explicit primary keys inCREATE TABLE
statements. #64951 - SQL service latency now only includes metrics from DML statements. #64893
- Added support for using
OPERATOR(operator)
for binary expressions. This only works for in-built CockroachDB operators. #64701 - Introduced the
OPERATOR
syntax for unary operators. This only works for unary operators usable in CockroachDB. #64701 - Implemented the geometry built-in function
ST_LineCrossingDirection
. #64997 - Added the
pg_relation_is_updatable
andpg_column_is_updatable
built-in functions #64788 information_schema.columns.data_type
now returns "USER-DEFINED
" when the column is a user-defined type (e.g.,ENUM
) #65154- CockroachDB now supports the scalar functions
get_byte()
andset_byte()
as in PostgreSQL. #65189 - CockroachDB now supports converting strings of hexadecimal digits prefixed by
x
orX
to a BIT value, in the same way as PostgreSQL. Note that only the conversion via casts is supported (e.g.,'XAB'::BIT(8)
); PostgreSQL's literal constant syntax (e.g.,X'AB'::BIT(8)
) continues to have different meaning in CockroachDB (byte array) due to historical reasons. #65188 SHOW JOBS
now shows thetrace_id
of the trace that is associated with the current execution of the job. This allows pulling inflight traces for a job for debugging purposes. #65322- The vectorized execution engine now supports the ntile window function. #64977
- Pg_sequences table was implemented on pg_catalog #65420
- A constant can now be cast to regclass without first converting the constant to an OID. E.g., 52::regclass can now be done instead of 52::oid::regclass. #65432
- References to WITH expressions from correlated subqueries are now always supported. #65550
- Added new
SHOW CHANGEFEED JOBS
command with additional information about changefeeds for improved user visibility. #64956 - This is strictly a change for docgen and sql grammar. Now all sql.y statements (excluding those that are unimplemented or specified to be skipped) will have automatically have a stmtSpec defined for them and thus will have a bnf and svg file automatically generated in cockroachdb/generated-diagrams. #65278
- The vectorized execution engine now supports the
lag
andlead
window functions. #65634 - The total number of statement/transaction fingerprints stored in-memory can now be limited using the cluster settings
sql.metrics.max_mem_stmt_fingerprints
andsql.metrics.max_mem_txn_fingerprints
. #65902 - Previously, SQL commands that were sent during the PostgreSQL extended protocol that were too big would error opaquely. This is now resolved by returning a friendlier error message. #57590
- Namespace entries may no longer be queried via
system.namespace2
. #65340 EXPLAIN ANALYZE
output now includes, for each plan step, the total time spent waiting for KV requests as well as the total time those KV requests spent contending with other transactions. #66157- Added the
SHOW CREATE DATABASE
command to get database metadata. #66033 - Added
sample_plan
,database_name
, andexec_node_ids
columns to thecrdb_internal.node_statement_statistics
table. This allows for third-party and partner consumption of this data. #65782 - Implemented
pg_rewrite
for table-view dependencies. Table-view dependencies are no longer stored directly inpg_depend
. #65495 - Added some virtual tables
crdb_internal.(node|cluster)_distsql_flows
that expose the information about the flows of the DistSQL execution scheduled on remote nodes. These tables do not include information about the non-distributed queries or about local flows (from the perspective of the gateway node of the query). #65727 - The use order of columns in a foreign key no longer needs to match the order the columns were defined for the reference table's unique constraint. #65209
- Previously, in some special cases (
UPSERT
s, as documented in this issue), the support of the distinct operations was missing in the vectorized execution engine. This has been added, and such operations will be able to spill to disk if necessary. However, in case the distinct operator does, in fact, spill to disk, there is a slight complication. The order in which rows are inserted can be non-deterministic: for example, for a query such asINSERT INTO t VALUES (1, 1), (1, 2), (1, 3) ON CONFLICT DO NOTHING
, witht
having the schemaa INT PRIMARY KEY, b INT
, it is possible that any of the three rows are actually inserted. PostgreSQL appears to have the same behavior. #61582 - Added three new views to the
crdb_internal schema
to support developers investigating contention events:cluster_contended_{tables, indexes, keys}
. #66370 - Implemented
similar_escape
and madesimilar_to_escape
compatible with PostgreSQL. #66578 - The
"char"
column type will now truncate long values, in line with PostgreSQL. #66422 - The contents of the statistics table in the information schema have changed; therefore, so have the results of
SHOW INDEX
andSHOW COLUMNS
. A column that is not in the primary key will now be listed as belonging to the primary index as a stored column. Previously, it was simply not listed as belonging to the primary index. #66599 - Adding empty missing tables on
information_schema
for compatibility:attributes
,check_constraint_routine_usage
,column_column_usage
,column_domain_usage
,column_options
,constraint_table_usage
,data_type_privileges
,domain_constraints
,domain_udt_usage
,domains
,element_types
,foreign_data_wrapper_options
,foreign_data_wrappers
,foreign_server_options
,foreign_servers
,foreign_table_options
,foreign_tables
,information_schema_catalog_name
,role_column_grants
,role_routine_grants
,role_udt_grants
,role_usage_grants
,routine_privileges
,sql_features
,sql_implementation_info
,sql_parts
,sql_sizing
,transforms
,triggered_update_columns
,triggers
,udt_privileges
,usage_privileges
,user_defined_types
,user_mapping_options
,user_mappings
,view_column_usage
,view_routine_usage
,view_table_usage
. #65854 - The
SHOW QUERIES
command was extended for prepared statements to show the actual values in use at query time, rather than the previous$1
,$2
, etc. placeholders. We expect showing these values will greatly improve the experience of debugging slow queries. #66689 - Populated the
pg_type
table with entries for each table. Also populatedpg_class.reltypid
with the correspondingoid
in thepg_type
table. #66815 - Added a virtual table
crdb_internal.cluster_inflight_traces
which surfaces cluster-wide inflight traces for thetrace_id
specified via an index constraint. The output of this table is not appropriate to consume over a SQL connection; follow-up changes will add CLI wrappers to make the interaction more user-friendly. #66679 - Added support for
iso_8601
andsql_standard
as usable session variables inIntervalStyle
. Also added asql.defaults.intervalstyle
cluster setting to be used as the default interval style. #67000 - Added a cluster setting
sql.defaults.primary_region
, which assigns aPRIMARY REGION
to a database by default. #67168 - Introduced a cluster setting
sql.allow_drop_final_region.enabled
which disallows dropping of aPRIMARY REGION
(the final region of a database). #67168 IMPORT TABLE
will be deprecated in v21.2 and removed in a future release. Users should create a table usingCREATE TABLE
and thenIMPORT INTO
the newly created table. #67275- CockroachDB now uses
JSONB
instead ofBYTES
to store statement plans insystem.statement_statistics
. #67331 - Reduced instantaneous memory usage during scans by up to 2x. #66376
- Added the session variable
backslash_quote
for PostgreSQL compatibility. Setting this does a no-op, and onlysafe_encoding
is supported. #67343 - Introduced a
crdb_internal.regions
table which contains data on all regions in the cluster. #67098 - When parsing intervals,
IntervalStyle
is now taken into account. In particular,IntervalStyle = 'sql_standard'
will make all interval fields negative if there is a negative symbol at the front, e.g.,-3 years 1 day
would be-(3 years 1 day)
insql_standard
and-3 days, 1 day
in PostgreSQLDateStyle
. #67210 ROLLBACK TO SAVEPOINT
can now be used to recover fromLockNotAvailable
errors (pgcode
55P03
), which are returned when performing aFOR UPDATE SELECT
with aNOWAIT
wait policy. #67514- Added tables to
information_schema
that are present on MySQL. The tables are not populated and are entirely empty.column_statistics
,columns_extensions
,engines
,events
,files
,keywords
,optimizer_trace
,partitions
,plugins
,processlist
,profiling
,resource_groups
,schemata_extensions
,st_geometry_columns
,st_spatial_reference_systems
,st_units_of_measure
,table_constraints_extensions
,tables_extensions
,tablespaces
,tablespaces_extensions
,user_attributes
. #66795 - Added new built-ins
compress(data, codec)
anddecompress(data, codec)
which can compress and decompress bytes with the specified codec.Gzip
is the only currently supported codec. #67426 - The column types of the results of
SHOW LAST QUERY STATISTICS
(an undocumented statement meant mostly for internal use by CockroachDB's SQL shell) has been changed fromINTERVAL
toSTRING
. They are populated by the durations of the various phases of executions as if the duration, as anINTERVAL
, was converted toSTRING
using the 'postgres
'IntervalStyle
. This ensures that the server-side execution timings are always available regardless of the value of theIntervalStyle
session variable. #67654 - Changed
information_schema.routines
data types at columnsinterval_precision
,result_cast_char_octet_length
andresult_cast_datetime_precision
toINT
. #67641 - Added syntax for granting and revoking privileges for all the tables in the specified schemas. New supported syntax:
GRANT {privileges...} ON ALL TABLES IN SCHEMA {schema_names...} TO {roles...}
;REVOKE {privileges...} ON ALL TABLES IN SCHEMA {schema_names...} TO {roles...}
. This command is added for PostgreSQL compatibility. #67509 - Added
pg_stat_database
andpg_stat_database_conflicts
topg_catalog
. #66687 - A database that is restored with the cluster setting
sql.defaults.primary_region
will now have thePRIMARY REGION
from the cluster setting assigned to the database. #67581 - The vectorized execution engine now supports
CASE
expressions that outputBYTES
-like types. #66399 - Introduced the
with_min_timestamp
andwith_max_staleness
built-in functions. In aSELECT
clause, they return the same timestamp and(now() - interval)
, but are intended for use inAS OF SYSTEM TIME
, which will appear in an upcoming update. #67697 first_value
,last_value
, andnth_value
window functions can now be executed in the vectorized execution engine. This allows for faster execution time, and also removes the need for conversions to and from row format. #67764- Improved performance of lookup joins in some cases. If join inequality conditions can be matched to index columns, CockroachDB now includes the conditions in the index lookup spans and removes them from the runtime filters. #66002
- Added support for
ALTER DEFAULT PRIVILEGES
and default privileges stored on databases. All objects created in a database will have the privilege set defined by the default privileges for that type of object on the database. The types of objects areTABLES
,SEQUENCES
,SCHEMAS
,TYPES
. Example:ALTER DEFAULT PRIVILEGES GRANT SELECT ON TABLES TO foo
makes it such that all tables created by the user that executed theALTER DEFAULT PRIVILEGES
command will haveSELECT
privilege on the table for userfoo
. Additionally, one can specify a role. Example:ALTER DEFAULT PRIVILEGES FOR ROLE bar GRANT SELECT ON TABLES TO foo
. All tables created by bar will haveSELECT
privilege forfoo
. If a role is not specified, it uses the current user. For further context, see the PostgreSQL documentation. Currently, default privileges are not supported on the schema. Specifying a schema likeALTER DEFAULT PRIVILEGES IN SCHEMA s
will error.WITH GRANT OPTION
is ignored.GRANT OPTION FOR
is also ignored. #66785 - Introduced a
nearest_only
argument forwith_min_timestamp
/with_max_staleness
, which enforces that bounded staleness reads only talk to the nearest replica. #67837 CREATE TABLE LIKE
now copies hidden columns over. #67799- Populated
pg_catalog.pg_default_acl
. This is important for tracking which default privileges are defined in the database.pg_catalog.pg_default_acl
has 5 columns:oid
(oid
): row identifierdefaclrole
(oid
):oid
of the role the default privileges are defined fordefaclnamespace
(oid
):oid
of the schema the default privileges are defined indefaclobjtype
(char
):r
= relation (table
,view
),S
= sequence,f
= function,T
= type,n
= schemadefaclacl
(aclitem[]
): string representation of default privileges, following the format "$1
=$2
/$3
" where$1
is the grantee's username,$2
is a list of characters representing the privileges, and$3
is the grantor (which is currently always an empty string in CockroachDB).
aclitem[]
representation.CREATE
= 'C
'SELECT
= 'r
'INSERT
= 'a
'DELETE
= 'd
'UPDATE
= 'w
'USAGE
= 'U
'CONNECT
= 'c
'
char
representations and the PostgreSQL definition ofpg_catalog.pg_default_acl
. #67872 - An earlier commit changed CockroachDB to use the value of the
IntervalStyle
session var when interpreting interval to string conversions. However, this madestring::interval
andinterval::string
casts have a volatility of "stable" instead of "immutable". This has ramifications for items such as computed columns and check clauses, which cannot use immutable expressions. This means that the particular results returned by these queries can become incoherent whenIntervalStyle
is customized to a different value from its default,postgres
. In order to provide guardrails against this incoherence, CockroachDB now provides a new, separate configuration knob calledintervalstyle_enabled
that applications can use to "opt in" the ability to customize IntervalStyle:- By default, this knob is false and applications cannot customize
IntervalStyle
. Interval to string conversions that are already stored in the schema are unaffected and continue to produce results as per the default stylepostgres
. - When the knob is true, these things happen:
- Apps can start customizing
IntervalStyle
in SQL sessions. - A SQL session that has a custom
IntervalStyle
will start observing incoherent results when accessing tables that already contain a conversion from interval to string.
sql.defaults.intervalstyle.enabled
. This is the knob that operators and DBAs should customize manually. Then, as a secondary configuration mechanism, the value of the cluster setting is also copied to each SQL session as a new session varintervalstyle_enabled
. This is a performance optimization. SQL apps should not modify this session var directly, except for temporary testing purposes. In v22.1, upgrades will be disabled if these stable expressions are found in computed columns, check clauses, etc. #67792 - By default, this knob is false and applications cannot customize
- Previously,
OPERATOR(+)int
would simplify to+int
when parsed, which would lead to re-reproducibility issues when considering order of operators. This is now fixed by leavingOPERATOR(+)
in the tree. #68041 - Previously, pretty printing could fold some
OPERATOR
expressions based on the order of operations of the operator inside theOPERATOR
. This can lead to a different order of operations when reparsing, so this is fixed by never foldingOPERATOR
expressions. #68041 - Added the
SHOW CREATE SCHEDULE
command to view SQL statements used to create existing schedules. #66782 - Created a built-in to reset the zone configurations of multi-region tables. This built-in can be helpful in cases where the user has overridden the zone configuration for a given table and wishes to revert back to the original system-specified state. #67985
- Implemented the
parse_interval
andto_char_with_style
built-ins, which convert strings from/to intervals with immutable volatility. #67970 - Casting from interval to string or vice-versa is now blocked for computed columns, partial indexes, and partitions when the
intervalstyle_enabled
session setting is enabled. Instead, usingto_char_with_style(interval, style)
orparse_interval(interval, intervalstyle)
is available as a substitute. This is enforced in v22.1, but is opt-in for v21.2. It is recommended to set the cluster settingsql.defaults.intervalstyle_enabled
totrue
to avoid surprises when upgrading to v22.1. #67970 - Common aggregate functions can now be executed in the vectorized execution engine. This allows for better memory accounting and faster execution in some cases. #68081
- Retry information has been added to the statement trace under the
exec stmt
operation. The trace message is in the format: "executing afterretries, last retry reason: ". This message will appear in any operations that show the statement trace, which is included in operations such as SHOW TRACE FOR SESSION
and is also exported in the statement diagnostics bundle. #67941 - Added empty
pg_stat*
tables onpg_catalog
:pg_stat_all_indexes
,pg_stat_all_tables
,pg_stat_archiver
,pg_stat_bgwriter
,pg_stat_gssapi
,pg_stat_progress_analyze
,pg_stat_progress_basebackup
,pg_stat_progress_cluster
,pg_stat_progress_create_index
,pg_stat_progress_vacuum
,pg_stat_replication
,pg_stat_slru
,pg_stat_ssl
,pg_stat_subscription
,pg_stat_sys_indexes
,pg_stat_sys_tables
,pg_stat_user_functions
,pg_stat_user_indexes
,pg_stat_user_tables
,pg_stat_wal_receiver
,pg_stat_xact_all_tables
,pg_stat_xact_sys_tables
,pg_stat_xact_user_functions
,pg_stat_xact_user_tables
,pg_statio_all_indexes
,pg_statio_all_sequences
,pg_statio_all_tables
,pg_statio_sys_indexes
,pg_statio_sys_sequences
,pg_statio_sys_tables
,pg_statio_user_indexes
,pg_statio_user_sequences
,pg_statio_user_tables
. #67947 - Added syntax for
ALTER ROLE ... SET
statements. The business logic for these statements is not yet implemented, but will be added in a later commit. The following forms are supported:ALTER ROLE { name | ALL } [ IN DATABASE database_name ] SET var { TO | = } { value | DEFAULT }
,ALTER ROLE { name | ALL } [ IN DATABASE database_name ] RESET var
,ALTER ROLE { name | ALL } [ IN DATABASE database_name ] RESET ALL
. As with other statements, the keywordsROLE
andUSER
are interchangeable. This matches the PostgreSQL syntax. #68001 BACKUP
now supports backing up tables in a specified schema (e.g.,BACKUP my_schema.*
, ormy_db.my_schema.*
). Schemas will be resolved before databases, somy_object.*
will resolve to a schema of that name in the current database before matching a database with that name. #67649- Added support for a new index hint,
NO_ZIGZAG_JOIN
, which will prevent the optimizer from planning a zigzag join for the specified table. The hint can be used in the same way as other existing index hints. For example,SELECT * FROM table_name@{NO_ZIGZAG_JOIN};
. #68141 - Added a
cardinality
built-in function that returns the total number of elements in a given array. #68263 - Introduced a new cluster setting
jobs.trace.force_dump_mode
that allows users to configure Traceable jobs to dump their traces:never
: Job will never dump its traces.onFail
: Job will dump its trace after transitioning to thefailed
state.onStatusChange
: Job will dump its trace whenever it transitions from paused, canceled, succeeded or failed state. #67386
- DMY and YMD
DateStyles
are now supported. #68093 - When the date value is out of range, a hint now suggests that the user try a different
DateStyle
. #68093 - When
DateStyle
andIntervalStyle
are updated, this will now send aParamStatusUpdate
over the wire protocol. #68093 - Added support to alter default privileges for all roles. The syntax supported is
ALTER DEFAULT PRIVILEGES FOR ALL ROLES grant_default_privs_stmt/revoke_default_privs_stmt.
Onlyadmin
users are able to execute this. This allows adding default privileges for objects that are created by ANY role, as opposed to having to specify a creator role to which the default privileges will apply when creating an object. Example:ALTER DEFAULT PRIVILEGES FOR ALL ROLES GRANT SELECT ON TABLES TO foo;
. Regardless of whichever user now creates a table in the current database,foo
will haveSELECT
. #68076 - Added a
crdb_internal.reset_multi_region_zone_configs_for_database
built-in to reset the zone configuration of a multi-region database. This built-in can be helpful in cases where the user has overridden the zone configuration for a given database and wishes to revert back to the original system-specified state. #68280 - The session setting
optimizer_improve_disjunction_selectivity
and its associated cluster settingsql.defaults.optimizer_improve_disjunction_selectivity.enabled
are no longer supported. They were added in v21.1.7 to enable better optimizer selectivity calculations for disjunctions. This logic is now always enabled. #68349 - Running
ALTER ROLE
on any role that is a member ofadmin
now requires theadmin
role. Previously, any user with theCREATEROLE
option couldALTER
anadmin
. #68187 - Introduced an
hlc_to_timestamp
built-in, which converts a CockroachDB HLC to aTIMESTAMPTZ
. This is useful for pretty printingcrdb_internal_mvcc_timestamp
orcluster_logical_timestamp()
, but is not useful for accuracy. #68360 - Added a
crdb_internal.default_privileges
table that is useful for getting a human-readable way of examining default privileges. #67997 - Added support for
SHOW DEFAULT PRIVILEGES
andSHOW DEFAULT PRIVILEGES FOR ROLE ...
. If a role(s) is not specified, default privileges are shown for the current role.SHOW DEFAULT PRIVILEGES
returns the following columns:schema_name
,role
,object_type
,grantee
,privilege_type
. #67997 - The
pg_db_role_setting
table of thepg_catalog
is now implemented. WhenALTER ROLE ... SET var
is used to configure per-role defaults, these default settings will be populated inpg_db_role_setting
. This table contains the same data no matter which database the current session is using. For more context, see the PostgreSQL documentation. #68245 - Removed the
count
column from thesystem.statement_statistics
andsystem.transaction_statistics
tables. #67866 - Introduced the
crdb_internal.index_usage_statistics
virtual table to surface index usage statistics. Thesql.metrics.index_usage_stats.enabled
cluster setting can be used to turn on/off the subsystem. It defaults totrue
. #66640 - The
bulkio.backup.proxy_file_writes.enabled
cluster setting is no longer needed to enable proxied writes, which are now the default. #68468 - Default session variable settings configured by
ALTER ROLE ... SET
are now supported. The following order of precedence is used for variable settings:- Settings specified in the connection URL as a query parameter
- Per-role and per-database settings configured by
ALTER ROLE
- Per-role and all-database settings configured by
ALTER ROLE
- All-role and per-database settings configured by
ALTER ROLE
- All-role and all-database settings configured by
ALTER ROLE
RESET
does not validate the setting name.SET
validates both the name and the proposed default value. Note that the default settings for a role are not inherited if one role is a member of another role that has default settings. Also, the defaults only apply during session initialization. UsingSET DATABASE
to change databases does not apply default settings for that database. Thepublic
,admin
, androot
roles cannot have default session variables configured. Theroot
role also will never use the "all-role" default settings. This is so thatroot
has fewer dependencies during session initialization and to make it less likely forroot
authentication to become unavailable during the loss of a node. Changing the default settings for a role requires the role running theALTER
command to either be anADMIN
or to have theCREATEROLE
role option. OnlyADMIN
s can edit the default settings for another admin. Futhermore, changing the default settings forALL
roles is only allowed forADMIN
s. Roles withoutADMIN
orCREATEROLE
cannot change the default settings for themselves. #68128 - An earlier commit changed CockroachDB to use the value of the
DateStyle
session var when interpreting date to string conversions (and vice-versa). However, this madestring::{date,timestamp}
and{date,timetz,time,timestamp}::string
casts have a volatility of "stable" instead of "immutable". This has ramifications for items such as computed columns and check clauses, which cannot use immutable expressions. This means that the particular results returned by these queries can become incoherent whenDateStyle
is customized to a different value from its default,ISO,MDY
. In order to provide guardrails against this incoherence, CockroachDB now provides a new, separate configuration knob calleddatestyle_enabled
that applications can use to "opt in" the ability to customize DateStyle:- By default, this knob is false and applications cannot customize
DateStyle
. Invalid conversions that are already stored in the schema are unaffected and continue to produce results as per the default stylepostgres
. - When the knob is true, these things happen:
- Apps can start customizing
DateStyle
in SQL sessions. - A SQL session that has a custom
DateStyle
will start observing incoherent results when accessing tables that already contain the aforementioned casts. - New schemas cannot have the above casts.
- Apps can start customizing
sql.defaults.datestyle.enabled
. This is the knob that operators and DBAs should customize manually. Then as a secondary configuration mechanism, the value of the cluster setting is also copied to each SQL session as a new session vardatestyle_enabled
. This is a performance optimization. SQL apps should not modify this session var directly, except for temporary testing purposes. In v22.1, upgrades will be disabled if these stable expressions are found in computed columns, check clauses, etc. #68352 - By default, this knob is false and applications cannot customize
- Introduced
parse_interval
andto_char
, which takes in 1 string or interval and assumes the PostgreSQLIntervalStyle
to make its output. #68351 parse_timestamp
now has a two-argument variant, which takes in aDateStyle
and parses timestamps according to thatDateStyle
. The one argument version assumes MDY. These built-ins have an immutable volatility. #68351- Introduced a
timestamp,DateStyle
variant toto_char_with_style
, which converts timestamps to a string with an immutable volatility. There is also a 1 argto_char
for timestamp values which assumes theISO,MDY
output style. #68351 - Introduced a
parse_date
built-in with two variants. The single-argument variant parses a date and assumesISO,MDY
datestyle, and the two-argument variant parses a date assuming theDateStyle
variant on the second argument. This provides an immutable way of casting strings to dates. #68351 - Introduced
to_char(date)
, which assumes aDateStyle
ofISO,MDY
and outputs date in that format. There is also ato_char_with_style(date, DateStyle)
variant which outputs the date in the chosenDateStyle
. This provides an immutable way of casting dates to strings. #68351 - Implemented the
parse_time
andparse_timetz
built-ins, which parses aTIME
orTIMETZ
with immutable volatility. #68351 - Some queries with lookup joins and/or top K sorts are now more likely to be executed in "local" manner with the
distsql=auto
session variable. #68524 - SQL stats now can be persisted into
system.statement_statistics
andsystem.transaction_statistics
tables by enabling thesql.stats.flush.enable
cluster setting. The interval of persistence is determined by the newsql.stats.flush.interval
cluster setting, which defaults to 1 hour. #67090 - The
lock_timeout
session variable is now supported. The configuration can be used to abort a query with an error if it waits longer than the configured duration while blocking on a single row-level lock acquisition. #68042 - Added support for
GENERATED {ALWAYS | BY DEFAULT} AS IDENTITY
syntax in a column definition. This will automatically create a sequence for the given column. This matches PostgreSQL syntax and functionality. For more context, see the PostgreSQL documentation. #68711 - A scan over an index and then join on the primary index to retrieve required columns now have improved performance in the vectorized execution engine. #67450
SHOW DEFAULT PRIVILEGES FOR ALL ROLES
is now supported as a syntax. Show default privileges returns a second columnfor_all_roles
(bool
) which indicates whether or not the default privileges shown are for all roles. #68607SHOW DEFAULT PRIVILEGES
now only shows default privileges for the current user. #68607- If a user has a default privilege defined for, they cannot be dropped until the default privilege is removed. Example:
ALTER DEFAULT PRIVILEGES FOR ROLE test1 GRANT SELECT ON TABLES TO test2;
. Neithertest1
nortest2
can be dropped until performingALTER DEFAULT PRIVILEGES FOR ROLE test1 REVOKE SELECT ON TABLES FROM test2;
. #67950 - Added new metrics to track schema job failure:
sql.schema_changer.errors.all
,sql.schema_changer.errors.constraint_violation
,sql.schema_changer.errors.uncategorized
; errors inside thecrdb_internal.feature_usage
table. #68252 - Indexes on expressions can now be created. These indexes can be used to satisfy queries that contain filters with identical expressions. For example,
SELECT * FROM t WHERE a + b = 10
can utilize an index likeCREATE INDEX i ON t ((a + b))
. #68807 - Roles with the name
none
and starting withpg_
orcrdb_internal
can no longer be created. Any existing roles with these names may continue to work, but they may be broken when new features (e.g.,SET ROLE
) are introduced. #68972 - Implemented the geometry-based built-in
ST_Translate
on arguments{geometry, float8,float8,float8}
. #68959 - Errors involving
MinTimestampBoundUnsatisfiableError
during a bounded staleness read now get a custompgcode
(54C01
). #68967 - Table statistics are no longer collected for views. #68997
- Added support for
SCHEMA
comments using PostgreSQL'sCOMMENT ON SCHEMA
syntax. #68606 SET ROLE user
now parses without an equal betweenROLE
and=
. This functionality is not yet implemented. #68750- Allowed
RESET ROLE
to be parsed. This is not yet implemented. #68750 - Added a
session_user()
built-in function, which currently returns the same thing ascurrent_user()
, as we do not implementSET ROLE
. #68749 - Introduced new
crdb_internal.statement_statistics
virtual table that surfaces both cluster-wide in-memory statement statistics as well as persisted statement statistics. #68715 - The regrole
OID
alias type is now supported, which is a PostgreSQL-compatible object identifier alias that references thepg_catalog.pg_authid
table. #68877 - CockroachDB now correctly sends the
RESET
tag instead of theSET
tag when aRESET
statement is run. #69053 - Bounded staleness reads now retry transactions when
nearest_only=True
and a schema change is detected which may prevent a follower read from being served. #68969 - Granting
SELECT
,UPDATE
,INSERT
,DELETE
on databases is being deprecated. The syntax is still supported, but is automatically converted to the equivalentALTER DEFAULT PRIVILEGES FOR ALL ROLES
command. The user is given a notice that the privilege is incompatible and automatically being converted to anALTER DEFAULT PRIVILEGE FOR ALL ROLES
command. #68391 - The syntax for setting database placement is now
ALTER DATABASE db PLACEMENT ...
. (TheSET
keyword is no longer allowed before thePLACEMENT
keyword.) #69067 - The
ALTER DATABASE db SET var ...
syntax is now supported. It is a syntax alias forALTER ROLE ALL IN DATABASE db SET var ...
, since it is identical to that functionality: it configures the default value to use for a session variable when a user connects to the given database. #69067 - Implemented the
crdb_internal.serialize_session()
andcrdb_internal.deserialize_session(bytes)
built-ins. The former outputs the session settings in a string that can be deserialized into another session by the latter. #68792 - Added a cluster setting
schedules.backup.gc_protection_enabled
that defaults totrue
and enables chaining of GC protection across backups run as part of a schedule. #68446 crdb_internal.pb_to_json
now does not emit default values by default. #69185- Implemented
pg_shdepend
with shared dependencies with tables, databases and pinned user/roles. #68018 - Added a built-in function
crdb_internal.datums_to_bytes
, which can encode any data type which can be used in an forward index key into bytes in an immutable way. This function is now used in the expression for hash-sharded indexes. #67865 - Introduced a new
crdb_internal.transaction_statistics
virtual table that surfaces both cluster-wide in-memory transaction statistics as well as persisted transaction statistics. #69049 - Introduced
SET ROLE
, which allows users with certain permissions to assume the identity of another user. It is worth noting that due to cross-version compatibility,session_user
will always return the same ascurrent_user
until v22.1. Instead, usesession_user()
if you require this information. #68973 - An
ON UPDATE
expression can now be added to a column. Whenever a row is updated without modifying theON UPDATE
column, the column'sON UPDATE
expression is re-evaluated, and the column is updated to the result. #69091 - Roles have a default set of default privileges. For example, a role has
ALL
privileges on all objects as its default privileges when it creates the object. Additionally, thepublic
role hasUsage
is a default privilege. This matches PostgreSQL's behavior such that the creator role andpublic
role have the same set of default privileges in the default state. Now, when a user creates a table, sequence, type, or schema, it will automatically haveALL
privileges on it, andpublic
will haveUSAGE
on types. This can be altered:ALTER DEFAULT PRIVILEGE FOR ROLE rolea REVOKE ALL ON ... FROM rolea
will remove the default set of default privileges on the specified object from the role. #68500 SHOW DEFAULT PRIVILEGES
shows implicit privileges. Implicit privileges are "default" default privileges. For example, the creator should have all privileges on any object that it creates. This is now reflected inSHOW DEFAULT PRIVILEGES
. #69377- Added a
system.span_configurations
table. This will later be used to store authoritative span configs. #69047 - Added support for
GENERATED {ALWAYS | BY DEFAULT} AS IDENTITY (seq_option)
syntax underCREATE TABLE
. AnIDENTITY
column is an auto-incremented column based on an automatically created sequence, with the same performance considerations as theCREATE SEQUENCE
syntax. Theseq_option
is consistent with the sequence option syntax inCREATE SEQUENCE
, and we also supportCACHE
inseq_option
for better performance. Hence, such a column can only be ofinteger
type, and is implicitlyNOT NULL
. It is essentially the same asSERIAL
withserial_normalization=sql_sequence
, except for user access to override it. AGENERATED ALWAYS AS IDENTITY
column cannot be overridden without specifyingOVERRIDING SYSTEM VALUE
in anINSERT
/UPSERT
/UPDATE
statement. This overriding issue cannot be resolved by theON CONFLICT
syntax. Such a column can only be updated toDEFAULT
. AGENERATED BY DEFAULT AS IDENTITY
column allows being overridden without specifying any extra syntax, and users are allowed to add repeated values to such a column. It can also be updated to customized expression, but only acceptsinteger
type expression result.GENERATED {ALWAYS | BY DEFAULT} AS IDENTITY
is also supported underALTER TABLE ... ADD COLUMN ...
syntax. This matches the PostgreSQL syntax. #69107 - Added
transaction_fingerprint_id
tosystem.statement_statistics
primary key. #69320 - Introduced
crdb_internal.schedule_sql_stats_compaction()
to manually create SQL Stats compaction schedule. Extended theSHOW SCHEDULES
command to supportSHOW SCHEDULES FOR SQL STATISTICS
. #68401 - The cluster setting
sql.defaults.experimental_auto_rehoming.enabled
and session settingexperimental_enable_auto_rehoming
were added to enable auto-rehoming onUPDATE
forREGIONAL BY ROW
tables. #69381 SHOW is_superuser
now works, and is set to true if the user hasroot
privileges. #69224- Introduced
SET LOCAL
, which sets a session variable for the duration of the transaction.SET LOCAL
is a no-op outside the transaction. #69224 SET LOCAL
now works forSAVEPOINT
s.ROLLBACK
will rollback any variables set duringSET LOCAL
.RELEASE TO SAVEPOINT
will continue to use the variables set bySET LOCAL
in the transaction. #69224- Interleaved syntax for
CREATE TABLE
/INDEX
is now a no-op, since support has been removed. #69304 crdb_internal.reset_sql_stats()
now resets persisted SQL Stats. #69273- Changed the
plan_hash
column in bothsystem.statement_statistics
andcrdb_internal.statement_statistics
fromInt
toBytes
. #69502 - Added the optional
IF NOT EXISTS
clause to theCREATE SCHEDULE
statement, making the statement idempotent. #69152 SHOW is_superuser
now works, and is set to true if the user hasadmin
privileges. #69355- The
set_config
built-in function now allows thelocal
parameter to be true. This is the same as usingSET LOCAL
. #69480 - Added a new
as_json
option toSHOW BACKUP
which renders the backup manifest as JSON value. #62628 - Added a new
EXPLAIN
flag,MEMO
, to be used withEXPLAIN (OPT)
. When theMEMO
flag is passed, a representation of the optimizer memo will be printed along with the best plan. TheMEMO
flag can be used in combination with other flags such asCATALOG
andVERBOSE
. For example,EXPLAIN (OPT, MEMO, VERBOSE)
will print the memo along with verbose output for the best plan.
Operational changes
- New session variable
large_full_scan_rows
, as well as the corresponding cluster settingsql.defaults.large_full_scan_rows
, are now available. This setting determines which tables are considered "large" for the purposes of enablingdisallow_full_table_scans
feature to reject full table/index scans only of "large" table. The default value for the new setting is1000
, and in order to reject all full table/index scans (the previous behavior) one can set the new setting to0
. Internally issued queries aren't affected, and the new setting has no impact whendisallow_full_table_scans
feature is not enabled. #69371 - Introduced new metric called
txn.restarts.commitdeadlineexceeded
that tracks the number of transactions that were forced to restart because their commit deadline was exceeded (COMMIT_DEADLINE_EXCEEDED
). #69671 - The default value of the
storage.transaction.separated_intents.enabled
cluster setting was changed totrue
. #64831 - Node-level admission control that considers the CPU resource was introduced for KV request processing, and response processing (in SQL) for KV responses. This admission control can be enabled using
admission.kv.enabled
andadmission.sql_kv_response.enabled
. #65614 - The new cluster setting
bulkio.backup.merge_file_size
allowsBACKUP
to buffer and merge smaller files to reduce the number of small individual files created byBACKUP
. #66856 - Increased the timeout for range MVCC garbage collection from 1 minute to 10 minutes, to allow larger jobs to run to completion. #65001
- MVCC and intent garbage collection now triggers when the average intent age is 8 hours, down from 10 days. #65001
- Added a
server.authentication_cache.enabled
cluster setting that defaults totrue
. When enabled, this cache stores authentication-related data and will improve the latency of authentication attempts. Keeping the cache up to date adds additional overhead when using theCREATE
,ALTER
, andDROP ROLE
commands. To minimize the overhead, any bulkROLE
operations should be run inside of a transaction. To make the cache more effective, any regularly-scheduledROLE
updates should be done all together, rather than occurring throughout the day at all times. #66919 - Introduced a new metric
exportrequest.delay.total
to track how longExportRequests
(issued byBACKUP
) are delayed by throttling mechansisms. #67310 - Enabling
admission.kv.enabled
may provide better inter-tenant isolation for multi-tenant KV nodes. #67533 debug.zip
files no longer contain the filethreads.txt
, which was previously used to list RocksDB background threads. #67389- DistSQL response admission control can now be enabled using the cluster setting
admission.sql_sql_response.enabled
. #67531 - Added the
kv.bulk_sst.target_size
andkv.bulk_sst.max_allowed_overage
cluster settings that control the batch size used by export requests duringBACKUP
. #67705 RESTORE
no longer dynamically reads from thekv.bulk_ingest.batch_size
cluster setting to determine its batch size. If the value is updated,RESTORE
jobs need to bePAUSE
d andRESUME
d to adopt the updated setting. #68105- The memory pool used for SQL is now also used to cover KV memory used for scans. #66362
- CockroachDB now records a log event and counter increment when removing an expired session. #68476
- Added an automatically created, on by default, emergency ballast file. This new ballast defaults to the minimum of 1% total disk capacity or 1GiB. The size of the ballast may be configured via the
--store
flag with aballast-size
field, accepting the same value formats as thesize
field. Also, added a newDisk Full (10)
exit code that indicates that the node exited because disk space on at least one store is exhausted. On node start, if any store has less than half the ballast's size bytes available, the node immediately exits with theDisk Full (10)
exit code. The operator may manually remove the configured ballast (assuming they haven't already) to allow the node to start, and they can take action to remedy the disk space exhaustion. The ballast will automatically be recreated when available disk space is 4x the ballast size, or at least 10 GiB is available after the ballast is created. #66893 - Added a new cluster setting,
sql.mutations.max_row_size.log
, which controls large row logging. Whenever a row larger than this size is written (or a single column family if multiple column families are in use) aLargeRow
event is logged to theSQL_PERF
channel (or aLargeRowInternal
event is logged toSQL_INTERNAL_PERF
if the row was added by an internal query). This could occur forINSERT
,UPSERT
,UPDATE
,CREATE TABLE AS
,CREATE INDEX
,ALTER TABLE
,ALTER INDEX
,IMPORT
, orRESTORE
statements.SELECT
,DELETE
,TRUNCATE
, andDROP
are not affected by this setting. #67953 - Added a new cluster setting,
sql.mutations.max_row_size.err
, which limits the size of rows written to the database (or individual column families, if multiple column families are in use). Statements trying to write a row larger than this will fail with a code54000 (program_limit_exceeded)
error. (Internal queries writing a row larger than this will not fail, but will log aLargeRowInternal
event to the SQL_INTERNAL_PERF channel.) This limit is enforced for INSERT, UPSERT, and UPDATE statements.CREATE TABLE
AS, CREATE INDEX, ALTER TABLE, ALTER INDEX, IMPORT, andRESTORE
will not fail with an error, but will log LargeRowInternal events to theSQL_INTERNAL_PERF
channel.SELECT
,DELETE
,TRUNCATE
, andDROP
are not affected by this limit. Note that existing rows violating the limit cannot be updated, unless the update shrinks the size of the row below the limit, but can be selected, deleted, altered, backed-up, and restored. For this reason we recommend using the accompanying settingsql.mutations.max_row_size.log
in conjunction withSELECT pg_column_size()
queries to detect and fix any existing large rows before loweringsql.mutations.max_row_size.err
. #67953 - The new cluster settings
admission.l0_sub_level_count_overload_threshold
andadmission.l0_file_count_overload_threshold
can be used to tune admission control. #69311 - The new cluster settings
sql.defaults.transaction_rows_written_log
,sql.defaults.transaction_rows_written_err
,sql.defaults.transaction_rows_read_log
, andsql.defaults.transaction_rows_read_err
(as well as the corresponding session variables) have been introduced. These settings determine the "size" of the transactions in written and read rows upon reaching of which the transactions are logged or rejected. The logging will go into theSQL_PERF
logging channel. Note that the internal queries (i.e., those issued by CockroachDB internally) cannot error out but can be logged instead intoSQL_INTERNAL_PERF
logging channel. The "written" limits apply toINSERT
,INSERT INTO SELECT FROM
,INSERT ON CONFLICT
,UPSERT
,UPDATE
, andDELETE
whereas the "read" limits apply toSELECT
statement in addition to all of these. These limits will not apply toCREATE TABLE AS
,SELECT
,IMPORT
,TRUNCATE
,DROP
,ALTER TABLE
,BACKUP
,RESTORE
, orCREATE STATISTICS
statements. Note that enablingtransaction_rows_read_err
guardrail comes at the cost of disabling the usage of the auto commit optimization for the mutation statements in implicit transactions. #69202 - The
cockroach debug tsdump
command now downloads histogram timeseries it silently omitted previously. #69469 - New variables
sql.mutations.max_row_size.{log|err}
were renamed tosql.guardrails.max_row_size_{log|err}
for consistency with other variables and metrics. #69457 - Improved range feed observability by adding a
crdb_internal.active_range_feeds
virtual table which lists all currently executing range feeds on the node. #69055 - Upgrading to the next version will be blocked if interleaved tables/indexes exist. Users should convert existing interleaved tables/indexes to non-interleaved ones or drop any interleaved tables/indexes before upgrading to the next version. #68074
- Added support for the DataDog tracer. Set the
trace.datadog.agent
cluster setting to enable it if you have got the DataDog collector service running. #61602 - Upgraded the Lightstep tracer version, resulting in better observability for Lightstep users. #61593
- Added four new metrics,
sql.guardrails.max_row_size_{log|err}.count{.internal}
, which are incremented whenever a large row violates the correspondingsql.guardrails.max_row_size_{log|err}
limit. #69457
Command-line changes
- Added
load show
args to display subset of backup metadata. Users can display subsets of metadata of a single manifest by usingload show files/descriptors/metadata/spans <backup_url>
. #61131 - Updated
load show
withsummary
subcommand to display meta information of an individual backup. Users are now able to inspect backup metadata, files, spans, and descriptors with the CLI commandcockroach load show summary <backup_url>
without a running cluster. #61131 - Updated
load show
withincremental
subcommand to display incremental backups. Users can list incremental backup paths of a full backup by runningcockroach load show incremental <backup_url>.
#61862 - Added
load show backups
to display backup collection. Previously, users could list backups created byBACKUP INTO
viaSHOW BACKUP IN
in a SQL session. But this listing task can be also done offline without a running cluster. Now, users are able to list backups in a collection withcockroach load show backups <collection_url>
. #61862 - The command
cockroach sysbench
has been removed. Users who depend on this command can use a copy of acockroachdb
executable binary from a previous version. #62305 - The number of connection retries and connection timeouts for configurations generated by
cockroach gen haproxy
have been tweaked. #62308 - Extended
load show
withload show data
subcommand to display backup table data. By runningcockroach load show data <table> <backup_url>
, users are able to inspect data of a table in backup. Also, added--as-of
flag toload show data
command. Users are able to show backup snapshot data at a specified timestamp by runningcockroach load show data <table> <backup_url> --as-of='-1s'
#62662 - Updated
load show data
command to display backup data in CSV format. Users can either pipe the output to a file or specify the destination by a--destination
flag. #62662 - Previously,
load show summary
would output results in an unstructured way, which made it harder to filter information.load show summary
now outputs the information in JSON format, which is easier to handle and can be filtered through another command-line JSON processor. #63100 - Previously,
--as-of
ofload show data
had the restriction that users could only inspect data at an exact backup timestamp. The flag has improved to work with backups with revision history so that users can inspect data at an arbitrary timestamp. #63181 - Certain errors caused by invalid command-line arguments are now printed on the process' standard error stream, instead of standard output. #63839
- The
cockroach gen autocomplete
command has been updated and can now produce autocompletion definitions for thefish
shell. #63839 - Previously, backup inspection was done via
cockroach load show ..
, which could confuse users with ambiguous verbs in the command chain. The syntax is now more clear and indicative for users debugging backups. The changes are:load show summary <backup_url>
->debug backup show <backup_url>
;load show incremental <backup_url>
->debug backup list-incremental <backup_url>
;load show backups <collection_url>
->debug backup list-backups <collection_url>
;load show data <table_name> <backup_url>
->debug backup export <backup_url> --table=<table_name>
. #63309 - Previously,
\demo shutdown <node_idx>
would error if--global
was set. This will now error gracefully as an unsupported behavior. #62435 - The
--global
flag forcockroach demo
is now advertised. This flag simulates latencies in multi-node demo clusters when the nodes are set in different regions to simulate real-life global latencies. #62435 - There will now be a message upon start-up on
cockroach demo --global
indicating that latencies between nodes will simulate real-world latencies. #62435 - Added
--max-rows
and--start-key
ofcockroach backup debug
tool for users to specify on export row number and start key when inspecting data from backup. #64157 - Added
--with-revisions
ondebug export
to allow users to export revisions of table data. If--with-revisions
is specified, revisions of data are returned to users, with an extra column displaying the revision time of that record. This is an experimenal/beta feature of thecockroach backup debug
tool to allow users to export revisions of data from backup. #64285 - Renamed
connect
toconnect init
, and addedconnect join
command to retrieve certificates from an existing secure cluster and setup a new node to connect with it. #63492 - The
cockroach debug keys
command recognizes a new flag--type
that constrains types of displayed entries. This enables more efficient introspection of storage in certain troubleshooting scenarios. #64879 - Server health metrics are now a structured event sent to the
HEALTH
logging channel. For details about the event payload, refer to the reference documentation. #65024 - Server health metrics are now optimized for machine readability by being sent as a structured event to the
HEALTH
logging channel. For details about the event payload, refer to the reference documentation. #65024 - The
cockroach debug pebble
tool can now be used with encrypted stores. #64908 - Added a
cockroach debug job-trace
command that takes 2 arguments:<jobID>
and file destination, along with a--url
pointing to the node on which to execute this command against. The command pulls information about inflight trace spans associated with the job and dumps it to the file destination. #65324 The new subcommand
cockroach convert-url
converts a connection URL, such as those printed out bycockroach start
or included in the online documentation, to the syntax recognized by various client drivers. For example:$ ./cockroach convert-url --url "postgres://foo/bar" Connection URL for libpq (C/C++), psycopg (Python), lib/pq & pgx (Go), node-postgres (JS) and most pq-compatible drivers: postgresql://root@foo:26257/bar Connection DSN (Data Source Name) for Postgres drivers that accept DSNs - most drivers and also ODBC: database=bar user=root host=foo port=26257 Connection URL for JDBC (Java and JVM-based languages): jdbc:postgresql://foo:26257/bar?user=root
The URLs spelled out by
cockroach start
,cockroach start-single-node
, andcockroach demo
in various outputs now always contain a target database for the connection; for example,defaultdb
for regular servers. Certain drivers previously automatically filled in the name "postgres" if the database name field was empty. #65460The connection URLs spelled out by
cockroach start
,cockroach start-single-node
, andcockroach demo
in various outputs now include a variant suitable for use with JDBC client apps. #65460cockroach sql
andcockroach demo
now support the client-side parameterborder
likepsql
. #66253Added support for
cockroach debug ballast
on Windows. #66793The
cockroach import pgdump
command now recognizes custom target database names inside the URL passed via--url
. Additionally, the command now also accepts a--database
parameter. Using this parameter is equivalent to customizing the database inside the--url
flag. #66375cockroach debug job-trace
now creates ajob-trace.zip
which contains trace information for each node executing the job. #66914Added the
--recursive
or-r
flag to thecockroach userfile upload
CLI command allowing users to upload the entire subtree rooted at a specified directory to user-scoped file storage:userfile upload -r path/to/source/dir destination
. The destination can be expressed one of four ways:- Empty (not specified)
- A relative path, such as
path/to/dir
- A well-formed URI with no host, such as
userfile:///path/to/dir/
- A full well-formed URI, such as
userfile://db.schema.tablename_prefix/path/to/dir
userfile://defaultdb.public.userfiles_root/yourdirectory
. If the destination is a relative path such aspath/to/dir
, the default userfile URI schema and host will be used (userfile://defaultdb.public.userfiles_$user/
), and the relative path will be appended to it. For example:userfile://defaultdb.public.userfiles_root/path/to/dir
. If the destination is a well-formed URI with no host, such asuserfile:///path/to/dir/
, the default userfile URI schema and host will be used (userfile://defaultdb.public.userfiles_$user/
). For example:userfile://defaultdb.public.userfiles_root/path/to/dir
. If the destination is a full well-formed URI, such asuserfile://db.schema.tablename_prefix/path/to/dir
, then it will be used verbatim. For example:userfile://foo.bar.baz_root/path/to/dir
. #65307Previously, the
crdb-v2
log file format lacked a parser. This has now changed. #65633The
cockroach debug merge-logs
command now renders in color by default. #66629CockroachDB now supports a new logging channel called
TELEMETRY
. This will be used in later versions to report diagnostic events useful to Cockroach Labs for product analytics. (At the time of this writing, no events are defined for theTELEMETRY
channel yet.) When no logging configuration is specified, this channel is connected to file output, with a maximum retention of 1MiB. To also produce the diagnostic output elsewhere, one can define a new sink that captures this channel. For example, to see diagnostics reports on the standard error, one can use:--log='sinks: {stderr: {channels: TELEMETRY, filter: INFO}}'
When configuring file output, the operator should be careful to apply a separate maximum retention for theTELEMETRY
channel from other file outputs, as telemetry data can be verbose and outcrowd other logging messages. For example:--log='sinks: {file-groups: {telemetry: {channels: TELEMETRY, max-group-size: 1MB}, ...}}
. #66427Added the
cockroach debug statement-bundle recreate <zipdir>
command, which allows users to load a statement bundle into an in-memory database for inspection. #67979CockroachDB server nodes now report more environment variables in logs upon startup. Only certain environment variables that may have an influence on the server's behavior are reported. #66842
cockroach sql
andcockroach demo
now support the\c
/\connect
client-side command, in a way similar topsql
:\c
without arguments: display the current connection parameters.\c [DB] [USER] [HOST] [PORT]
connect using the specified parameters. Specify '-' to omit one parameter.\c URL
connect using the specified URL. For example:\c - myuser
to reconnect to the same server/db asmyuser
.
cockroach demo
. Note:\c <dbname>
reuses the existing server connection to change the current database, using aSET
statement. To force a network reconnect, use\c -
then\c <dbname>
, or use\c <dbname> -
. Note: When using the syntax with discrete parameters, the generated URL reuses the same TLS parameters as the original connection, including the CA certificate used to validate the server. To use different TLS settings, use\c <URL>
instead. #66258Added a new
HTTP
sink to the logging system. This can be configured similarly to other log sinks with the newhttp-servers
andhttp-defaults
sections of the logging config passed via the--log
or--log-config-file
command-line flags. #66196The
\c
client-side command incockroach sql
andcockroach demo
now always reconnects to the server even when only changing the current database. (This negates a part of a previous release note.) #68326cockroach demo
now recognizes the command-line flag--listening-url-file
likecockroach start
andcockroach start-single-node
. When specified, thedemo
utility will write a valid connection URL to that file after the test cluster has been initialized. This facility also makes it possible to automatically wait until the demo cluster has been initialized in automation; for example, by passing the name of a unix namedFIFO
via the new flag. #68706cockroach mt start-sql
now supports--advertise-addr
in the same fashion ascockroach start
. #69113cockroach debug decode-proto
now does not emit default values by default. #69185The
cockroach debug tsdump
command now accepts--from
and--to
flags that limit for which dates timeseries are exported. #69491Log file read and write permissions may now be set via the new
file-permissions
key in the--log
flag or--log-config-file
file. #69243Updated the output of
--locality
and--locality-addr
flags to use terms that match cloud provider names for things such as 'region' and 'zone'. #62381
API endpoint changes
- A list of node IDs representing the nodes that store data for the database has been added to the stats field in the database details endpoint under
nodeIds
. Database details must be requested withinclude_stats
set totrue
, e.g.,/_admin/v1/databases/{database}?include_stats=true
. Similarly,nodeIds
has also been added to the table stats endpoint, which is an ordered list of node ids that stores the table data:/_admin/v1/databases/{database}/tables/{table}/stats
#69788 - The
changefeed.poll_request_nanos
metric is no longer reported by the node status API, thecrdb_internal.metrics
table, or the Prometheus endpoint. #63935 - The transaction abort error reason
ABORT_REASON_ALREADY_COMMITTED_OR_ROLLED_BACK_POSSIBLE_REPLAY
has been renamed toABORT_REASON_RECORD_ALREADY_WRITTEN_POSSIBLE_REPLAY
. #67215 - A Stats message was added to the
admin
DatabaseDetails
response, providingRangeCount
andApproximateDiskBytes
in support of upcoming UI changes to the DB console. #67986 - Tenant pods now expose the Statements API at
/_status/statements
on their HTTP port. #66675 - Tenant pods now expose the ListSessions API at
/_status/sessions
on their HTTP port. #69376 - Added a new endpoint
/_status/combinedstmts
to retrieve persisted and in-memory statements fromcrdb_internal.statement_statistics
andcrdb_internal.transaction_statistics
by aggregated_ts range. The request supports optional query string parametersstart
andend
, which are the date range in unix time. The response returned is currently the response expected from/_status/statements
./_status/statements
has also been updated to support the parameterscombined
,start
, andend
. Ifcombined
istrue
, then the statements endpoint will use/_status/combinedstmts
with the optional parametersstart
andend
. #69238
DB Console changes
- A new column on the Database Page now shows the node and region information for each database. The Tables view now displays a summary section of the nodes and regions where the table data is stored. The new table columns and region/node sections are only displayed if there is more than one node. #69804
- Fixed duplicates of statements on the Transaction Details Page for multi-node clusters. #61771
- Changed copy that previously referred to the app as "Admin UI" to "DB Console" instead. #62452
- Users can now reset SQL stats from the DB Console. #63342
- Created new routes for statements. A database name can be passed on statements routes, so only statements executed on that particular database are displayed. Added a new function returning all databases that had at least one statement executed during the current statistics collection period. #64087
- The lease history section on the range report debug page now shows the type of lease acquisition event that resulted in a given lease. #63822
- Updated the DB Console to show information about the database on the Statements Page and ability to choose which columns to display. #64614
- The DB Console now shows information about the region of a node on the Transactions Page. #64996
- Added missing formatting for some event types displayed in the DB Console. #65717
- Changed the default event formatting to appear less alarming to users. #65717
- The Statement Details Page now displays information about nodes and regions a statement was executed on. #65126
- The Statements and Transactions pages now display information about nodes and regions a statement was executed on. #65126
- Changed time format on metrics events to 24-hour UTC time. #66277
- Removed styling width calculation from multiple bars. #66734
- Added a new chart showing the latency of establishing a new SQL connection, including the time spent on authentication. #66625
- The KV transaction restarts chart was moved from the Distributed metrics to the SQL Dashboard to be close to the Open SQL Transactions chart for more prominent visibility. #66973
- Fixed mislabelled tooltips on the Transactions and Transaction Details pages in DB console. #66605
- The DB Console now uses dotted underline on text that contains a tooltip. The 'i' icon was removed. #67023
- Added
""
to whitespace application names on filter selection on the Statements and Transactions pages. #66967 - Added a new Overload dashboard that groups metrics that are useful for admission control. #66595
- The SQL Statement Contention Time chart is surfaced more prominently on the SQL Dashboard. #66969
- Added a Full Table/Index Scans time series chart on the SQL Dashboard. #66972
- The 'threads' debugging page, previously used to inspect RocksDB threads, has been removed. #67389
- Fixed a color mismatch ont he node status badge on the Cluster Overview page. #68049
- Added a CES survey link component to support being able to get client feedback. #68429
- The Transaction Details Page's SQL box now shows all of a transaction's statements in the order that they were executed. The Transaction Details Page also no longer displays statement statistics. #68447
- Updated the Databases Page in the DB Console to bring them into alignment with our modern UX. #68390
The "Logical Plan" tab in the DB Console has been renamed "Explain Plan", and the displayed plan format has been updated to match the output of the
EXPLAIN
command in the SQL shell. GlobalEXPLAIN
properties have been added to the logical plan in the DB Console which were previously missing. TheEXPLAIN
format shown below should now be reflected in the DB Console:distribution: full vectorized: true • hash join │ estimated row count: 503 │ equality: (rider_id) = (id) │ ├── • scan │ estimated row count: 513 (100% of the table; stats collected 9 seconds ago) │ table: rides@primary │ spans: FULL SCAN │ └── • scan estimated row count: 50 (100% of the table; stats collected 1 minute ago) table: users@primary spans: FULL SCAN
Changed date times on the Jobs Page to use 24-hour UTC. #68916
Added admission control metrics to the Overload dashboard. #68595
Hid node and region information on the new tenant plan (serverless/free tier). #69444
Added a new date range selector component to the DB Console's Statements and Transactions pages with the ability to show historical data. The default date range is set to 1 hour ago, and is used as the value when users reset the date range. #68831
Fixed tooltip text on the Statements and Transactions pages to use the correct setting
diagnostics.sql_stat_reset.interval
instead of the previous value,diagnostics.reporting.interval
. #69577
Bug fixes
- Fixed a bug where cluster backups with revision history may have included dropped descriptors in the "current" snapshot of descriptors on the cluster. #68983
- Users can now only scroll in the content section of the Transactions Page, Statements Page, and Sessions Page. #69620
- Previously, when using
ALTER PRIMARY KEY
on a regional by row table, the copied unique index from the old primary key would not have the correct zone configurations applied. This is now resolved, but users who encountered this bug should re-create the index. #69681 - Fixed a bug that caused incorrect evaluation of the
IN
operator when the tuple on the right-hand side of the operator included a subquery, likea IN ('foo', (SELECT s FROM t), 'bar')
. #69651 - Fixed a bug where previously an internal error or a crash could occur when some
crdb_internal
built-in functions took string-like type arguments (e.g.,name
). #69698 - Previously, users would receive a panic message when the log parser failed to extract log file formats. This has been replaced with a helpful error message. #69018
- Fixed a bug to ensure that auxiliary tables used during cluster restore are garbage collected quickly afterwards. #67936
RESTORE
will now correctly ignore dropped databases that may have been included in cluster backups with revision history. #68551- Fixed a bug that can cause prolonged unavailability due to lease transfer to a replica that may be in need of a Raft snapshot. #69696
- Fixed a bug where resuming an active schedule would always reset its next run time. This was sometimes undesirable with schedules that had a
first_run
option specified. #69571 - Fixed a regression in statistics estimation in the optimizer for very large tables. The bug, which has been present since v20.2.14 and v21.1.7, could cause the optimizer to severely underestimate the number of rows returned by an expression. #69711
- The
raft.commandsapplied
metric is now populated again. #69857 - Fixed a bug where previously the store rebalancer was unable to rebalance leases for hot ranges that received a disproportionate amount of traffic relative to the rest of the cluster. This often led to prolonged single node hotspots in certain workloads that led to hot ranges. #65379
- Added protection to
IMPORT INTO
to guard against concurrent type changes on user-defined types referenced by the target table. #69674 - DNS unavailability during range 1 leaseholder loss will no longer cause significant latency increases for queries and other operations. b6fb0e626
Previously, using
SET
in a transaction and having the transaction retry internally could result in the previous session variable being unused. For example:SET intervalstyle = 'postgres'; BEGIN; do something with interval -- (1) SET intervalstyle = 'iso_8601'; do something with interval -- (2) COMMIT;
If the transaction retries at
COMMIT
, when attempting to re-run (1), we would have an interval style'iso_8601'
instead of the original'postgres'
value. This has now been resolved. #69554Envelope schema in Avro registry now honors
schema_prefix
andfull_table_name
. #60946Previously, a drop column would cause check constraints that are currently validating to become active on a table. This has been fixed. #62257
OpenTracing traces now work correctly across nodes. The client and server spans for RPCs are once again part of the same trace instead of the server erroneously being a root span. #62703
Fixed a bug which prevented
cockroach debug doctor zipdir
from validating foreign key information represented in the un-upgraded deprecated format. #62829Schema changes that include both a column addition and primary key change in the same transaction no longer result in a failed changefeed. #63217
Fixed a bug whereby transient clock synchronization errors could result in permanent schema change failures. #63671
Fixed a bug of
debug backup export
caused by inspecting table with multiple ranges. #63678Fixed a performance regression for very simple queries. #64225
Fixed a bug that prevented transactions which lasted longer than 5 minutes and then performed writes from committing. #63725
Added a fix to prevent a rare crash that could occur when reading data from interleaved tables. #64374
Fixed an "index out of range" internal error with certain simple queries. #65018
Hosts listed with the
connect --join
command-line flag now default to port26257
(was443
). This matches the existing behavior ofstart --join
. #65014CockroachDB now shows a correct error message if it tries to parse an interval that is out of range. #65377
Fixed a bug where
NaN
coordinates could makeShortestLine
/LongestLine
panic. #65445Fixed a bug whereby using an
enum
value as a placeholder in anAS OF SYSTEM TIME
query preceding a recent change to thatenum
could result in a fatal error. #65620Fixed a race condition where transaction cleanup would fail to take into account ongoing writes and clean up their intents. #65592
The Transactions Page now shows the correct value for implicit transactions. #65126
Fixed a bug where
TIMETZ
values would not display appopriately in the CLI. #65321Fixed a bug which prevented adding self-referencing
FOREIGN KEY
constraints in theNOT VALID
state. #65871The
cockroach mt start-sql
command with a nonexistent tenant ID now returns an error. Previously, it would crash and poison the tenant ID for future usage. #65683CockroachDB now correctly handles errors during the
pgwire
extended protocol. Specifically, when an error is detected while processing any extended protocol message, anErrorResponse
is returned; then the server reads and discards messages until aSync
command is received from the client. This matches the PostgreSQL behavior. #57590Fixed a bug where owners of a table have privileges to
SELECT
from it, but would return false onhas_*_privilege
-related functions. #65766Added a more accurate error message for restoring AOST before GC TTL. #66025
When a non-SQL CLI command (e.g.,
cockroach init
) was invoked with the--url
flag and the URL did not contain asslmode
parameter, the command was incorrecting defaulting to operate as if--insecure
was specified. This has been corrected. #65460The URLs printed out by the client-side command
\demo ls
incockroach demo
now properly include the workload database name, if any was created. #65460Fixed a bug where a superfluous unique constraint would be added to a table during a primary key change when the primary key change specified a new primary key constraint that involved the same columns in the same directions. #66225
Properly populated
crdb_internal.job
'scoordinator_id
field, which had not been properly populated since v20.2. #61417Fixed a bug in
SHOW ZONE CONFIGURATIONS
where long constraints fields may show\n
characters. #69470CockroachDB could previously error out when a query involving tuples with collated strings and NULLs was executed in a distributed manner. This is now fixed. #66337
Fixed a bug with PostgreSQL compatibility where dividing an interval by a number would round to the nearest Microsecond instead of always rounding down. #66345
Previously, rows treated as tuples in functions such as
row_to_json
may have had their keys normalized to lowercase, instead of being preserved in the original casing as per PostgreSQL. This is now fixed. #66535CockroachDB could previously crash when executing
EXPLAIN (VEC)
on some mutations. This is now fixed. #66569Fixed a bug that caused a panic for window functions operating in
GROUPS
mode withOFFSET PRECEDING
start and end bounds. #66582Fixed a bug on the chart catalog admin API. #66645
Fixed a deadlock during
adminVerifyProtectedTimestamp
. #66760Fixed a bug where a substring of a linestring with the same points would return
EMPTY
instead of aPOINT
with the repeated point. #66738Fixed a bug where it was possible for a linestring returned from
ST_LineSubString
to have repeated points. #66738Fixed an error occurring when executing
OPERATOR(pg_catalog.~)
. #66865Fixed
ST_LineSubstring
forLINESTRING EMPTY
panicking instead of returningnull
. #66936A migration will be run when users upgrade to v21.2 (specifically v21.2.14). This migration fixes any privilege descriptors that were corrupted from the fallout of the
ZONECONFIG
/USAGE
bug on tables and databases after upgrading from v20.1 to v20.2 (#65010) and those that were corrupted after converting a database to a schema (#65697). #66495Fixed a bug where job leases might be revoked due to a transient network error. #67075
Fixed a case where
IMPORT
would panic when parsing geospacial schemas with spacial index tuning parameters. In particular, this bug could be triggered by specifying thefillfactor
option, or setting theautovacuum_enabled
option tofalse
. #66899Intent garbage collection no longer waits for or aborts running transactions. #65001
The Statements Page now properly displays the Statement Time label on the column selector. #67327
Avro feeds now support special decimals like Infinity #66870
Fixed a typo on the Network tooltip on the Statements Page. #65126
PostgreSQL-style intervals now print a
+
sign for day units if the year/month unit preceding was negative (e.g.,-1 year -2 months 2 days
will now print as-1 year -2 months +2 days
). #67210SQL Standard intervals will omit the day value if the day value is
0
. #67210Added partial redactability to log SQL statements. This change provides greater visibility to SQL usage in the logs, enabling greater ability to troubleshoot. #66359
Fixed a bug in jobs where failures to write to the jobs table could prevent subsequent adoption of a job until the previous node dies or the job is paused. #67671
Fixed a minor resource leak that occurs when a
RESTORE
is run. #67478Previously, an unavailable node that started draining or decommissioning would be treated as live and thus could receive a lease transfer, leading to the range becoming unavailable. This has been fixed. #67319
INSERT
andUPDATE
statements which operate on larger rows are split into batches using the sql.mutations.mutation_batch_byte_size setting #67537Fixed a bug that could cause the
min
window function to incorrectly returnnull
when executed with a non-defaultEXCLUDE
clause, becausemin
andmax
did not ignorenull
input values. #68025Fixed a bug that could cause a panic when a window function was executed in
RANGE
mode withOFFSET PRECEDING
orOFFSET FOLLOWING
on a datetime column. #68013SHOW
search_path will now properly quote$user
. #68034Fixed a bug where restores of data with multiple column families could be split illegally (within a single SQL row). This could result in temporary data unavailability until the ranges on either side of the invalid split were merged. #67497
Fixed a bug that was introduced in v21.1.5, which prevented nodes from decommissioning in a cluster if there were multiple nodes intermittently missing their liveness heartbeats. #67714
Fixed a bug where the
schedules.backup.succeeded
andschedules.backup.failed
metrics would sometimes not be updated. #67855Previously, a
SHOW GRANTS ON TYPE db.public.typ
command would not correctly show the grants if the current database was notdb
. This is now fixed. #68137Fixed a bug which permitted the dropping of
enum
values which were in use in index predicates or partitioning values. #68257Fixed a bug that could cause the
min
andmax
window functions to return incorrect results when the window frame for a row was smaller than the frame for the previous row. #68314Previously, parsing a date from a string would incorrectly assuming YMD format instead of the MDY format if the date was formatted using the two digit format for year: "YY-MM-DD" instead of "MM-DD-YY". This has been resolved. However, if you relied on having two-digit years as YY-MM-DD, prepend
0
s at the front until it is at least 3 digits; e.g., "15-10-15" for the year 15 should read "015-10-15". #68093Fixed a bug where migration jobs might run and update a cluster version before the cluster was ready for the upgrade. The bug could result in many extra failed migration jobs. #67281
IMPORT PGDUMP
with aUDT
would result in a nil pointer exception. It now fails gracefully. #67994Cascaded drop of views could run into '
table ...is already being dropped
' errors incorrectly. This is now fixed. #68601Fixed a bug in which an
ENUM
-type value could be dropped despite it being referenced in a table'sCHECK
expression. #68666Fixed an oversight in the data generator for TPC-H which was causing a smaller number of distinct values to be generated for
p_type
andp_container
in the part table than the spec called for. #68699Fixed a bug that created non-partial unique constraints when a user attempted to create a partial unique constraint in
ALTER TABLE
statements. #68629Fixed a bug where encryption-at-rest registry would accumulate nonexistent file entries forever, contributing to the filesystem operation's latency on the store. #68394
Fixed a bug where
IMPORT
would incorrectly reset its progress upon resumption. #68337Previously, given a table with hash-sharded indexes, the output of
SHOW CREATE TABLE
was not round-trippable: executing the output would not create an identical table. This has been fixed by showingCHECK
constraints that are automatically created for these indexes in the output ofSHOW CREATE TABLE
. The bug had existed since v21.1. #69001Importing tables via
IMPORT PGDUMP
orIMPORT MYSQL
should now honor cluster settingsql.defaults.default_int_size
and session variabledefault_int_size
. #68902Fixed a bug with cardinality estimation in the optimizer that was introduced in v21.1.0. This bug could cause inaccurate row count estimates in queries involving tables with a large number of null values. As a result, it was possible that the optimizer could choose a suboptimal plan. This issue has now been fixed. #69070
Fixed internal or "invalid cast" errors in some cases involving cascading updates. #69126
Previously, CockroachDB could return an internal error when performing the streaming aggregation in some edge cases, and this is now fixed. The bug had been present since v21.1. #69122
Introduced checks on Statements and Transactions pages so that the managed repo can update the cluster-ui version. #69205
When using
COPY FROM .. BINARY
, the correct format code will now be returned. #69066Previously,
COPY FROM ... BINARY
would return an error if the input data was split across different messages. This is now fixed. #69066Previously,
COPY FROM ... CSV
would require eachCopyData
message to be split at the boundary of a record. This was a bug since theCOPY
protocol would allow messages to be split at arbitrary points. This is now fixed. #69066Previously,
COPY FROM ... CSV
did not correctly handle octal byte escape sequences such as\011
when using aBYTEA
column. This is now fixed. #69066Fixed a bug that caused internal errors with set operations, like
UNION
, and columns with tuple types that contained constantNULL
values. This bug was introduced in v20.2. #68627Fixed a crash when using the
cockroach backup debug
tool. #69251Previously, after a temporary node outage, other nodes in the cluster could fail to connect to the restarted node due to their circuit breakers not resetting. This would manifest in the logs via messages "unable to dial nXX: breaker open", where
XX
is the ID of the restarted node. (Note that such errors are expected for nodes that are truly unreachable, and may still occur around the time of the restart, but for no longer than a few seconds). This is now fixed. #69405Previously, table stats collection issued via an
ANALYZE
orCREATE STATISTICS
statement without specifyingAS OF SYSTEM TIME
option could run intoflow: memory budget exceeded
. This has been fixed. #69483Fixed a bug where
IMPORT
internal retries (i.e., due to node failures) might not pick up the latest progress updates. #68218Fixed a bug where the summary displayed after an
IMPORT
command would sometimes be inaccurate due to retries. #68218Long-running
ANALYZE
statements will no longer result in GC TTL errors. #68929
Performance improvements
- Intent resolution for transactions that write many intents such that we track intent ranges, for the purpose of intent resolution, is much faster (potentially 100x) when using the separated lock table. #66268
- Updated the optimizer cost model so that all else being equal, the optimizer prefers plans in which
LIMIT
operators are pushed as far down the tree as possible. This can reduce the number of rows that need to be processed by higher operators in the plan tree, thus improving performance. #69688 - QPS-based replica rebalancing is now aware of different constraints placed on different replication zones. This means that heterogeneously loaded replication zones (for instance, regions) will achieve a more even distribution of QPS within the stores inside each of these zone. #65379
- Some additional expressions using the
<@
(contained by) and@>
(contains) operators now support index-acceleration with the indexed column on either side of the expression. #61219 - Some additional expressions using the
<@
(contained by) and@>
(contains) operators now support index-acceleration with the indexed column on either side of the expression. #61817 - Columns that are held constant in partial index predicates can now be produced when scanning the partial index. This eliminates unnecessary primary index joins to retrieve those constant columns in some queries, resulting in lower latency. #62406
- Inverted joins using
<@
(contained by) and@>
(contains) operators are now supported with the indexed column on either side of the expression. #62626 - The optimizer now folds functions to
NULL
when the function does not allowNULL
arguments and one of the arguments is aNULL
constant. As a result, more efficient query plans will be produced for queries with these types of function calls. #62924 - Expressions with the
->
(fetch val) operator on the left side of either<@
(contained by) or@>
(contains) now support index-acceleration. #63048 - SQL will now emit
GetRequests
when possible to KV instead of always emittingScanRequests
. This manifests as a modest performance improvement for some workloads. #61583 - Set operations (
UNION
,UNION ALL
,INTERSECT
,INTERSECT ALL
,EXCEPT
, andEXCEPT ALL
) can now maintain ordering if both inputs are ordered on the desired output ordering. This can eliminate unnecessary sort operations and improve performance. #63805 - Reduced memory usage in some write-heavy workloads. #64222
- Increased the intelligence of the optimizer around the ability of a scan to provide certain requested orderings when some of the columns are held constant. This can eliminate unneeded sort operations in some cases, resulting in improved performance. #64254
- Increased the intelligence of the optimizer around orderings that can be provided by certain relational expressions when some columns are constant or there are equalities between columns. This can allow the optimizer to plan merge joins, streaming group bys, and streaming set operations in more cases, resulting in improved performance. #64501
- Increased the intelligence of the optimizer around orderings that can be provided by certain relational expressions when there are equalities between columns. This can allow the optimizer to remove unnecessary sort operations in some cases, thus improving performance. #64593
- Improved the performance for distributed queries that need to send a lot of data of certain datatypes across the network. #64169
- Peak memory usage in the lock table is now significantly reduced. Runaway CPU usage due to wasted quadratic time complexity in clearing unclearable locks is addressed. #64102
- The selectivity of query filters with
OR
expressions is now calculated more accurately during query optimization, improving query plans in some cases. #64886 - Validation of a new
UNIQUE
index in aREGIONAL BY ROW
table no longer requires an inefficient and memory-intensive hash aggregation query. The optimizer can now plans the validation query so that it uses all streaming operations, which are much more efficient. #65355 - A limited scan now checks for conflicting locks in an optimistic manner, which means it will not conflict with locks (typically unreplicated locks) that were held in the scan's full spans, but were not in the spans that were scanned until the limit was reached. This behavior can be turned off by changing the value of the cluster setting
kv.concurrency.optimistic_eval_limited_scans.enabled
tofalse
. #58670 - Queries that produce a lot of rows in the result usually will now run faster when executed via the vectorized execution engine. #65289
- Inner, Left, and Semi joins involving
REGIONAL BY ROW
tables can now take advantage of locality-optimized search. This optimization allows lookup joins to avoid communicating with remote nodes if a lookup is known to produce at most one match per input row, and all matches are found locally. This can reduce query latency. #65784 - Improved the performance of
has_table_privilege
by using an internal cache for performing privilege lookups. #65766 - Improved the performance of
has_any_column_privilege
by removing some internal queries. #65766 - Improved the performance of
has_column_privilege
by removing excessive queries. #65766 - When admission control is enabled, work sent to the KV layer is subject to admission control that takes into account write overload in the storage engines. #65850
- Regexp expressions that restrict values to a prefix (e.g.,
x ^ '^foo'
) now result in better plans if there is a suitable index. #66441 - The optimizer can now create query plans that use streaming set operations, even when no ordering is required by the query. Streaming set operations are more efficient than the alternative hash set operations, because they avoid the overhead of building a hash table. This can result in improved performance for queries containing the set operations
UNION
,INTERSECT
,INTERSECT ALL
,EXCEPT
, andEXCEPT ALL
. (UNION ALL
does not benefit from this optimization.) #64953 - A limited scan now checks for conflicting latches in an optimistic manner, which means it will not conflict with latches that were held in the scan's full spans, but were not in the spans that were scanned until the limit was reached. This behavior can be turned off (along with optimistic locking) by changing the value of the cluster setting
kv.concurrency.optimistic_eval_limited_scans.enabled
tofalse
. #66059 - The optimizer is now less likely to create query plans that require buffering a large number of rows in memory. This can improve performance by reducing memory pressure and reducing the likelihood that execution operators will need to spill to disk. #66559
- Validation of a new partial
UNIQUE
index in aREGIONAL BY ROW
table no longer requires an inefficient and memory-intensive hash aggregation query. The optimizer can now plan the validation query so that it uses all streaming operations, which are much more efficient. #66565 - Fixed a performance regression that made the in-memory vectorized sorter slower than the row-engine sorter when the input had decimal columns. #66807
- Increased the default value for the
kv.transaction.max_intents_bytes
cluster setting from 256KB to 4MB to improve transaction performance for large transactions at the expense of increased memory usage. Transactions above this size limit use slower cleanup mode for commits and aborts. #66859 - Adjusted optimizer cost to include CPU cost of
lookupExprs
when used by lookup joins. When a lookup join is chosen we can use two strategies: a simple 1-column lookup or a more involved multi-column lookup that makes more efficient use of indexes but has higher CPU cost. This change makes the cost model reflect that extra cost. #66786 - Improved the efficiency of validation for some partial unique indexes in REGIONAL BY ROW tables by improving the query plan to use all streaming operations. #67263
- The latency of authenticating a user has been improved by adding a cache for lookups of authentication related information. #66919
- Improved the optimizer's cardinality estimations for
enum
columns, including thecrdb_region
column inREGIONAL BY ROW
tables, as well as all other columns with user-defined types. This may result in the optimizer choosing a better query plan in some cases. #67374 - Eliminated a round-trip when running most jobs. #67671
- The performance of queries returning many arrays has been improved. #66941
- Improved concurrency control for heavily contended write queries outside of transactions that touch multiple ranges, reducing excessive aborts and retries. #67215
- The optimizer can now decorrelate queries that have a limit on the right (uncorrelated) input of a lateral join when the limit is greater than one. #68299
- Sort performance has been improved when sorting columns of type
STRING
,BYTES
, orUUID
. #67451 - Lookup joins on partial indexes with virtual columns are no considered by the optimizer, resulting in more efficient query plans in some cases. #68568
- The
COCKROACHDB_REGISTRY
file used for encryption-at-rest will be replaced with aCOCKROACHDB_ENCRYPTION_REGISTRY
, which can be written to in a more efficient manner. #67320 - Reduce memory usage slightly during
ANALYZE
orCREATE STATISTICS
statements. #69051 - The optimizer more accurately costs streaming group-by operators. As a result, more efficient query plans should be chosen in some cases. #68922
- If the query is executed locally and needs to perform reads from multiple remote leaseholders, those remote reads might now be done faster. This is especially likely for the case of locality optimized search when there is a local region miss. #68679
- Improved the histogram construction logic so that histograms for columns with a large number of distinct values are more accurate. This can result in better cardinality estimates in the optimizer and enable the optimizer to choose better query plans. #68698
- Locality-optimized search is now supported for scans that are guaranteed to return 100,000 keys or less. This optimization allows the execution engine to avoid visiting remote regions if all requested keys are found in the local region, thus reducing the latency of the query. #69395
Build changes
- Added go-swagger dependency. Updated Makefile to call it to rebuild spec in
docs/generated/swagger/
, which will eventually be used for API docs. #62560
Contributors
This release includes 2750 merged PRs by 229 authors. We would like to thank the following contributors from the CockroachDB community:
- AJ (first-time contributor)
- Alan Acosta (first-time contributor)
- Aleksandr Fedorov (first-time contributor)
- Callum Neenan (first-time contributor)
- Catherine J (first-time contributor)
- David López
- Eugene Kalinin
- Ganeshprasad Biradar (first-time contributor)
- Jane Xing (first-time contributor)
- Janusz Marcinkiewicz (first-time contributor)
- Jonathan Albrecht (first-time contributor)
- Julien Levesy (first-time contributor)
- Justin Lowery (first-time contributor)
- K Rain Leander (first-time contributor)
- Keith McClellan (first-time contributor)
- Kumar Akshay
- Lakshmi Kannan (first-time contributor)
- Lauren Barker (first-time contributor)
- Masahiro Ikeda (first-time contributor)
- Max Neverov
- Miguel Novelo (first-time contributor)
- Mohammad Aziz (first-time contributor)
- Mohit Agarwal (first-time contributor)
- Nikola N (first-time contributor)
- OrlovM (first-time contributor)
- Rupesh Harode (first-time contributor)
- Sam X Smith (first-time contributor)
- Shivam Agrawal (first-time contributor)
- Sumit Tembe (first-time contributor)
- Tharun
- Wilson Meng (first-time contributor)
- Zhou Xing (first-time contributor)
- Zijie Lu (first-time contributor)
- aayush (first-time contributor)
- ajstorm (first-time contributor)
- auxten (first-time contributor)
- e-mbrown (first-time contributor)
- joesankey (first-time contributor)
- kurokochin (first-time contributor)
- linyimin (first-time contributor)
- oeph (first-time contributor)
- rharding6373 (first-time contributor)
- seekingua (first-time contributor)
- snyk-bot (first-time contributor)
- yangxuan (first-time contributor)
- zhangwei.95 (first-time contributor)