Docs Menu

Docs HomeDevelop ApplicationsMongoDB Manual

6.0 Changelog

On this page

  • 6.0.5 Changelog
  • 6.0.4 Changelog
  • 6.0.3 Changelog
  • 6.0.2 Changelog
  • 6.0.1 Changelog
  • SERVER-71219 Migration can miss writes from prepared transactions

  • SERVER-71368 Stop excluding tests that drop collection/database in sharded suites

  • SERVER-72430 MigrationDestinationManager::report() may access null _migrationCloningProgress

  • SERVER-73916 Improve ReshardingTest fixture error reporting when reshardCollection has already failed before any failpoints are waited on

  • SERVER-74124 Disallow sharding with wildcard shard key pattern

SERVER-73534 Serialization of 'sbe::TypeTags::ArraySet' to 'KeyString' can segfault

SERVER-38232 Mongod on Ubuntu 16/18 does not create a pid file

  • SERVER-49705 'permitted' file may have been deleted by 'after_test'

  • SERVER-53870 Improve view creation performance over time

  • SERVER-54284 ExceptionFor<ErrorCodes::WriteConflict> should resolve to WriteConflictException

  • SERVER-61909 Hang inserting or deleting document with large number of index entries

  • SERVER-65990 Test BUS w/ changing BucketMaxTimeSpan

  • SERVER-66050 findSelfInConfig should attempt fast path for every HostAndPort before trying slow path

  • SERVER-66355 Pass dbName to validateViewDefinitionBSON in DurableViewCatalog::onExternalInsert

  • SERVER-66374 Exclude fle2_retryable_writes from large transactions format builder

  • SERVER-66469 Filtering timeseries with date-field does not include results from before 1970

  • SERVER-66793 Disable bucket unpacking with sort for clustered collections with out of order buckets

  • SERVER-66836 Make restarting from failpoint atomic in FCBIS

  • SERVER-67111 Investigate fixes to testClusteredTailableCursorCappedPositionLostWithTTL

  • SERVER-67183 Higher throughput Chunk Migration - reimplement for fetching and insertion

  • SERVER-67416 Always sort fieldpath string sets using custom comparator

  • SERVER-67446 Ensure consistent wildcardProjection and columnstoreProjection specs in catalog

  • SERVER-67722 Shard cursor is not killed on MaxTimeMSExpired

  • SERVER-67950 Make stronger assertions in bucket_unpacking_with_sort_granularity_change.js

  • SERVER-68122 Investigate replicating the collection WiredTiger config string during initial sync

  • SERVER-68388 Limit concurrency setting and update server parameter name

  • SERVER-68434 Equality to null can incorrectly use a cached partial ixscan which does not cover the predicate

  • SERVER-68594 Add vscode format/lint on save

  • SERVER-68647 Create feature flag

  • SERVER-68648 Enable feature flag

  • SERVER-68739 Add WiredTiger session statistic without affecting slow op statistics

  • SERVER-68836 Properly handle NaN and 0 in for LDAPTimeoutMS

  • SERVER-69648 [SBE] Improve visit(ExpressionConcatArrays*) and visit(ExpressionObject*)

  • SERVER-69902 Stop bucket_unpacking_with_sort_plan_cache.js from running in parallel with fsyncLock tests

  • SERVER-70167 Resumed create coordinator may incorrectly try to release the critical section

  • SERVER-70219 Use "linearizable" readConcern for spill_to_disk_secondary_read

  • SERVER-70321 Collmod coordinator must not resume migrations on retriable errors

  • SERVER-70360 Do not allow extremely large write concern wTimeout values

  • SERVER-70369 Create serverParameter for migrationConcurrency

  • SERVER-70395 Slot-Based Engine too aggressively uses disk for $group and is slow

  • SERVER-70427 Remove chef+kitchen package test infrastructure

  • SERVER-70566 Make assertion in backup_restore.js print error code

  • SERVER-70640 Add migrationConcurrency to serverStatus

  • SERVER-70747 Rename collection used in bucket_unpacking_with_sort_extended_range.js

  • SERVER-70830 Unit test WiredTigerOperationStats

  • SERVER-71049 crypt_shared emits log messages to stdout when loaded by libmongocrypt

  • SERVER-71053 Fix dataSize can be negative and incorrect on rollback

  • SERVER-71068 Partial indexes should not check FCV during startup

  • SERVER-71328 Ensure correct filtering metadata on donor shard after multiple failures

  • SERVER-71392 Track usage of JSON Schema for validation

  • SERVER-71608 Segmentation fault: in mongo::LockManager::lock

  • SERVER-71632 Re-enable dropDatabase FSM test in stepdown suites

  • SERVER-71680 $operationMetrics fails to account for "keysSorted" or "sorterSpills" when $group is pushed down to SBE

  • SERVER-71750 Revert refactor into handleWriteConflictException in writeConflictRetry loop

  • SERVER-71751 Skip transaction_too_large_for_cache.js for in-memory variants

  • SERVER-71771 Defragmenter should cap chunk size estimation

  • SERVER-71840 Change assert.eq statement in fle2_contention_update

  • SERVER-71924 Reduce verbosity of chunk merge change log event

  • SERVER-71950 Fail and log the operation when out-of-order keys are detected in WiredTiger

  • SERVER-71969 Update system_perf.yml for compile-variant and compile_variant.

  • SERVER-72046 Concurrent chunk migration testing

  • SERVER-72182 Consider adding Enterprise RHEL 8.0 (large transactions format) build variant to mongodb-mongo-v6.0 Evergreen project

  • SERVER-72185 TSBS perf test definition depends on a personal github repo

  • SERVER-72194 oplog_rollover.js should wait for the durable timestamp to advance

  • SERVER-72449 backup_restore.js should check for code 2 when killing child resmoke client

  • SERVER-72512 Indexes reported as valid when unable to return inconsistencies due to memory limit

  • SERVER-72535 Sharded clusters allow creating the 'admin', 'local', and 'config' databases with alternative casings

  • SERVER-72576 Notarize archive-dist binaries on macOS

  • SERVER-72619 Refactor and add more testing for migration_chunk_cloner_source changes

  • SERVER-72620 $indexStats doesn't include the "shard" field when run on unsharded collections

  • SERVER-72677 Full validation doesn't always report information about indexes

  • SERVER-72825 Remove all outdated entries from backports_required_for_multiversion_tests.yml

  • SERVER-72827 Filter out historic runtimes of non-passing tests

  • SERVER-72831 Fix use after move in sharding_util::processShardResponses

  • SERVER-72868 Complete TODO listed in SERVER-30949

  • SERVER-72877 Mongos retargeting logic in stepdown hooks should skip views

  • SERVER-73003 Use correct project when getting historical test runtime data

  • SERVER-73009 Decreasing order sort on clustered collections on replica sets returns increasing order

  • SERVER-73110 bucket_unpacking_with_sort_extended_range.js fails in sharded passthrough

  • SERVER-73157 Move out_max_time_ms tests to serial_run suite

  • SERVER-73164 increase maxTimeMS for index build in index_max_time_ms.js

  • SERVER-73176 Only print error message if there were in fact errors in getHostFQDNs

  • SERVER-73183 WiredTigerKVEngine::getSanitizedStorageOptionsForSecondaryReplication should skip inMemory

  • SERVER-73216 Upgrade BlackDuck to Detect v8

  • SERVER-73228 Remove active directory server from jstests/external_auth/ldap_mongos_health_checking.js

  • SERVER-73232 Change the default log-verbosity for _killOperations

  • SERVER-73235 Replace invariant with uassert in geometry_container

  • SERVER-73264 Fix wrong invariant in MigrationChunkClonerSource::commitClone

  • SERVER-73266 Deadlock among createIndexes, index build commit, and step down

  • SERVER-73368 Evergreen push task is failing to update v6.0-latest tarball in S3

  • SERVER-73389 Checkpoint vector clock in drop database coordinator

  • SERVER-73390 Mitigate database version regression bug on drop database

  • SERVER-73398 Invariant may be hit when downgrading from v6.0 due to moveChunk request without max key

  • SERVER-73481 Validate does not detect out-of-order keys with {full: false}

  • SERVER-73520 [6.0] Backport setProfilingFilterGlobally command

  • SERVER-73598 Extend FLEQueryInterface to test if a document exists by id

  • SERVER-73636 Coverity analysis defect 135025: Inefficient vector resizing with reserve.

  • SERVER-73697 Do not split out match expression on meta field when it's not renameable

  • SERVER-73706 Save WTRecordStoreUassertOutOfOrder fail point state to prevent concurrency bugs in testing

  • SERVER-73707 Evergreen timeout calculation fixes and cleanups

  • SERVER-73719 Comment out Legacy Build Variants in Sys-perf

  • SERVER-73745 Zero initialize IndexKeyBucket struct

  • SERVER-73852 Allow timeseries bounded-sort optimization on 5.0, on 6.0 binary

  • SERVER-73904 Update FreeBSD spidermonkey configuration

  • SERVER-73905 Implement getCurrentNativeThreadId for FreeBSD

  • SERVER-73938 Make sure chunk migration can handle a retryable internal transaction whose oplog entries have been truncated

  • SERVER-73998 Fix system_perf.yml and perf.yml microbench buildvariant definitions

  • SERVER-74097 Sharded find with expected collection UUID does not handle all cases of concurrent DDL operations

  • SERVER-74335 Spill to disk tests for $group must be tagged as "requires_persistence" on the v6.0 branch

  • WT-8848 Add API to roll back and indicate that a transaction has exceeded a configurable limit of pinned dirty data

  • WT-8981 Enable evergreen testing for RHEL8 on PPC

  • WT-9774 Avoid rolling back transactions in test_stat08 and re enable the test

  • WT-9879 Fix overcounting of session txn dirty bytes statistic

  • WT-10027 Session txn dirty statistic is incorrect

  • WT-10461 Fix key out of order in skip list on weakly ordered architecture

  • WT-10506 Introduce stable toolchain cmake files that point to the latest

  • WT-10584 Add missing read barriers in __cursor_skip_prev

  • SERVER-68361 LogTransactionOperationsForShardingHandler::commit misses transferring documents from prepared and non-prepared transactions changing a document's shard key value

  • SERVER-69874 Document or possibly mitigate scenario where shards end up with different prepareUnique and unique index settings

  • SERVER-70793 Make database metadata refresh first check new metadata under the IS lock before taking X lock

  • SERVER-71092 shard_id_test.cpp relies on a pure behavior of std::string::compare function

  • SERVER-71689 Refresh the CatalogCache before dropping the local collection

  • SERVER-72301 Use ordered:false when inserting chunks in optimized path of create collection

SERVER-58712 Inconsistent update performance on collections with multiple secondary indexes on same key

  • SERVER-60455 serverStatus metrics for external sorter

  • SERVER-60829 Tenant donor shouldn't use donorAbortMigration cancellation token when writing commit decision

  • SERVER-62300 Platform Support: Add support for Ubuntu 22.04 x86

  • SERVER-63104 Make it easy to run jsCore locally again in a world with tests tagged by feature flag

  • SERVER-65177 Elapsed initial sync time in TestRemainingInitialSyncEstimatedMillisMetric unit test can be 0 ms

  • SERVER-65259 Cursor leak in aggregation that requires merging on shard

  • SERVER-65385 Disable threshold checks for Google Microbenchmarks on DEBUG/Sanitizer variants

  • SERVER-66337 Ensure that check for the interrupt is done on every getNext() call in datasize_kill_op.js

  • SERVER-66466 Remove TransportLayerASIOTest dependence on ThreadContext

  • SERVER-66570 Timeseries pushes down metaField-projections that can change semantics

  • SERVER-66920 Crash in debug builds due to WiredTigerIndexCursorBase::seekWTCursor assertion not following search_near comparison semantics

  • SERVER-67290 Repair doesn't handle recordIds correctly for clustered collections

  • SERVER-67406 Sorting a cursor on sharded coll returns documents that are missing $-prefixed fields

  • SERVER-67795 Add serverstatus tracking to know how many users use updateMany and DeleteMany

  • SERVER-67898 BalancerCollectionStatus return wrong chunk size for session collection

  • SERVER-68125 Index build on multi-key fields can consume more memory than limit

  • SERVER-68338 sync_source_changes.js needs to wait for heartbeat

  • SERVER-68500 multiversion tag files are not correctly excluding tests in CI

  • SERVER-68576 We need to know how many sharded collections exist in a cluster

  • SERVER-68769 If a shard key index cannot be dropped then a user should not be able to hide that index

  • SERVER-68853 Remove invariant that a session stat needs to be a slow op stat

  • SERVER-68901 Incorrect $elemMatch query analysis in mongocryptd if document contains 2 different fields with the same name

  • SERVER-69160 Make ShardingTest wait for FCV initialization before running getClusterParameter tests

  • SERVER-69497 Have internal_sessions_reaping_basic.js oplog application use batches of size 1

  • SERVER-69603 Do not report drop events as part of shardCollection

  • SERVER-69890 Concurrent movePrimary and removeShard can move database to a no-longer existent shard

  • SERVER-69902 Stop bucket_unpacking_with_sort_plan_cache.js from running in parallel with fsyncLock tests

  • SERVER-69944 Resmoke's globstar.py does not properly parse * before **

  • SERVER-70024 ldap_provider_check.js needs to be updated for rhel9

  • SERVER-70100 Ensure that shardCollection emits an oplog event on commit time at least once in case of step-down

  • SERVER-70139 listCollection returns duplicate view names

  • SERVER-70158 Fix undefined argument order for $atan2 in SBE

  • SERVER-70237 Chunks merge commit must not create a BSON object too large

  • SERVER-70323 Convert invariant to tassert in collection_sharding_runtime

  • SERVER-70394 Fix self-swap in MultiPlanStage::removeRejectedPlans

  • SERVER-70553 Add module support to the mongo test runner

  • SERVER-70594 Add updated build variants to sys-perf

  • SERVER-70694 Platform Support: Add support for RHEL9 ARM64

  • SERVER-70720 Evergreen for WT should capture parent process id as part of top output

  • SERVER-70768 balancer use wrong chunk size for jumbo chunks

  • SERVER-70973 Balancer should stop iterating collections when there are no more available shards

  • SERVER-71006 Small window of inconsistency for reads after turning index to multikey

  • SERVER-71020 Ensure aborting time series batch eventually removes bucket from catalog

  • SERVER-71055 OplogOrder test can read stale all_durable timestamp after rolling back oplog entries

  • SERVER-71089 Run signing tasks on a single distro

  • SERVER-71094 Handle other transient election failures in fcbs_election_during_storage_change

  • SERVER-71139 Ensure indexes with simple collation are created correctly during initial sync

  • SERVER-71167 txn_index_catalog_changes.js session garbage collection can deadlock with fsync lock in consistency checks

  • SERVER-71191 Deadlock between index build setup, prepared transaction, and stepdown

  • SERVER-71225 Make sure collation.js does not change 'db'

  • SERVER-71247 DocumentSourceBackupFile should ensure backup cursor is open before returning data

  • SERVER-71249 Remove buildvariant task overrides for .publish tags

  • SERVER-71328 Ensure correct filtering metadata on donor shard after multiple failures

  • SERVER-71399 Jumbo chunk flag isn't automatically cleared after a chunk split

  • SERVER-71424 Fix failures in lint_fuzzer_sanity

  • SERVER-71435 Increse verbosity level for range-deleter in resmoke

  • SERVER-71436 Range deleter must not aggressively spam the log when shard key index not found

  • SERVER-71449 Fix log_successs_msg: not found in init.d on debian

  • SERVER-71467 Dont run feature flag specific tests for multiversion testing

  • SERVER-71471 Improve jstestfuzz deployment to work with new node run/install

  • SERVER-71473 Begin using the new test stats location

  • SERVER-71477 Check '_internalAllCollectionStatsSpec.getStats()' exists (boost::optional) before calling 'makeStatsForNs' in 'document_source_internal_all_collection_stats.cpp'

  • SERVER-71479 Merging chunks must not set validAfter to the current wall time

  • SERVER-71518 Use S3 test stats in mongo-task-generator

  • SERVER-71534 lint_fuzzer_sanity_all regression caused by running multiple instances of npm

  • SERVER-71568 Fix race condition related to ChangeStreamOptions access

  • SERVER-71597 Fix race condition on createDatabase for case sensitive dbName

  • SERVER-71609 splitOrMarkJumbo must not over-split chunks

  • SERVER-71614 Add a case to accept to hide an index if it is not compatible with shard key

  • SERVER-71632 Re-enable dropDatabase FSM test in stepdown suites

  • SERVER-71638 Don't let to hide the last shard key index using a key pattern

  • SERVER-71666 Reduce number of scanned index entries on chunk migration commit

  • SERVER-71668 Move isLastNonHiddenShardKeyIndex check after hide index on system collection and hide _id index in coll_mod.cpp

  • SERVER-71691 Error 5643004 when using $setWindowFields in a facet

  • SERVER-71726 Increase timeout of server_discovery_and_monitoring_json_test

  • SERVER-71756 Defragmentation policy should issue dataSize commands with estimate true

  • SERVER-71759 dataSize command doesn't yield

  • SERVER-71769 Add a new log message when a secondary node is skipping a two-phase index build

  • SERVER-71771 Defragmenter should cap chunk size estimation

  • SERVER-71787 Balancer needs to attach forceJumbo to moveRange command

  • SERVER-71788 Defragmentation should handle ChunkTooBig errors

  • SERVER-71880 _shardsvrDropCollectionParticipant with fromMigrate=true does not abort index builds

  • SERVER-71921 Task update_timeseries_fuzzer times out on some variants

  • SERVER-71924 Reduce verbosity of chunk merge change log event

  • SERVER-71939 Update BucketCatalogTest::Task class with failpoint

  • SERVER-71982 Add directConnection=True to standalone.py for multiversion testing

  • SERVER-72005 Enable TSBS on 2022-11 sys-perf variants

  • SERVER-72011 Add the ability to load js files to fsm worker threads.

  • SERVER-72021 Fix Enterprise SLES 12 crypt_create_lib Evergreen Failure

  • SERVER-72065 The logical sessions cache cannot be refreshed in secondary nodes of the CSRS

  • SERVER-72091 Enable auth-delay sys-perf variant

  • SERVER-72176 MetadataManagerTest must reset orphanCleanupDelaySecs to the default value on teardown

  • SERVER-72222 MapReduce with single reduce optimization fails when merging results in sharded cluster

  • SERVER-72276 Remove all outdated entries from backports_required_for_multiversion_tests.yml

  • SERVER-72288 microbenchmark tests fail after "Enable M1 Mac support for DSI"

  • SERVER-72408 Default timeout for receiveChunkWaitForRangeDeleterTimeoutMS is too low at agg_collstats_expr.js

  • SERVER-72416 The find and findAndModify projection code does not honor the collection level collation

  • SERVER-72422 FCBIS may never truncate the oplog

  • SERVER-72423 FCBIS will never delete drop-pending tables

  • SERVER-72483 Disable KMIP tests on s390x

  • SERVER-72506 Fix key error in benchmarks analysis script

  • SERVER-72533 Shards must send validAfter field on _configsvrCommitChunksMerge on v6.0

  • SERVER-72535 Sharded clusters allow creating the 'admin', 'local', and 'config' databases with alternative casings

  • SERVER-72581 Increase timeout for replica_sets_jscore_passthrough on macos-arm64 variant

  • SERVER-72613 Speed up taking core dumps with the hang analyzer

  • SERVER-72831 Fix use after move in sharding_util::processShardResponses

  • SERVER-72877 Mongos retargeting logic in stepdown hooks should skip views

  • WT-9268 Delay deletion of the history store record to reconciliation

  • WT-9428 Fix two asserts in rec_visibility.c

  • WT-9592 Rollback to stable should also clear WT_UPDATE_TO_DELETE_FROM_HS flag

  • WT-9637 WiredTiger strict compilation failure with gcc-11 on ubuntu 22.04

  • WT-9705 Fix accidentally freeing update on the update chain in prepared commit

  • WT-9751 Fix a memory leak in reconciliation after aborted eviction

  • WT-9765 Fix handling a prepared commit after a prepared rollback with eviction failure

  • WT-9805 Save the updates need to be deleted from history store and delete them later

  • WT-10062 Fix checkpoint cleanup not to skip the internal pages

  • WT-10081 Fix failure format configs for older branch

  • WT-10250 Remove certain Evergreen builders for release branches

  • WT-10291 Ensure failure configs task executes test format once per configuration.

  • SERVER-68371 Enabling CSFLE in your MongoClient causes Atlas Search to fail

  • SERVER-70559 tag FLE2 tests such that they do not run with stepdown suites

  • SERVER-63668 Guard the chunk splitter behind the no more auto-splitter feature flag

  • SERVER-66916 The range deleter configuration parameters are not dynamically changeable

  • SERVER-67466 Internal transactions API may be memory unsafe when outer OperationContext is interrupted

  • SERVER-67891 Implement basic structure of $shardedDataDistribution stage

  • SERVER-68139 Resharding command fails if the projection sort is bigger than 100MB

  • SERVER-68249 Add required privileges on the $shardedDataDistribution aggregation stage

  • SERVER-68869 A retry of _configSvrReshardCollection can succeed causing resharding_coordinator_recovers_abort_decision.js to fail

  • SERVER-69134 Dropping a sharded collection doesn't get rid of the CSS entry

  • SERVER-69429 Missing checks in collMod for shard key and unique index

  • SERVER-69444 Make the joining of concurrent critical section and refresh look the same between DSS and CSS

  • SERVER-69700 Replication rollback fails resharding_coordinator_recovers_abort_decision.js

  • SERVER-69756 Segmentation fault on abortReshardCollection issued right after reshardCollection cmd

  • SERVER-69897 Exclude internal_transactions_setFCV.js FSM workload from concurrency_simultaneous_replication*.yml test suites

  • SERVER-70364 Retry configureFailPoint command on network error (resharding_coordinator_recovers_abort_decision.js)

  • SERVER-70373 Invariant failure in case resharding metrics are not restored

  • SERVER-70793 Make database metadata refresh first check new metadata under the IS lock before taking X lock

  • SERVER-70852 Recommit SERVER-66716 on v6.0

  • SERVER-71092 shard_id_test.cpp relies on a pure behavior of std::string::compare function

SERVER-69861 Uninterruptible lock guard in election causes FCBIS to hang

  • SERVER-60141 Upgrade timelib to 2021.09 or later

  • SERVER-66289 $out incorrectly throws BSONObj size error on v5.0.8

  • SERVER-70190 ExpressionSwitch::optimize() can leave expression tree in an invalid state leading to invariant failure

  • SERVER-70381 _internalSearchIdLookup stage violates a 5.0 precondition of the getOwnershipFilter function

SERVER-67793 log_progress_msg in init.d does not print message

  • SERVER-57417 Enable NoMoreAutoSplitter Feature flag

  • SERVER-60753 Removing index build entries from 'config.system.indexBuilds' can make mixed mode writes

  • SERVER-60829 Tenant donor shouldn't use donorAbortMigration cancellation token when writing commit decision

  • SERVER-62300 Platform Support: Add support for Ubuntu 22.04 x86

  • SERVER-62302 Platform Support: Add support for RHEL9 x86

  • SERVER-62760 Add information to query log line indicating when the new optimizer is used

  • SERVER-63811 mongos returns no results for $documents if the database doesn't exist

  • SERVER-64319 Coverity analysis defect 121642: Parse warning

  • SERVER-65191 Run StorageEngineRepairTest with wiredTiger

  • SERVER-65816 Change balancer policy to balance on data size rather than number of chunks

  • SERVER-66078 Adapt sessions collection balacing policy to data-size aware balancing

  • SERVER-66208 Remove chunk creation for shard collection with existing data

  • SERVER-66378 Adapt tests skipped when featureFlagBalanceAccordingToDataSize is enabled

  • SERVER-66525 errexit prevents capturing pip install log

  • SERVER-66614 Speed up unit tests on macOS

  • SERVER-66747 Increase deadline to wait for balancing in jstests/sharding/authCommands.js

  • SERVER-66753 Change BalancerPolicy::_getLeastLoadedReceiverShard currentMin type

  • SERVER-66781 Enable BalanceAccordingToDataSize feature flag

  • SERVER-66827 Balancer may skip a round if last randomly selected collection has balancing disabled

  • SERVER-66834 Zones created by defragmentation_util.js must always align with chunks

  • SERVER-66835 [test-only bug] Compare number of chunks in balancing_based_on_size.js

  • SERVER-66913 configureCollectionBalancing() should return NamespaceNotSharded when the requested collection cannot be processed

  • SERVER-66972 Database critical section does not serialize with ongoing refreshes

  • SERVER-67231 Use assert.adminCommandWorkedAllowingNetworkError in fcbis_fails_if_backup_cursor_is_already_open_on_sync_source.js

  • SERVER-67301 Balancer may perform one unnecessary migration for a completely balanced collection

  • SERVER-67346 Disable autosplit on config.system.sessions when upgrading the cluster to avoid crashes on shard primaries

  • SERVER-67619 Increase the build frequency of the s390x variant

  • SERVER-67681 Create specific target for compile commands

  • SERVER-67733 ShardingTest::awaitBalancerRound() doesn't work in case of CSRS stepdowns

  • SERVER-67739 tenant_migration_donor_retry.js state docs can be cleaned up prior to assertions against them

  • SERVER-67809 Execute insert_with_data_size_aware_balancing.js in stepdown suites

  • SERVER-67813 Review "requires_fcv_61" tags when data size aware balancing lands in v6.0

  • SERVER-67898 BalancerCollectionStatus return wrong chunk size for session collection

  • SERVER-68115 Bug fix for "elemMatchRootLength > 0" invariant trigger

  • SERVER-68157 AuditEncryptionCompressionManager::encryptAndEncode should emit big BSON

  • SERVER-68233 MongoShell numberDecimalsAlmostEqual(NumberDecimal(0), NumberDecimal(0)) returns false

  • SERVER-68394 Ensure we do not yield strong locks upon startup recovery when _id index is missing

  • SERVER-68484 Increase threshold to consider a collection balanced in balancing_based_on_size.js

  • SERVER-68541 Concurrent removeShard and movePrimary may delete unsharded collections

  • SERVER-68893 Remove unnecessary ticketholder benchmarks

  • SERVER-69001 Initial sync should set the minValid document to the "stopTimestamp"

  • SERVER-69037 SBE plan cache size calculation is slightly off

  • SERVER-69069 InTel would like to be able to specify a subset of collections in the data-size distribution API

  • SERVER-69133 remove redundant setting of hardlink install action

  • SERVER-69136 Tests should consider balancerCollectionStatus may report balancerCompliant too early

  • SERVER-69160 Make ShardingTest wait for FCV initialization before running getClusterParameter tests

  • SERVER-69224 Skip AuditEncCompManagerTest.EncryptAndEncodeLargePayloadSucceeds When GCM not supported

  • SERVER-69281 Force minimum ninja version

  • SERVER-69348 Commands must declare empty auth checks to be universally callable

  • SERVER-69353 Generate burn_in tasks separately

  • SERVER-69380 $_internalUnpackBucket stage can incorrectly swap with a $project if an inclusion projection has already been absorbed

  • SERVER-69389 Command checkAuthorization may throw ErrorCodes::NamespaceNotFound for existing collection while trying to resolve UUID to namespace when the node is shutting down.

  • SERVER-69446 Increase electionTimeoutMillis in jstests/replsets/dbcheck_write_concern.js

  • SERVER-69447 Add a query knob to control version of Cost Model coefficients

  • SERVER-69465 Accept same specs for $_internalAllCollectionStats as $collStats

  • SERVER-69603 Do not report drop events as part of shardCollection

  • SERVER-69784 Fix instances of signed char misuse

  • SERVER-69793 Disable memory underflow check in the query system

  • SERVER-69849 [v6.0] Delete FifoBasicMetrics unit test

  • SERVER-69868 Return an error when starting a TransportLayer that is shutdown

  • SERVER-69898 Wait for the critical section catch-up phase before refreshing the DB version

  • SERVER-69912 SConstruct is executable by mistake

  • SERVER-69917 Implement _clusterWriteWithoutShardKey command

  • SERVER-69926 errorcodes.py doesn't detect duplicate errors in MONGO_UNREACHABLE_TASSERT

  • SERVER-69929 Skip Strict API testing if required feature flags are not enabled

  • SERVER-69930 Unexpected error message in the logs attempting to refresh the version of a dropped database

  • SERVER-70062 Log pertinent info about oplog entries in oplog rolled over restore failure

  • SERVER-70170 Update ssl_helpers.js for Amazon 2022

  • SERVER-70181 Ubuntu and Debian package tests failing in Server master

  • SERVER-70209 List new timelib library in 3rd-party components

  • SERVER-70211 Remove applying overrides boilerplate code in CostModelManager

  • SERVER-70226 rhel9 Support for YUM publishing

  • SERVER-70274 Improve performance of change stream pre-images purging job by leveraging EOF filter

  • SERVER-70299 Remove JSON.send command usage

  • SERVER-70314 Adjust time series extended range tests to account for log retention limitations

  • SERVER-70348 Remove EAGAIN for queryable WT and retry internally

  • SERVER-70361 OperationContext wait should handle out of range durations

  • SERVER-70436 Restrict cases where isCoveredNullQuery can apply

  • SERVER-70469 Use virtual env python in watchdog tests

  • SERVER-70475 Fix signed integer comparison issue in older boost thread library

  • SERVER-70483 Update Resmoke to pass "evergreen_execution" up to logkeeper.

  • SERVER-70484 Remove signal processing module from perf.yml and sys_perf.yml

  • SERVER-70602 Handle faulty balancerCompliant reporting by waiting for some no-op balancing rounds

  • SERVER-70725 Cluster aggregate may incorrectly result in CollectionUUIDMismatch if fetching routing info fails

  • SERVER-70814 Remove const qualifier in _createCmdObj() method signature

  • SERVER-70834 fix tasks which don't use scons cache from reporting failure

  • SERVER-70864 Get rid of fine grained scoped range deleter lock

  • SERVER-70879 Fix race where multiple threads are turning an index multikey concurrently

  • SERVER-71112 Fix count of resharding errors in Resharding Recipient unit test

  • WT-9792 Fix RTS to remove globally visible update of the data store update from the history store

  • WT-9926 A crash during startup from backup can lose metadata

SERVER-66554 Make FLE2 suites work with stepdown and kill_primary suites

  • SERVER-61035 Increase zones in 'resharding_large_number_of_initial_chunks.js' to 175,000

  • SERVER-61985 resharding_coordinator_recovers_abort_decision.js may report resharding operation as succeeding due to primary shard retrying _configsvrReshardCollection and running a second resharding operation

  • SERVER-66331 Additional $searchMeta test coverage

  • SERVER-67193 Ensure Coordinator Began Resharding Before setFCV in setfcv_reshard_collection.js

  • SERVER-68094 Resharding with custom generated _id fails with projection error

  • SERVER-68139 Resharding command fails if the projection sort is bigger than 100MB

  • SERVER-68495 Resharding a collection with a very large number of zones configured may stall on config server primary indefinitely

  • SERVER-68628 Retrying a failed resharding operation after a primary failover can lead to server crash or lost writes

  • SERVER-68728 Add addl. activation condition for interruptBeforeProcessingPrePostImageOriginatingOp fail point

  • SERVER-68869 A retry of _configSvrReshardCollection can succeed causing resharding_coordinator_recovers_abort_decision.js to fail

  • SERVER-68890 Remove error code conversions in the MigrationSourceManager commit path

  • SERVER-69220 refineCollectionShardKey permits toggling current shard key fields between range-based and hashed, leading to data inconsistency

  • SERVER-69700 Replication rollback fails resharding_coordinator_recovers_abort_decision.js

SERVER-68548 mongo shell version 4.4.15 logging asio message despite --quiet flag

  • SERVER-60551 Occasionally getting "Initialized wire specification" when connecting

  • SERVER-61281 Fix underflow when accounting for Document size in query memory tracker

  • SERVER-63191 Create Task that Generates Version Metadata Earlier

  • SERVER-63843 Don't allow recursive doLog in synchronous signal handlers

  • SERVER-63852 getThreadName() should not crash

  • SERVER-65317 mongod removes connection from connection pool after running simple $search query

  • SERVER-65382 AutoSplitVector should not use clientReadable to reorder shard key fields

  • SERVER-65435 Config fuzzer can set eviction trigger lower than amount of dirty data a single operation may generate

  • SERVER-65781 Have shell fixtures be symbolized

  • SERVER-66436 Fix initialisation error in DConcurrencyTest benchmarks

  • SERVER-66613 Send binary version instead of evergreen version to symbolizer service

  • SERVER-66726 Fix serialization in killAllSessionsByPattern

  • SERVER-66794 Add an in-memory flag for TS collections having dates outside years 1970-2038

  • SERVER-66804 Remove check_binary_version from test setup

  • SERVER-66841 LOGV2: invalid JSON when truncation happens at a backslash character

  • SERVER-67126 Remove LOGV2 call from printStackTrace no-LOGV2 codepath

  • SERVER-67239 Improve timeout handling in set_audit_config test

  • SERVER-67280 Ensure HealthObserver::periodicCheckImpl() implementations handle exceptions and return an appropriate failing health check status when one occurs

  • SERVER-67296 Mark the OpCtx of the configsvr commands used to commit chunk-related DDL ops as interruptible

  • SERVER-67385 Range deletion tasks may be wrongly scheduled before ongoing queries on range finish on a shard primary

  • SERVER-67402 Linearizable reads can occasionally read with wrong read source

  • SERVER-67538 Multi-doc transactions should fail if on an old, incompatible snapshot

  • SERVER-67605 Make retryable_findAndModify_commit_and_abort_prepared_txns_after_failover_and_restart.js not test restart with a 1-node shard

  • SERVER-67650 Resharding recipient can return remainingOperationTimeEstimatedSecs=0 when the oplog applier hasn't caught up with the oplog fetcher

  • SERVER-67653 Resharding coordinator can incorrectly conclude that it can start the critical section although on one recipient the oplog applier hasn't caught up with the oplog fetcher

  • SERVER-67666 Allow watching system.buckets collections in full cluster change streams

  • SERVER-67679 Concurrent collection drops can return NamespaceNotFound instead of CollectionUUIDMismatch

  • SERVER-67725 Check catalog consistency on shards as precondition for rename

  • SERVER-67728 Use FeatureFlagUtil in timeseries jstests

  • SERVER-67787 Retry mutation ops in auth concurrency tests

  • SERVER-67814 Track the number of time-series collections with dates outside 1970-2038 in serverStatus

  • SERVER-67846 Tests relying on featureFlagCollModIndexUnique should check FCV 60

  • SERVER-67909 Skip dropping a non-existent temp ECOC collection in the compact coordinator

  • SERVER-67916 Race during stepdown can trigger invariant in ReshardingMetrics

  • SERVER-67939 run_dbcheck_background.js should be resilient to CappedPositionLost

  • SERVER-68003 Make experiment_unified_ninja.vars the default

  • SERVER-68126 Check for negative maxChunkSize input value in AutoSplitVector

  • SERVER-68207 Add collStats for system collections to clusterMonitor role

  • SERVER-68399 Fix parsing of safeint version numbers in blackduck_hub.py

  • SERVER-68441 collection_uuid_index_commands.js not robust to failover

  • SERVER-68461 Persist the result of the doCompactOperation in the Pre-6.1-compatible compaction coordinator

  • SERVER-68465 selinux tests fail due to journal.enabled parameter

  • SERVER-68475 Find solution to relocation overflow in static builds

  • SERVER-68477 Improve NaN-handling for expireAfterSeconds TTL index parameter

  • SERVER-68479 collMod coordiantor V2 must block migration on bucket nss

  • SERVER-68521 Restore timeout in awaitdata_getmore.js

  • SERVER-68540 Add docker_incompatible tag for jscore tests

  • SERVER-68568 future_git_tag should override MONGO_VERSION

  • SERVER-68637 Add scons cache to enterprise-rhel-72-s390x-compile builder

  • SERVER-68694 Investigate the locking around the compact command

  • SERVER-68766 Add option to re-enable single value MapReduce optimization

  • SERVER-68790 Fix multiversion tests which rely on the renamed internalQueryFrameworkControl knob

  • SERVER-68886 Remove extra call to addEagerlyReapedSession in internal transactions reap service unittest

  • SERVER-68905 Add append_oplog_note_mongos.js to backports_required_for_multiversion_tests.yml

  • SERVER-68925 Reintroduce check table logging settings at startup (revert SERVER-43664)

  • SERVER-68937 Improve task splitting based on historic tests runtime

  • SERVER-68950 Update ssl_helpers.js for Ubuntu 22.04

  • SERVER-68951 Fix kerberos_tool.js and ldap_authz_authn.js on Ubuntu 22.04

  • SERVER-69006 Add more tracing to fle basic insert/update/replace for hedged reads

  • SERVER-69052 Ensure bucket collection is valid when checking for extended range

  • SERVER-69103 Disable use of SBE on the inner side of DocumentSourceLookup

  • SERVER-69108 SCCL can immediately return config and admin metadata without triggering a refresh

  • SERVER-69118 Have retryable findAndModify failover internal transaction test wait until lastCommittedOpTime is recovered after failover

  • SERVER-69141 [6.1] Move forward pinned TSBS version

  • SERVER-69167 Check if FCV is initialized before performing feature flag check in setClusterParameter and getClusterParameter

  • SERVER-69175 Add transport::SocketOption template for making ASIO-style sockopt types

  • SERVER-69207 Coverity analysis defect 122696: Using a moved object

  • SERVER-69265 Increase config_fuzzer_replica_sets_jscore_passthrough timeout

  • SERVER-69284 Remove FifoTicketHolder

  • SERVER-69290 Disable sharding/refine basic test in 6.0

  • SERVER-69376 Increase timeout for replica_sets_jscore_passthrough on macos variant

  • SERVER-69475 Remove unused updateConcurrentTotalTransactions() method

  • SERVER-69569 Python scripts failing in Evergreen tasks

  • SERVER-69611 Set the -ffp-contract=off compiler option by default

  • SERVER-69693 Use lambda instead of repeating code in resharding coordinator

  • SERVER-69707 [SBE] Undefined slot error for $group with $cond / $switch / $ifNull expressions

  • SERVER-69785 robustify change_streams_per_shard_cursor.js

  • SERVER-69793 Disable memory underflow check in the query system

  • SERVER-69849 [v6.0] Delete FifoBasicMetrics unit test

  • WT-9323 Fix a race tracking whether a tree has updates after a checkpoint

  • WT-9599 Acquire the hot backup lock to call fallocate in the block

  • WT-9763 Return EBUSY if the time window of inserting record does not match with history store time window

  • WT-9870 Fix updating pinned timestamp whenever oldest timestamp is updated during recovery

  • SERVER-57519 Make ARS use causally consistent ShardRegistry::getShard() function

  • SERVER-64340 Warn if balancer is disabled while draining shard

  • SERVER-67457 Resharding operation aborted in the midst of contacting participants may stall on config server primary indefinitely

  • SERVER-67477 Ensure range deletion index is created on addShard (6.0 only)

  • SERVER-67492 Failed chunk migrations can lead recipient shard to have divergent config.transactions records between primary and secondaries

  • SERVER-67535 move_chunk_large_chunk_map_workloads no longer reports timing breakdown of chunk migration due to server logging changes

  • SERVER-68431 resharding_test_fixture doesn't configure failpoints for all nodes of config server

SERVER-68062 Multi-stage aggregations that use $geoNear may violate constraints.

SERVER-66808 Remove undocumented fields from the change stream error

  • SERVER-61481 Remove check in dropIndexes command that no index builds are in progress for the collection once kLastLTS is 6.0

  • SERVER-62857 Handle same-migration recovery on recipient upon multiple stepdowns

  • SERVER-62969 Fix ocsp_unable_to_staple_log.js wait to connect issue

  • SERVER-64112 Stop running applicable multiversion tests as soon as a release is EOL

  • SERVER-64242 Make collStats aggregation stage retrieve orphans from BalancerStatisticsRegistry

  • SERVER-64416 Have view creation return the same error as collection creation

  • SERVER-65006 Write conflict on commitIndexBuild oplog entry insertion can cause multikey to fail to be set

  • SERVER-65262 Expand usage of WT numerical timestamp API

  • SERVER-65385 Disable signal processing for Google Microbenchmarks on DEBUG/Sanitizer variants

  • SERVER-65454 Retried findAndModify requests can slow log/profile into the wrong namespace

  • SERVER-65657 Reduce calls to the cappedInsertNotifier for the oplog

  • SERVER-65884 $lookup from time-series can place $sequentialCache after correlated $match

  • SERVER-66023 Do not constantly reset election and liveness timers

  • SERVER-66027 Speedup tenant migration JS tests

  • SERVER-66034 backports_required_for_multiversion_tests.yml is not blacklisting tenant migration tests from running on multiversion test suites

  • SERVER-66246 Optimize Tenant Migration Concurrent test runtime

  • SERVER-66247 Refactor api_version jstests to pass view name to assertViewSucceedsWithAPIStrict helper

  • SERVER-66308 Restore views test for 'sbe' command to satisfy multiversion testing

  • SERVER-66310 Make ExpressionSetUnion::isCommutative() collation aware

  • SERVER-66348 Add a kill_sessions tag to exclude tests in concurrency simultaneous replication suites

  • SERVER-66461 Run notarization earlier in the build process

  • SERVER-66508 Make explain handling consistent between csfle and mongocryptd

  • SERVER-66529 The oplog manager thread updating the oplogReadTimestamp can race with a cappedTruncateAfter operation directly updating the oplogReadTimestamp

  • SERVER-66548 $lookup sequential cache can incorrectly treat a $facet as non-correlated

  • SERVER-66651 Role "restore" not sufficient for mongorestore --preserveUUID

  • SERVER-66658 Shard registry might be accessed before initialization

  • SERVER-66938 Drastically simplify command to generate ninja files

  • SERVER-66943 Do not run aggregation for orphans against oplog.rs for collstats

  • SERVER-66958 Handle potential multiple "processing" range deletions on step-up

  • SERVER-66970 Add EOL'd releases information to the mongo repo

  • SERVER-67006 increase log vebosity for DEBUG assertion messages in replsets/profile.js

  • SERVER-67122 Add warning when building with --module=ninja that it is deprecated

  • SERVER-67188 Use -large instance for replica_sets_jscore_passthrough on Windows

  • SERVER-67227 Insert with collectionUUID could implicitly create a collection if command failed with collectionUUIDMismatch

  • SERVER-67259 Change sleep for assert.soon in ttl_deletes_not_targeting_orphaned_documents.js

  • SERVER-67305 Lock-free reads setup should validate writes permitted before and after setting up snapshot.

  • SERVER-67377 Check whether $lookup pushdown feature availability on primary shard in mixed version cluster

  • SERVER-67390 backup_restore.js should check for code -SIGINT due to unclean SIGINT

  • SERVER-67395 Increase the timeout of sharding_update_v1_oplog_jscore_passthrough task to 2.5 hours on macos-arm64

  • SERVER-67408 CollectionUUIDMismatch error can be hidden if database does not exist

  • SERVER-67418 Retry SSLManagerApple global initialization

  • SERVER-67422 Have getAllRemovalFuturesForCoordinatorsForInternalTransactions wait for TransactionCoordinator catalog recovery

  • SERVER-67428 secondary_dryrun_vote_timeout.js should wait for "Voted for importCollection" log message on the secondary

  • SERVER-67430 Fix tags in fle2 tests and improve tag parser

  • SERVER-67462 Support renaming encrypted collections if client has correct privileges

  • SERVER-67486 "command failed because of stale config" failure in catalog shard POC

  • SERVER-67523 Must clear _nextCall on reschedule failure in delayable_timeout_callback

  • SERVER-67527 add kills_random_sessions to concurrency_replication_for_export_import.yml

  • SERVER-67532 Fail less in OplogServerStatusSection

  • SERVER-67625 Spike OIDC SASL Mechanism Negotiation

  • SERVER-67648 [v6.0] Tag timeseries_delete_hint.js and timeseries_update_hint.js with requires_fcv_60

  • SERVER-67683 Change some of the modes in fast and opt builds

  • SERVER-67690 Use mongo-task-generator that randomizes test order

  • SERVER-67700 limit does not get pushed to shards in search queries

  • SERVER-67717 ${suffix} is not set in push task

  • SERVER-67723 SessionCatalogMongoD reaper can interrupt expired internal transaction sessions for retryable writes that are still in use

  • SERVER-67800 [6.0] Exclude clustered_collection_*.js from multiversion suites

  • SERVER-67801 createIndexes should handle empty index specs on config.transactions

  • SERVER-67802 mongos count does not handle large values for skip

  • SERVER-67804 [6.0] Exclude dbstats.js from multiversion suites

  • SERVER-67845 Acquire critical section in rename "check preconditions" phase only if target not sharded

  • SERVER-67885 shardCollection with a mismatched UUID on a capped collection will fail first with InvalidOptions

  • SERVER-67911 Random distribution of test data in accumulator_fix_last_[continuous|lts].js can cause occasional test failure

  • SERVER-67917 Use DBDirectClient in FLE count code path

  • SERVER-67992 Use operation timer tracker in fle mongos crud processing

  • SERVER-68016 Use little endian for deserializing data serialized by BufBuilder

  • SERVER-68041 Robustify merge_write_concern.js and add diagnostic log

  • SERVER-68130 AutoSplitVector could generate response bigger than BSONObjMaxUserSize

  • SERVER-68158 serverstatus_indexbulkbuilder.js should run listIndexes on primary after creating indexes

  • SERVER-68184 Use Number instead of NumberLong when indexing in checkWritesOfCommittedTxns

  • SERVER-68193 Sharding DDL coordinator can lock itself out in distlock retry loop

  • SERVER-68196 Memory usage for BoundedSorter is invalid when sorting then grouping.

  • SERVER-68201 Add the commit queue variant to the release branch's evergreen config

  • SERVER-68209 Remove uassert that prevents config.image_collection entry from being invalidated

  • SERVER-68330 [6.0] Allow mixed_mode writes on config.transactions

  • SERVER-68354 Set whenToClean to now when marking range deletion task as processing

  • SERVER-68363 Mark 5.3 as EOL

  • SERVER-68405 Constant Nothing in $group's _id expression should be converted to null in $group SBE stage builder

  • SERVER-68443 InternalTransactionChunkMigrationTest and RetryableInternalTransactionTest fixtures should retry internal transactions on all transient errors

  • SERVER-68463 [6.0] replsets/profile.js fails to set log level in replica_sets_multiversion suite

  • SERVER-68487 add BSONElement method to check for NaN field values

  • SERVER-68511 movePrimary might introduce sharding metadata inconsistency in MongoDB 5.0+

  • SERVER-68513 The _configsvrRunRestore command should restore databases with unsharded collections

  • SERVER-68526 Use mongo-task-generator that generates tasks separately for Windows, MacOS, Linux distro groups

  • SERVER-68574 Switch to the new logkeeper cluster

  • SERVER-68653 Fix compilation on gcc

  • WT-9302 Deprecated object_target_size as a config in api_data.py

  • WT-9311 Ensure log messages clearly identify storage HW corruption

  • WT-9432 Ensure Evergreen builds have debug information

←  Upgrade a Sharded Cluster to 6.0Release Notes for MongoDB 5.3 →