What's new in the YugabyteDB v2.18 STS release series

YugabyteDB Anywhere release notes have moved

Starting with v2.16, the release notes for YugabyteDB Anywhere have moved to their own page.

Included here are the release notes for the YugabyteDB v2.18 release series. Content will be added as new notable features and changes are available in the patch releases of the YugabyteDB v2.18 release series.

For an RSS feed of all release series, point your feed reader to the RSS feed for releases.

v2.18.3.0 - September 20, 2023

Build: 2.18.3.0-b75

Third-party licenses: YugabyteDB, YugabyteDB Anywhere

Downloads

Docker

docker pull yugabytedb/yugabyte:2.18.3.0-b75

New features

  • [18069] [YSQL] Add support for OIDC (JWT) based authentication

Improvements

  • [12853] [PITR] Turn consistent_restore flag on by default
  • [16963] [#18838] [DOCDB] Add verbose logging to the load balancer
  • [17570] [DOCDB] Improve leaderless tablet endpoint
  • [18069] [YSQL] Introduce jwtcpp_util as a wrapper over JWT-CPP
  • [18321] [YSQL] Enable preloading additional tables by specifying catalog list in flags; restore --ysql_catalog_preload_additional_tables
  • [18465] [DOCDB] Dump PeerManager to tserver debug ui consensus page
  • [18555] [CDCSDK] Refactored cdcsdk_ysql_tests to add waiting mechanism for GetChanges() call
  • [18826] Build - thirdparty_tool --list-compilers option enhancement
  • [18854] [YSQL] SELECT INTO and CREATE TABLE AS cause catalog version increase

Bug fixes

  • [12574] [xCluster] Hold reference count of YBTable in XClusterWriteRpc
  • [13171] [DOCDB] reject expired retryable requests
  • [14210] [DOCDB] fixed YSQL tablet routing
  • [14369] [DOCDB] Add a flag to ignore NULL sys catalog entries during enumeration
  • [15925] Disabling pg_tablet_split-test.cc tests for tsan
  • [16432] [17080] [xCluster] Disallow N:1 replication topology
  • [16446] [YSQL] Make yb_pg_batch_detection_mechanism configurable at runtime for session, Peek message following Execute from JDBC driver to identify batch execution
  • [16556] [CDCSDK] Only ignore unpolled tablets depending on context
  • [17146] [xCluster] Fix missing pgschema_name during SetupUniverseReplication
  • [17148] [DOCDB] Fixed wrong metric_type of prometheus metric
  • [17468] Retry ysqlsh in the Docker-based package check
  • [17682] [DOCDB] fix hybrid time too low due to race between TransactionParticipant::Poll and RaftConsensus::Start in rf-1 setup
  • [17751] [CDCSDK] Turn flag enable_update_local_peer_min_index to true by default
  • [17795] [CDCSDK] Don't stream same txn twice in same GetChanges call
  • [18164] [DOCDB] Ignore deleted tablets in leaderless endpoint
  • [18281] [YSQL] Fix query layer's read restart retries in Read Committed isolation
  • [18344] [YCQL] Fix TOJSON() to also unpack nested FROZENs
  • [18387] [DOCDB] Select statement fails with TABLET_DATA_SPLIT_COMPLETED
  • [18518] [DOCDB] removed unused MemTracker::rand_ field
  • [18519] [CDCSDK] Stop sending checkpoint details for unpolled child tablets in UpdatePeersAndMetrics
  • [18586] [YCQL] Return reserved keywords in double quotes
  • [18592] [DOCDB] Fix log message format in WritePostgresConfig
  • [18635] [xCluster] Fix ordering in GetLatestEntryOpId during bootstrap
  • [18642] [DOCDB] Code refactoring to match usage of has_been_fully_compacted to a proper name
  • [18652] [YSQL] YB Sequential Scans don't take locks in SERIALIZABLE isolation
  • [18879] [YSQL] Disable pushdown for TextSearch functions that are not thread safe

Known issues

N/A

v2.18.2.1 - August 16, 2023

Build: 2.18.2.1-b1

Third-party licenses: YugabyteDB, YugabyteDB Anywhere

Downloads

Docker

docker pull yugabytedb/yugabyte:2.18.2.1-b1

New features

  • [16912] [DocDB] Expose GetOldTransactions RPC to fetch long-running transaction metadata
  • [17312] [CDCSDK] Add begin/commit records for single shard txns
  • [17608] [DocDB] Add HTTP security headers
  • [17696] [YSQL] Add yb_latency_histogram to server statements
  • [17700] [YSQL] Add yb_get_percentile YSQL function
  • [17795] [CDCSDK] Add wal_segment_index to GetChanges Response and Request
  • [17868] [DocDB] Export histogram quantile p50/95/99 as gauge to Prometheus #TYPE
  • [18068] [YSQL] add a new tserver (preview) convenience GFlag ysql_ident_conf_csv for user name maps

Improvements

  • [14308] [DocDB] update flag description now that savepoints work with xCluster
  • [15060] [DocDB] Makes backoff loop aggressive in colocated table creation path
  • [16116] [DocDB] Lazily flush superblock on colocated table creation
  • [16466] [DocDB] Flush superblock before reading in RBS with lazy superblock flush
  • [16604] [DocDB] Renames last_change_metadata_op_id to last_flushed_change_metadata_op_id in superblock
  • [16778] [DocDB] Background flush task when lazy superblock flush is enabled
  • [17104] [DocDB] Shuts downs superblock_flush_bg_task_ on tserver shutdown
  • [17356] [YSQL] Reduced memory_tracking overhead in high use situations from 10% to 3%
  • [17683] [DocDB] Invalidate YCQL system.partitions cache on table creation
  • [17730] [YSQL] Import Improve pruning of a default partition
  • [17801] [YSQL] Option to toggle distinct pushdown
  • [17805] [17965] [YSQL] Enhance TServer PG daemon robustness
  • [17826] [17823] [YSQL] Use a more granular clock for RPC timing on Linux builds
  • [17855] [CDCSDK] Force add snapshot bootstrap operation checkpoint to cdc_state table
  • [17867] [DocDB] Account for table placement and read replicas in underreplicated endpoint
  • [17884] [CDCSDK] Add checkpoint details to snapshot records and change check of copying checkpoint from colocated snapshot to streaming
  • [17966] [DocDB] Unify ModifyPlacementInfo string parsing
  • [17972] [CDCSDK] Add guards around updating invalid checkpoints during snapshot phase
  • [18064] [DocDB] enhance tserver consensus state page
  • [18067] [YSQL] Import 'Remove arbitrary restrictions on password length.'
  • [18067] [YSQL] Import "Make StringInfo available to frontend code."
  • [18069] [YSQL] Update third-party dependencies & add CMake configs for JWT-CPP
  • [18116] [CDCSDK] Persist the safe_time from explicit checkpoint in cdc_state table
  • [18391] [17864] [YSQL] RPC timers in write path default to granular clocks in Linux
  • [18418] [CDCSDK] Set cdc_populate_safepoint_record default to true
  • [DB-2613] [YSQL] Remove unused log4j reference from the java modules

Bug fixes

  • [13395] [YSQL] Return error for unset bind PK value
  • [14762] [DocDB] Prevent crashing the master if trying to restore a deleted table
  • [16267] [17755] [DocDB] Fix issues in RBS from closest peer codepath
  • [16441] [YSQL] Retry CREATE DATABASE when oid collision happens
  • [16508] [YSQL] Fix incorrect tablet count assignment on user tables created within geo-partitoned tablespace
  • [16597] [DocDB] Fixed PartitionSchema::CreateHashPartitions to provide even hash codes distribution
  • [16665] [14308] [DocDB] fix logging of RocksDB write batches when packing is used, part I and II
  • [16680] [CDCSDK] Fix colocated before image test with packed row
  • [16711] [DocDB] Only display AutoFlags in UI that are relevent to the process
  • [17038] [DocDB] Async open table while updating indexes
  • [17043] [YSQL] Fix check to see when to attempt binding hash key options in scanspec
  • [17225] [YSQL] Use consistent read snapshot in DEFERRABLE READ ONLY mode
  • [17290] [DocDB] Fix race condition in deadlock_detector causing invalid probe_num
  • [17351] [yugabyted] Enable EAR command is failing on Mac builds
  • [17400] [17488] [16665] [14308] [DocDB] fix crash due to speculatively decoding a slice ending in a Typeset
  • [17512] [yugabyted] Code changes to provide the master and tserver webserver port information to the API server
  • [17558] [DocDB] Issue with picking local_limit during paging read
  • [17574] [DocDB] Add EncryptedWritableFile::Size() to fix incorrect WAL footer start offset
  • [17592] [17760] [DocDB] Rename WAL file after writing the file header on the disk
  • [17648] [YSQL] Unexpected SELECT DISTINCT behaviour with non index conditions
  • [17663] [DocDB] Clear drive load / leader load maps before appending to them
  • [17718] [xCluster] Check table leader term in xCluster Poller
  • [17795] [CDCSDK] Emit CDC records in order of commit time instead of op ID and fix response safe_time calculation in corner cases
  • [17848] [DocDB] Fix race on RemoteTablet::replicas_ between RemoteTablet::GetRemoteTabletServers and RemoteTablet::Refresh
  • [17869] [YSQL] fix incorrect optimization on NULL scans
  • [17887] [DST] PITR restores should ignore Deleted namespaces
  • [17890] [xCluster] create intent iterator outside of RegularDB batch writer to avoid deadlock
  • [17925] [CDCSDK] Refetch correct schema in cases of schema versioning errors
  • [17935] [CDCSDK] Reduce the number of txns in TestCDCSDKConsistentStreamWithManyTransactions
  • [17961] [18008] [YSQL] Fix max connection limit errors with additional locking
  • [17969] [CDCSDK] Fix heap-use-after-free failure for TestFromOpIdInGetChangesResponse
  • [17981] [yugabyted] yugabyted start should work when custom certs_dir is provided
  • [17997] [xCluster] IsBootstrapRequired should return False if any data exists in the WAL
  • [18001] [DocDB] Skip key registry decryption in EncryptionManager::GetFullUniverseKeyRegistry() when EAR is disabled
  • [18023] [DocDB] Log the result of chronyd when tserver crashes with a high clock skew
  • [18071] [yugabyted] Changing the status display to not show the actual password when it's generated in secure mode
  • [18133] [CDCSDK] GetTabletListToPollForCDC should return safe_time as well
  • [18184] [DocDB] Fix crash in case of IN handling
  • [18227] [DocDB] Fix log reader missing max_replicate_index
  • [18322] [YSQL] fix index ScanKey bugs
  • [18328] [CDCSDK] Fix bug in GetTabletIdsToPoll when only 1 child tablet has been polled
  • [18393] [DocDB] Fix unknown int64 flags incorrectly getting tagged as runtime
  • [18445] [CDCSDK] Call ResolveIntents if consistent_safe_time is stuck
  • [18467] [CDCSDK] Do not send safepoint records in snapshot phase
  • [18635] [xCluster] Fix ordering in GetLatestEntryOpId during bootstrap
  • [18756] [xCluster] Only Throttle xCluster Traffic from source side

Known issues

N/A

v2.18.1.0 - June 27, 2023

Build: 2.18.1.0-b84

Third-party licenses: YugabyteDB, YugabyteDB Anywhere

Downloads

Docker

docker pull yugabytedb/yugabyte:2.18.1.0-b84

Highlights

  • Improvements to xCluster, including:
    • Support for transactional atomicity
    • Faster bootstrapping
    • Automatic transfer of the source universe certificate when new nodes are added to the target universe
    • Ability to set up replication even if matching tables do not exist on the target universe
    • Improved performance and reliability when gathering replication stream statuses
    • Disallowing replication between two YugabyteDB versions that are incompatible
  • View latency histograms for queries using the yb_latency_histogram column in pg_stat_statements
  • Faster nested loops with batching. Requests to YB-TServers are batched during joins using a new join execution method referenced as Batched Nested Loop, and derived from classic nested loop joins.

New features

  • [14445] [YSQL] Add query latency histogram column in pg_stat_statements
  • [15036] [xCluster] Add transactional flag to setup_universe_replication
  • [16294] [14067] [YSQL] Implementation Enhancements for EXPLAIN ANALYZE
  • [16757] [xCluster] Add transactional flag on Producer stream

Improvements

  • [13786] [17395] [17494] [DOCDB] Auto full compactions based on deletes in SST files
  • [14284] [13041] [YSQL] Avoid setting read time when using serializable isolation level
  • [14473] [DOCDB] Accept registrations from tservers on the same node with greater sequence numbers
  • [16240] [YSQL] Use per-tuple memory context in relcache preloading
  • [16343] [DOCDB] Include TableType in the table and cdc metrics
  • [16750] [xCluster] Disallow setting up transactional replication if any YCQL tables are included in replication
  • [16826] [DOCDB] [xCluster] Use RocksDB DirectWriter for applying external intents
  • [17013] [DOCDB] Add colocation info to ListTables output
  • [17016] [DOCDB] Add #HELP and #TYPE lines for prometheus metric
  • [17150] [YSQL] Allow BNL on expressions with multiple relations on one side
  • [17318] [YSQL] Import 'Replace last PushOverrideSearchPath() call with set_config_option().' from PG
  • [17358] [DOCDB] Add tracking for memory used by YBMetadataCache
  • [17455] [xCluster] Log when UpdateCdcMetrics is delayed
  • [17463] [xCluster] Producer and consumer side network throttling
  • [17633] [YCQL] Introduce flag to control local calls on RPC thread

Bug fixes

  • [14308] [xCluster] fix xCluster replication so it correctly handles SAVEPOINTs
  • [14926] [DOCDB] Prevent intent clean-up while reading YSQL system tables
  • [15769] [YSQL] Fix functional indexes returning wrong results
  • [16157] [17433] [YSQL] Set PgClient session timeout value
  • [16367] [DOCDB] Delete Snapshot keeps on retrying indefinitely after master failover
  • [16513] [DOCDB] Correcting statistics for DOCDB keys found
  • [16590] [DOCDB] Add test which ensures deadlocks are detected across partitions
  • [16612] [DOCDB] Fix transaction promotion race condition resulting in unnecessary abort
  • [16631] [DOCDB] Fix delete_snapshot sending delete RPCs indefinitely for deleted tablets
  • [16697] [DOCDB] Disallow multiple OpenTable calls in YBMetaDataCache::GetTable
  • [16698] [DOCDB] Add NewWritableFile Encryption Wrapper to fix WAL reuse issue
  • [16794] [DOCDB] Make full compactions non-exclusive by default
  • [16805] [DOCDB] Split PgMiniTest into smaller ones
  • [16863] [DOCDB] Ignore missing YSQL indices when importing a snapshot
  • [16911] [DOCDB] Augment GetLockStatus tserver endpoint to handle transaction_id list
  • [16943] [xCluster] switch xcluster_ysql-test to use consistent WAL mode
  • [16999] [DOCDB] Retry read if read buffer was full on previous step
  • [17026] [xCluster] Fix metrics jump when regaining leadership
  • [17041] [YCQL] Add cache in FindMemberForIndex for jsonb
  • [17074] [DOCDB] Root memory consumption should not include pageheap_free_bytes
  • [17107] [YCQL] Prevent DROP TYPE for the used YCQL type
  • [17163] [YCQL] Use Metadata Cache by default in PREPARE
  • [17194] [CQL] Add memtracker to track CQL requests memory usage
  • [17203] Fix post_install.sh failure related to pg_stat_statements.so
  • [17219] [YCQL] Fixing tests AlterDropAdd*
  • [17253] [DOCDB] Fix RPC error handling in pg client
  • [17261] [DST] [PITR] Single file compaction does not reset Hybrid Time filter
  • [17276] [xCluster] cleanup the transaction to write_id map whenever transaction is applied
  • [17293] [xCluster] Avoid creating multiple copies of GetChangesPB and cleanup PBs as soon as apply finishes
  • [17296] [xCluster] Fix StreamMetadata TSAN race
  • [17308] [DOCDB] [xCluster] track schema packings in frontier for external records
  • [17317] [YSQL] Import Handle RLS dependencies in inlined set-returning functions properly
  • [17362] Avoid double memory tracking of request data and fix tracking for plain response buffer size
  • [17380] [YSQL] Make sure ybctid_column_value is still sent in index scans for upgrade compatibility
  • [17398] [CQL] Account for user query and keyspace name for prepared statements
  • [17404] Use LLVM URL from the third-party dir for ASAN/TSAN
  • [17431] [DOCDB] Fix partial hash key columns projection in DocRowwiseIterator
  • [17437] [DOCDB] Rename WAL reuse flag to include unit
  • [17480] [DOCDB] Update to NULL could be lost after compaction when packed row is enabled
  • [17502] [DOCDB] Exclude yugabyted-ui from sed binary manipulation
  • [17502] Fix the shared library interpreter used for yugabyted-ui
  • [17531] [DocDB] Disable wait-on-conflict behavior for YCQL traffic
  • [17559] [DST] Adding loop call during tablet server init to wait on master leader to get encryption keys at rest
  • [17632] [DOCDB] Fix GC of schema packings of colocated table
  • [17712] [DOCDB] Fix system partitions query to not return empty namespace name when its not set at table level
  • [17714] [YSQL] Resolve version_metadata.json missing issue
  • [17726] [DOCDB] A workaround for memory leak from InboundCall weak pointers
  • [17762] Bound the number of cloned ops by the number of partitions for IN conditions sent to hash sharded tables

Known issues

N/A

v2.18.0.1 - May 30, 2023

Build: 2.18.0.1-b4

Third-party licenses: YugabyteDB, YugabyteDB Anywhere

Downloads

Docker

docker pull yugabytedb/yugabyte:2.18.0.1-b4

Bug fixes

  • [17431] [DocDB] Fix partial hash key columns projection in DocRowwiseIterator
  • [17480] [DocDB] Update to NULL could be lost after compaction when packed row is enabled
  • [17502] [DocDB] Exclude yugabyted-ui from sed binary manipulation, Fix the shared library interpreter used for yugabyted-ui.

Known issues

N/A

v2.18.0.0 - May 16, 2023

Build: 2.18.0.0-b65

Third-party licenses: YugabyteDB, YugabyteDB Anywhere

Downloads

Docker

docker pull yugabytedb/yugabyte:2.18.0.0-b65

New features

  • [12417] [YSQL] Use relcache init files in per-database catalog version mode
  • [13336] [YSQL] push down the avg() aggregate
  • [13488] [xCluster] Create index in transactionally consistent xCluster
  • [14234] [14674] [DOCDB] Support Colocated+Packed+XCluster & auto pause/resume on schema changes
  • [14665] [DOCDB] enable packed row for co-located tables by default
  • [16068] [DOCDB] Support storing wait-for probes of distributed waiter txns spanning across tservers
  • [16137] [DST] PITR + Sequences - Ensure generated sequence values are monotonic after restore
  • [16165] [16358] [yugabyted] [UI] New design implementation for Overview and Database pages (#16167)
  • [16165] [yugabyted] UI Adding replication factor info in the /cluster API
  • [16195] [DOCDB] Add metrics support for ScanForward API
  • [16218] [DOCDB] Adding xcluster_read_only mode to standby cluster databases
  • [16351] [DocDB] Add Cql Tests to Simulate Update Index Callback Leak
  • [16370] [DOCDB] enable packed row in locking unit tests
  • [16380] Use thread safety analysis annotations to enforce the reactor thread requirement
  • [16447] [DOCDB] Use shared memory for Perform queries between postgres and tserver
  • [16503] [CDCSDK] Support colocated table with before image
  • [16513] Add statistics to track DOCDB keys found (total, obsolete, and obsolete past history cutoff)
  • [16515] [xCluster] Enable using metacache in cdcservice
  • [16571] [DOCDB] Protect InboundCall::trace_ with the mutex
  • [16600] Odyssey connection pooler CMake integration
  • [16601] [DOCDB] Introduce simplified version for RocksDB iterator Next
  • [16648] [DOCDB] Decode directly to QLValuePB
  • [16663] [YSQL] Extend Batched Nested Loop Join functionality to Appended base relations for partitioned tables
  • [16700] [DOCDB] Read directly to QLTableRow
  • [16719] [YSQL] Make ysql_yb_bnl_batch_size a runtime flag
  • [16742] Adding additional logging for API server
  • [16746] [xCluster] Compute and propagate apply_safe_time from producer
  • [16892] [DOCDB] AutoFlags should provide the capability to enable flags on Install scenarios only, but not upgrade

Improvements

  • [3090] [YCQL] Limit topology change events to subscribed connections
  • [13701] Build: Use Google TCMalloc for fastdebug build
  • [14961] [14962] [YSQL] Further reduce first-query metadata RPCs
  • [15014] [14333] [YSQL] Refactor some code to honour coding best pratices
  • [15746] [DOCDB] harden master leaderless tablet endpoint
  • [15749] [DOCDB] Delay rocksdb gauge metrics update to end of request
  • [15794] [DOCDB] Reduced Number of Tablets in AreLeadersOnPreferredOnly test
  • [15884] [YSQL] Skip indexed table's stats update after non-concurrent create index
  • [15909] [DOCDB] Move sys catalog writes out of catalog loader
  • [16058] [CDCSDK] Use safe time from request rather than response
  • [16091] [DOCDB] Changing post-split compaction to run non-exclusively
  • [16123] [DOCDB] Remove co-partitioning logic
  • [16237] [xCluster] deprecate flags cdc_max_apply_batch_num_records and cdc_max_apply_batch_size_bytes
  • [16255] [YSQL] Reduce memory use on insert, update, and delete by using per-tuple contexts and freeing bitmapsets
  • [16317] [13718] Move common functionality to base iterator class
  • [16374] [DOCDB] Improve error message when SAVEPOINT feature is attempted when disabled by --enable_pg_savepoint
  • [16397] [DOCDB] Set table to RUNNING state only after all tablets are ready
  • [16402] [yugabyted] Set cluster config as soon as the 3rd node joins
  • [16442] [DST] PITR + Per DB catalog version: Increment only the catalog version of the relevant database
  • [16454] [YSQL] Log on unexpected backend termination
  • [16460] [YSQL] Improve error messages for transaction conflicts
  • [16461] [YSQL] Allow hash batching to apply to an unbounded number of permutations
  • [16467] compact_table Now Updates last_full_compaction_time For Tables without Writes
  • [16472] [DOCDB] Replace std::thread with yb::Thread
  • [16480] Reduce the amount of recompilation due to Postgres header copying
  • [16494] [DOCDB] Create VerifyPgClientServiceCleanupQueue unit test
  • [16504] [CDCSDK] [Colocation] YBTable object should contain metadata about colocation
  • [16510] [xCluster] Return nullopt from GetSafeTime if namespace does not require xCluster safe time
  • [16513] [DOCDB] Improve collecting statistics for DOCDB keys found
  • [16545] Build: build/package on mac11
  • [16551] [xCluster] Account for xcluster safe time for history retention on consumer
  • [16555] [DOCDB] Avoid decoding doc hybrid time during read when possible
  • [16562] [DOCDB] Avoid unnecessary calls to SeekForward and FindLatestValue in doc reader prepare phase
  • [16581] [DOCDB] Remove outstanding tablet split limit by default
  • [16587] [DOCDB] Move common ScanSpec functionality to base class and remove specific handling from iterator
  • [16588] build-infra: Don't use pipes python module
  • [16617] [DB-6011] [YCQLSH] Updating yugabyte-db-thirdparty release version
  • [16650] [DOCDB] Remove intent_doc_ht control field from packed column value
  • [16651] [DOCDB] Sanity check for RocksDB iterator status validation
  • [16666] [YSQL] Switch to new query context for get_tablespace_distance() operations
  • [16683] Support build with Clang 16
  • [16715] [DOCDB] Optimize handling of add_table change_metadata_op
  • [16756] [xCluster] Move yb-admin get_xcluster_estimated_data_loss to get_xcluster_safe_time
  • [16789] [YSQL] Assume that CAPABILITY_PickReadTimeAtTabletServer is enabled all the time
  • [16849] [DOCDB] Tablet splitting: Lower the thresholds for splits on low core machines
  • [16868] [DOCDB] Sanitizes debug messages
  • [16875] [DST] PITR - Extend master's sys catalog retention based on snapshot schedule
  • [16900] [CDCSDK] Remove cdcsdk_unprocessed_tables from CDCStreamInfo
  • [16969] yugabyted UI updates
  • [16991] [YSQL] Update pruning quals when nested loop batching is on
  • [16993] [YSQL] Restructure type checking when forming batched expressions
  • [17075] [17078] Send full universe key registry to Tablet Server on Startup
  • [17115] [YSQL] Restructure batched indexqual creation
  • [CLOUDGA-12738] Make the package updates work on AlmaLinux 9
  • [CLOUDGA-12738] Update OS pacakges during AMI build process
  • [DB-5975] [YCQLSH] Updating yugabyte-db-thirdparty release version

Bug fixes

  • [506] [YCQL] Disable alter table rename on columns with index
  • [13862] [YSQL] Fix metric for total number of connections made
  • [14167] [YSQL] Fix PgPackedRowTest.AddDropColumn flakiness
  • [14270] [DOCDB] Fixes test SnapshotTxnTest.BankAccountsWithTimeStrobe
  • [15090] [DOCDB] Tablet splitting: Some queries fail with "The tablet is shutting down" during the workload
  • [15166] [DOCDB] Fix crashes due to tablet shutdown timeout
  • [15449] [CDCSDK] Send snapshot end marker when snapshot has no data
  • [15612] [YSQL] Fix a memory leak in pg_isolation_regress
  • [15930] [DOCDB] Fixes data race issue with YBSubTransaction in TableSizeTest_PartitionedTableSize
  • [16009] [YSQL] Fix the system catalog versioning behaviour on CREATE TABLE with FK reference command
  • [16010] [DOCDB] Fixes tsan data race in CompactionTestWithFileExpiration.FileExpirationAfterExpiry
  • [16131] [DST] B/R, PITR Fix invalid enum value of restoration state object
  • [16156] [DOCDB] Limit duplicate address check to used host-port combination in Tserver registration
  • [16195] [DOCDB] Handle duplicate user keys in ScanForward API
  • [16262] [DOCDB] deflake failover pitr tests on tsan
  • [16329] [YSQL] Fix metric for rejections due to connections limit
  • [16401] [yugabyted] configure data_placement not working with constraint value with uppercases
  • [16444] [DOCDB] Fix tsan and fastdebug test, Ignore heartbeats from peers not in reported config
  • [16451] [YSQL] Fix imports in D22790 and D22956
  • [16481] [CDCSDK] [Colocation] YBClient fails to map multiple colocated tables to same tablet
  • [16518] [DOCDB] Prevent resuming conflict resolution at special timestamps in case transaction is not found
  • [16526] [DOCDB] Enable remote bootstrap to fix missing tablet replica problem in CreateTableStressTest::TestConcurrentCreateTableAndReloadMetadata.
  • [16540] [YSQL] Address HLL ASAN failures
  • [16541] [yugabyted] Show EAR in status if enabled even when --secure flag is false
  • [16552] [YSQL] Prevent prefix_length_ from taking non-key columns into account
  • [16565] [DOCDB] Fixed missing data in case of RocksDB iterator error
  • [16570] [YSQL] Fix build errors when building with --no-tcmalloc
  • [16571] [DOCDB] Fix InboundCall::trace() regression
  • [16583] [YSQL] Fix IndexOnlyScan with no targets returning empty rows
  • [16615] Dev tools: Fix script compatibility with newer arcanist
  • [16626] [DOCDB] Fix TSAN failure:XClusterConsumer and XClusterOutputClient deadlock
  • [16632] [DOCDB] Fix TestIndex.testDropDuringWrite
  • [16637] [CDCSDK] Fix safe_time issues around large transactions
  • [16644] [DST] PITR Fix YbAdminSnapshotScheduleTest.PgsqlAddColumnCompactWithPackedRow test
  • [16669] [DOCDB] Fix tablet splitting / PITR deadlock
  • [16679] [CDCSDK] Correcting safe_time bug for batches with only commit record
  • [16713] [YSQL] Fix heap-buffer-overflow in ysql_upgrade.cc
  • [16745] [YSQL] Fix TestPgRegressAuthorization failure
  • [16748] [DOCDB] Fix colocation parent table's metrics update when a colocated table is altered
  • [16763] [xCluster] Reduce logging noise during xcluster errors
  • [16773] [xCluster] Fix TSAN race on StreamTabletMetadata
  • [16790] [CDCSDK] GetCheckpoint will return invalid checkpoint for unpolled tablets
  • [16807] [DOCDB] Enable automatic_tablet_splitting for new clusters using AutoFlags
  • [16851] Fix DB UT for learner-TS due to broadcast address changes in yb_backup.py
  • [16944] [16715] [DOCDB] Fix 2 bugs with xcluster + packed, Fixing the demo connect creating tables to default database.
  • [16964] [DOCDB] Compilation failure for Apple clang 14.0.3
  • [16976] [YSQL] Fix postgres crash when pg_stat_progress_create_index has an index from a different database
  • [16992] [YSQL] Fix scan upperbound calculation during batched IN query on hash columns
  • [16995] [CDCSDK] Removed duplicated access to CDC Stream table
  • [17067] [YSQL] Disallow hash batching if there is only one batch element
  • [17118] [CDCSDK] Remove tables with no active streams from namespace_to_cdcsdk_unprocessed_table_map_
  • [17150] [YSQL] Disable batching on join clauses that involve more than one base relation on a side
  • [17165] [CDCSDK] Added serve_as_proxy member to GetCheckpointRequestPB
  • [17253] [DocDB] Fix RPC error handling in pg_client
  • [CLOUDGA-12305] Missing getters for provider fields - Part 2
  • [CLOUDGA-13117] Remove the OS update playbook components
  • [YSQL] style: fix/improve most of D21043 style
  • Fix xCluster utest build error

Known issues

N/A