Docs Menu

Docs HomeMongoDB Manual

5.0 Changelog

On this page

  • 5.0.18 Changelog
  • 5.0.17 Changelog
  • 5.0.16 Changelog
  • 5.0.15 Changelog
  • 5.0.14 Changelog
  • 5.0.13 Changelog
  • 5.0.12 Changelog
  • 5.0.11 Changelog
  • 5.0.10 Changelog
  • 5.0.9 Changelog
  • 5.0.8 Changelog
  • 5.0.7 Changelog
  • 5.0.6 Changelog
  • 5.0.5 Changelog
  • 5.0.4 Changelog
  • 5.0.3 Changelog
  • 5.0.2 Changelog
  • 5.0.1 Changelog
  • SERVER-72146 Make chunk migrations metrics more accessible from Atlas

  • SERVER-76004 Remove incorrect sharding tassert in getOwnershipFilter function

  • SERVER-76516 Fix Concurrent Access of Clock in ReshardingRecipientServiceTest in 5.0 Branch

SERVER-48196 Upgrade the timelib to the latest to update the built-in timezone files to the latest

  • SERVER-54150 Recovery from a stable checkpoint should fassert on oplog application failures

  • SERVER-57056 Syslog severity set incorrectly for INFO messages

  • SERVER-60375 Blacklist move_chunk_remove_shard.js from sharding_csrs_continuous_config_stepdown

  • SERVER-62053 Add retry for errors in AWS server-side conversation

  • SERVER-63865 Handle missing index idents during standalone startup recovery after unclean shutdown

  • SERVER-66009 Ban $search when running in update pipeline (stub process interface is present)

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

  • SERVER-71089 Run signing tasks on a single distro

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

  • SERVER-72686 Add support for $collStats agg stage on timeseries collection

  • SERVER-73007 CURL_OPT_SEEKFUNCTION not set for multi-pass authentication

  • SERVER-73385 RenameCollectionCoordinator wrongly releases critical section for destination ns.

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

  • SERVER-74344 Ban use of sparse indexes on internal comparison expression unless explicitly hinted

  • SERVER-74997 Reduce the timeout of tlsOCSPVerifyTimeoutSecs to 4 seconds

  • SERVER-75010 Implement no-op planShardedSearch in 5.0

  • SERVER-75082 Make balancer migrations throttling configurable

  • SERVER-75360 Include $search result count (total hits) in slow query log

  • SERVER-75369 Fix the overflow of total possible enumeration count in LockstepOr enumeration strategy

  • SERVER-75479 Use system python on macos for ssl tests

  • SERVER-75626 Special handling for macosx venv

  • SERVER-75652 Migrate from notary client to garasign for push task

  • SERVER-75987 Synchronize the connection and server threads in transport_layer_test

  • SERVER-76039 PauseDuringStateTransitions guard needs correct initialization in DropsTemporaryReshardingCollectionOnAbort

  • SERVER-76063 Update the getFreeMonitoringStatus command to always return state: disabled

  • SERVER-76139 sync_source_changes.js should wait for node to no longer be newly added before asserting on selected sync source

  • SERVER-76179 "/var/run/mongodb/"mongod.pid" deleted on each Mongod shutdown

  • SERVER-76274 Move microbenchmarks to their own task distro

  • SERVER-76278 Log extra migration information

  • SERVER-76378 Use estimated impersonation metadata size in calculating block chunks

  • SERVER-76421 [5.0] ttl_expire_nan_upgrade.js checks indexes on node before it becomes secondary

  • SERVER-76498 Update push task to run on rhel8.7-small

  • SERVER-76599 Exclude jstests/sharding/balancer_collection_status.js from step-down suites

  • SERVER-76600 Increase timeouts for aggregation_timeseries_fuzzer on tsan/asan variants

  • SERVER-76619 Add setParameter to enable libcurl's verbose logging

  • SERVER-76690 Special handling for PYTHONPATH when activate venv

  • SERVER-76695 initial_sync_nodes_maintain_and_gossip_commit_point.js should wait longer for initial sync node to advance commit point

  • SERVER-76698 Disable Curl Connection Pooling for STS requests

  • SERVER-76699 Add configurable retry count in AWS IAM code

  • SERVER-76718 [v5.0] Push mongocryptd and create packages for RHEL 7 PPC in 5.0

  • SERVER-76721 Robustify plan_cache_stats_shard_and_host.js to count plan cache entries only for specific plan cache key

  • SERVER-76767 Disable 4.0 upgrade tests on v5.0 branch

  • WT-8570 Do not increase oldest ID during recovery

  • WT-8689 Switch Evergreen zSeries builder to RHEL distro

  • WT-8702 Limit oldest id to recovered checkpoint snapshot in recovery

  • WT-10551 Incremental backup may omit modified blocks

  • WT-10932 Disable many-collection-test on release branches

  • SERVER-73229 Logical sessions cache refresh ignores write errors from updating session document, leading to cursors being killed early

  • SERVER-73877 Wait for shard to have a primary before doing a migration in prepare_transaction_then_migrate.js

SERVER-75517 illegal format of _id possible via upsert

  • SERVER-66927 Remove reference to silentFail from mongo repo

  • SERVER-73400 Use -large Evergreen distro for compiling on arm64 in sys-perf project

  • SERVER-74647 Resharding state machine creation should be retried after interruption

  • SERVER-74720 The default 'shardingStatistics' serverStatus section takes locks

  • SERVER-74824 Add more expressive logging to map_reduce_drop.js

  • SERVER-75066 Check for parent directory before writing to SCons cache

  • SERVER-75172 Use unique collection name in partial_index_logical.js

  • SERVER-75261 "listCollections" command fails with BSONObjectTooLarge error

  • SERVER-75404 Designate $searchSortValues as metadata field on v5.0

  • SERVER-75431 Get rid or fix best effort check for primary db on rename path in sharded clusters

  • SERVER-75501 Don't run Sys-perf FCV variants on stable branches

  • SERVER-75561 Report and log more detailed information when validate encounters multikey inconsistencies

  • SERVER-75601 Make serverStatus apiversion field more robust

  • SERVER-75618 check oplog fast count before restarting server in oplog_sampling.js

  • SERVER-75745 Only log record and index metadata associated with missing or extra index keys

  • SERVER-75795 Update aws_e2e_ec2.js for evergreen changes to AWS test identity

  • SERVER-76098 Allow queries with $search and non-simple collations

  • SERVER-58466 Minor optimization on the CatalogCache: do not create a new routing table if the collection version hasn't changed

  • SERVER-62036 Failures in preCacheMongosRoutingInfo() will cause mongos to fail startup

  • SERVER-66542 Missing log/Update of the stats after the completion of a CatalogCache refresh

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

  • SERVER-73751 movePrimary shouldn't create indexes for sharded collections

  • SERVER-74124 Disallow sharding with wildcard shard key pattern

SERVER-63049 Track usage of agg accumulators

SERVER-75517 illegal format of _id possible via upsert

  • SERVER-51835 Mongos readPreferenceTags are not working as expected

  • SERVER-59169 Use larger machines for large inMemory tests

  • SERVER-60830 Missing index scan bound in time-series query rewrite

  • SERVER-61100 Fix multiversion tests that assert last-lts/last-continuous incompatibility

  • SERVER-61203 Add record metadata and history in validate output when corruption is detected

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

  • SERVER-62665 Ensure TransportLayerASIO::TimerService can safely end the session

  • SERVER-63637 Execution stats for $_internalBoundedSort

  • SERVER-63699 Proof of Concept of bounded-sort stage for time-series

  • SERVER-64093 Support spilling to disk in BoundedSorter

  • SERVER-64347 Add support for descending sort to the bounded sorter

  • SERVER-64348 Add support for compound sorts (meta, time) to the bounded sorter

  • SERVER-64349 Add heuristic-based planning support for bucket unpacking with sort

  • SERVER-64397 TimeSorter comparator int overflow

  • SERVER-64451 Ensure we don't try to access BoundedSorter heap if it is empty

  • SERVER-64602 Provide time-series bucket time bounds as document metadata for use by bounded sorter

  • SERVER-64654 Enable Feature flag for PM-2786

  • SERVER-64769 Make sure $_internalBoundedSort provides sort key for sharded mergesort

  • SERVER-65050 BUS planning work for point query on meta data

  • SERVER-65990 Test BUS w/ changing BucketMaxTimeSpan

  • SERVER-66012 Use a WiredTiger version cursor to print metadata of extra index entries during validation

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

  • SERVER-66558 $sort does not rewrite to bounded sort when multiple index options are available

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

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

  • SERVER-67780 Incorrect $group rewrite for timeseries collection when the accumulator uses meta field

  • SERVER-67950 Make stronger assertions in bucket_unpacking_with_sort_granularity_change.js

  • SERVER-68328 Add ResumableChangeStreamError label to ReadConcernMajorityNotAvailableYet errors

  • SERVER-68594 Add vscode format/lint on save

  • SERVER-69952 Filtering on dates outside of the 32 bit epoch range returns wrong results

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

  • SERVER-70747 Rename collection used in bucket_unpacking_with_sort_extended_range.js

  • SERVER-71178 Create project branch and flag for PM-2786

  • SERVER-71307 Aggregations with $search should fail if the resolved collation is non-simple

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

  • SERVER-71392 Track usage of JSON Schema for validation

  • SERVER-71750 Revert refactor into handleWriteConflictException in writeConflictRetry loop

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

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

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

  • SERVER-72519 Add arm and intel Microbenchmark test variants to Sys Perf

  • SERVER-72520 Decommission Microbenchmark performance tests that are running on CBI instances

  • SERVER-72542 fullValidate should not return a count of items

  • SERVER-72774 A node in quiesce mode can win election

  • SERVER-73110 bucket_unpacking_with_sort_extended_range.js fails in sharded passthrough

  • SERVER-73125 Builtin variable $$NOW is not available in document validation

  • SERVER-73157 Move out_max_time_ms tests to serial_run suite

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

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

  • SERVER-73400 Use -large Evergreen distro for compiling on arm64 in sys-perf project

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

  • SERVER-73521 [5.0] Backport setProfilingFilterGlobally command

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

  • SERVER-73732 Complete TODO listed in SERVER-61100

  • SERVER-73745 Zero initialize IndexKeyBucket struct

  • SERVER-73822 Time-series $group rewrite ignores certain accumulators

  • SERVER-74038 [Windows] Possible negative performance effects of SetProcessWorkingSetSize in SecureAllocator

  • SERVER-74045 Allow turning on diagnostic log messages for validate

  • SERVER-74103 Increase storage log verbosity in oplog_sampling.js

  • SERVER-74104 [v5.0] Disable journal flusher in validate_out_of_order.js

  • SERVER-74131 Multiplanning together with subplanning causes server crash in mapReduce queries

  • SERVER-74137 [v5.0] Tag validate_out_of_order.js with requires_replication

  • SERVER-74153 Fix blackduck_hub.sh 5.0 script

  • SERVER-74156 Package plist files with macosx releases

  • SERVER-74287 create scons OOM retry tool

  • SERVER-74345 mongodb-org-server 4.4.19, 5.0.15, 6.0.5 not starting after upgrading from older version (Debian, RPM Packages)

  • SERVER-74386 Don’t reset recordPreImages on collMod [6.0 only]

  • SERVER-74501 Fix MigrationBatchFetcher/Inserter completion reliance to not spawn an extra cleanup thread

  • SERVER-74631 Log index spec when validation detects index key inconsistencies

  • SERVER-74632 Log $collStats output when a collection fails validation

  • SERVER-74642 Log additional information about the oplog entry that generated a document or index key when printing metadata

  • SERVER-74647 Resharding state machine creation should be retried after interruption

  • SERVER-74690 Change Atlas Real variants to use “2022-11” workload client

  • SERVER-74824 Add more expressive logging to map_reduce_drop.js

  • SERVER-74845 Create mechanism to ignore ignore fork option with systemd

  • SERVER-74895 Expect command errors in validation when querying $collStats, and improve the error message

  • SERVER-75172 Use unique collection name in partial_index_logical.js

  • SERVER-75205 Deadlock between stepdown and restoring locks after yielding when all read tickets exhausted

  • SERVER-75397 Make v5.0/v4.4 required variants run every other day

  • SERVER-75404 Designate $searchSortValues as metadata field on v5.0

  • SERVER-75431 Get rid or fix best effort check for primary db on rename path in sharded clusters

  • SERVER-75561 Report and log more detailed information when validate encounters multikey inconsistencies

  • SERVER-75618 check oplog fast count before restarting server in oplog_sampling.js

  • WT-8333 Implement version cursor

  • 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-9629 Fix collection of compact progress statistics

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

  • WT-10027 Session txn dirty statistic is incorrect

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

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

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

  • SERVER-71219 Migration can miss writes from prepared transactions

  • SERVER-71305 Legacy shard collection path waits on wrong opTime to be majority committed (5.0 and older)

  • 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-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-58712 Inconsistent update performance on collections with multiple secondary indexes on same key

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-54900 Blocking networking calls can delay sync-source resolution indefinitely

  • SERVER-60839 Introduce a TemporarilyUnavailable error type

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

  • SERVER-64764 $expr rewrite is not prepared to handle "$$ROOT"

  • 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-65881 Support sort-limit optimization with bounded sort stage

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

  • SERVER-66106 sharded_moveChunk_partitioned.js failed moveChunk check may be incorrect (only pre-6.0)

  • SERVER-66466 Remove TransportLayerASIOTest dependence on ThreadContext

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

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

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

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

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

  • 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-68576 We need to know how many sharded collections exist in a cluster

  • 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-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-69944 Resmoke's globstar.py does not properly parse * before **

  • SERVER-70139 listCollection returns duplicate view names

  • SERVER-70323 Convert invariant to tassert in collection_sharding_runtime

  • SERVER-70369 Create serverParameter for migrationConcurrency

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

  • SERVER-70427 Remove chef+kitchen package test infrastructure

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

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

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

  • SERVER-70640 Add migrationConcurrency to serverStatus

  • SERVER-70830 Unit test WiredTigerOperationStats

  • 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-71191 Deadlock between index build setup, prepared transaction, and stepdown

  • SERVER-71291 Variant "* Enterprise RHEL 8.0" should not have a .publish file

  • SERVER-71373 Extend assert.soon timeout inside predictive_connpool.js

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

  • SERVER-71424 Fix failures in lint_fuzzer_sanity

  • 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-71471 Improve jstestfuzz deployment to work with new node run/install

  • SERVER-71533 Update legacy task generation to use new test stats location

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

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

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

  • SERVER-71648 [v5.0] txn_index_catalog_changes.js runs on storage engines that do not support snapshot reads

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

  • 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-71939 Update BucketCatalogTest::Task class with failpoint

  • 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-72005 Enable TSBS on 2022-11 sys-perf variants

  • SERVER-72046 Concurrent chunk migration testing

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

  • SERVER-72143 Fix sys-perf logkeeper links on 5.0 and 4.4

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

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

  • 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-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-72613 Speed up taking core dumps with the hang analyzer

  • 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-72868 Complete TODO listed in SERVER-30949

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

  • SERVER-72910 [v5.0] Backport wtRCToStatus changes from SERVER-60839

  • 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-73264 Fix wrong invariant in MigrationChunkClonerSource::commitClone

  • SERVER-73389 Checkpoint vector clock in drop database coordinator

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

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

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

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

  • SERVER-73745 Zero initialize IndexKeyBucket struct

  • WT-8290 Adding a new API to the session to return the rollback reason

  • WT-8379 Do not disable eviction during shutdown

  • WT-8651 Allow checkpoint scrub during shutdown

  • WT-8652 Do not skip the final metadata checkpoint when shutdown configured with use_timestamp=true

  • 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-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-9792 Fix RTS to remove globally visible update of the data store update from the history store

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

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

  • WT-10081 Fix failure format configs for older branch

  • WT-10250 Remove certain Evergreen builders for release branches

  • WT-10257 Fix data-validation-stress-test-checkpoint-fp-hs-insert-s7 in 5.0

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

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

  • WT-10584 Add missing read barriers in __cursor_skip_prev

  • SERVER-60143 Avoid clearing filtering metadata after failed metadata refresh

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

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

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

  • 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-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-71092 shard_id_test.cpp relies on a pure behavior of std::string::compare function

  • SERVER-71305 Legacy shard collection path waits on wrong opTime to be majority committed (5.0 and older)

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

  • 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-54284 ExceptionFor<ErrorCodes::WriteConflict> should resolve to WriteConflictException

  • SERVER-57072 Explore upgrading wheel on all platforms.

  • SERVER-60016 serverStatus and collection stats should not block on the RSTL lock

  • SERVER-61185 Use prefix_search for unique index lookup

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

  • SERVER-63585 Fastcount gets out of sync when a delete rollbacks and another transaction deletes the same rows

  • SERVER-66525 errexit prevents capturing pip install log

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

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

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

  • SERVER-67681 Create specific target for compile commands

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

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

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

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

  • SERVER-69133 remove redundant setting of hardlink install action

  • SERVER-69281 Force minimum ninja version

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

  • 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-69569 Python scripts failing in Evergreen tasks

  • SERVER-69784 Fix instances of signed char misuse

  • 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-69926 errorcodes.py doesn't detect duplicate errors in MONGO_UNREACHABLE_TASSERT

  • 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-70160 Do not push down $match that needs whole document before $internalUnpackBucket

  • 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-70469 Use virtual env python in watchdog tests

  • 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-70557 Increase timeout for integration_tests_sharded on s90x

  • SERVER-70633 Make per shard cursors suite actually run tests in 5.0

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

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

  • WT-8234 Prevent eviction of internal pages while reconciling leaf pages which could refer to their memory

  • 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 manager

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

  • 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-68869 A retry of _configSvrReshardCollection can succeed causing resharding_coordinator_recovers_abort_decision.js to fail

  • SERVER-69142 A retry of _shardsvrReshardCollection can cause DuplicateKey error (resharding_nonblocking_coordinator_rebuild.js)

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

  • SERVER-69384 Fix v5.0 legacy shardCollection path for implicitCreateIndex parameter

  • SERVER-69700 Replication rollback fails resharding_coordinator_recovers_abort_decision.js

SERVER-50454 Avoiding sending the "keyValue" field to drivers on duplicate key error

  • SERVER-58673 Enable featureFlagPerShardCursor

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

  • SERVER-61185 Use prefix_search for unique index lookup

  • SERVER-62400 Add $_passthroughToShard parameter to AggregateCommandRequest

  • SERVER-62681 Create change streams per shard cursor passthrough suite

  • SERVER-62738 Give mongos the ability to passthrough to a specific shard

  • SERVER-63772 Post Batch Resume token not sent on initial batch from per shard cursor change stream

  • SERVER-63773 Per Shard cursor post batch resume token not set in getMore responses

  • SERVER-63774 Pass optional dbVersion to runPipelineOnSpecificShard

  • SERVER-63781 $sortKey not filtered out in initial batch from post batch resume token

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

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

  • 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-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-67725 Check catalog consistency on shards as precondition for rename

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

  • SERVER-68003 Make experiment_unified_ninja.vars the default

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

  • SERVER-68691 $graphLookup does not report variable references for 'restrictSearchWithMatch' filter

  • SERVER-69002 [5.0] backport pm-2419 Per Shard Cursors via mongos

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

  • SERVER-69547 Add multiversion_incompatible tag to show_raw_update_description*.js

  • SERVER-69590 libunwind warnings on clang arm platforms

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

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

  • SERVER-69785 robustify change_streams_per_shard_cursor.js

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

  • SERVER-63732 Add new implicitlyCreateIndex and enforceUniquenessCheck to shardCollection command

  • SERVER-64142 Add new enforceUniqueness to refineCollectionShardKey command

  • 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-69142 A retry of _shardsvrReshardCollection can cause DuplicateKey error (resharding_nonblocking_coordinator_rebuild.js)

SERVER-62636 setFeatureCompatibilityVersion 4.4 succeeds on 5.0 binVersion that has indexes with conflicting options

  • SERVER-58176 Mongos does not validate readConcern on insert/update/delete commands

  • SERVER-58966 timeseries_granularity.js and timeseries_timestamp_rounding.js collide on test namespaces in parallel suite

  • SERVER-59834 $group with allowDiskUse doesn't clean up _tmp files

  • SERVER-60958 Avoid server hang in chunk migration when step-down event occurs

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

  • SERVER-63852 getThreadName() should not crash

  • SERVER-64573 Make implicitlyCreateIndex and enforceUniquenessCheck fields optional

  • SERVER-64741 Create mongos appendOplogNote command

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

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

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

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

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

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

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

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

  • SERVER-68039 Old pymongo version 3.10.1 on MongoDB v5.0 causes Invariant failure (message.operation() == dbMsg) after connection reset by peer

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

  • SERVER-68482 [5.0] Add TSAN exclusion to getFlowControlStats

  • SERVER-68538 Typo in dependencies list in RPM config forces to fail installing mongodb enterprise in amazon linux 1

  • SERVER-68540 Add docker_incompatible tag for jscore tests

  • SERVER-68694 Investigate the locking around the compact command

  • SERVER-68737 remove multiversion test from debian11 5.0

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

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

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

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

  • SERVER-56185 Investigate possible improvements with session migration and a chunk migration's critical section

  • 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-64340 Warn if balancer is disabled while draining shard

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

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

  • 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-43155 Queries which exceed maxTimeMS may return NetworkInterfaceExceededTimeLimit

  • SERVER-66072 $match sampling and $group aggregation strange behavior

  • SERVER-61894 Support the 'showRawUpdateDescription' option in change stream specs

  • SERVER-63159 Implement the $_internalApplyOplogUpdate aggregation stage

  • SERVER-60607 improve handling of large/NaN values for geo index version

  • SERVER-60958 Avoid server hang in chunk migration when step-down event occurs

  • SERVER-61321 Improve handling of large/NaN values for text index version

  • SERVER-62747 proxy_protocol_connect.js needs to use the loopback address for Docker containers

  • SERVER-65262 Expand usage of WT numerical timestamp API

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

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

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

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

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

  • SERVER-66726 Fix serialization in killAllSessionsByPattern

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

  • SERVER-66938 Drastically simplify command to generate ninja files

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

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

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

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

  • SERVER-67532 Fail less in OplogServerStatusSection

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

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

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

  • 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-68487 add BSONElement method to check for NaN field values

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

  • SERVER-68522 Prevent 5.0 binary from starting in FCV 4.4 with misconfigured TTL index

  • SERVER-68540 Add docker_incompatible tag for jscore tests

  • SERVER-68574 Switch to the new logkeeper cluster

  • SERVER-68737 remove multiversion test from debian11 5.0

  • WT-8847 Add tombstone to WT_SAVE_UPD to truncate the update list upon page restore

  • WT-9004 Fix memory leak in update restore eviction

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

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

  • WT-9477 Don't allow checkpoint triggering internal page split which leads to corrupted internal page in the checkpoint

  • WT-9500 Fix RTS to use cell time window instead of key/value timestamps of HS update

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

  • SERVER-62272 Adding schema validation to a collection can prevent chunk migrations of failing documents

  • SERVER-62432 Ensure safe access to ShardingDDLCoordinator instance state documents

  • SERVER-62656 Decouple mongos-to-config-server connection pool sizing from mongos-to-shard-server connection pool sizing

  • SERVER-63243 Range deleter must not clean up orphan ranges in a round-robin fashion

  • SERVER-64433 A new topology time could be gossiped without being majority committed

  • SERVER-65027 Resharding commands permit extra options without returning an error

  • SERVER-65821 Deadlock during setFCV when there are prepared transactions that have not persisted commit/abort decision

  • SERVER-65925 shardsvrCommitReshardCollection should check for transient errors when joining

  • SERVER-65930 DDL coordinators and rename participant initial checkpoint may incur in DuplicateKey error

  • SERVER-66046 Resharding coordinator won't automatically abort the resharding operation when a recipient shard errors during its applying phase

  • SERVER-66618 Ensure ReshardingCoordinator has aborted in resharding_coordinator_recovers_abort_decision.js

  • SERVER-66866 The range deleter waits between batches while holding the collection IX lock

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

SERVER-61234 JS object-based types are not properly auto-serialized when directly returned by server-side JS functions

SERVER-66627 Backport the install-devcore target

  • SERVER-57938 Skip polygon validation for stored GeoJSON when query has $geoIntersect and a 2dsphere index

  • SERVER-58257 Add better diagnostics to predictive_connpool.js

  • SERVER-59658 Improve logging to reflect that sharding metadata refresh waiting on replication

  • SERVER-61856 Upgrade libunwind to 1.6.2+

  • SERVER-62386 Coverity analysis defect 121298: Parse warning

  • SERVER-62716 Handle spurious finishWaitingForOneOpTime in WaitForMajorityServiceTest

  • SERVER-63271 serverStatus can fail the server

  • SERVER-63493 update-shard-key tests failing due to transaction lock timeouts

  • SERVER-63971 Change server parameter to default to read-your-writes behavior after 2PC transaction

  • SERVER-64215 Interrupt OplogBufferMock::waitForData on shutdown

  • SERVER-64244 RunDBCheckInBackground should be resilient to interrupts

  • SERVER-64509 Fix ShardRegistry threadpool shutdown order

  • SERVER-64627 Need general method to handle in-memory state after initial sync

  • SERVER-64628 More testing of adding nodes to sharded sets

  • SERVER-64659 Report in serverStatus number of file descriptors used during index builds

  • SERVER-64725 Make ShardRegistry::periodicReloader interruptible

  • SERVER-64797 Use WT's new numerical timestamp API

  • SERVER-65100 Increase memory block size for BSONColumn

  • SERVER-65131 Disable opportunistic read targeting (except for hedged reads)

  • SERVER-65313 Use BatchedCollectionCatalogWriter during startup recovery

  • SERVER-65371 MigrationSourceManager running on secondary node may trip invariant

  • SERVER-65399 'commitIndexBuild' oplog entry is a no-op for unfinished index builds not restarted

  • SERVER-65723 Add tunable parameter to improve batching on secondaries

  • SERVER-65777 "revokePrivilegesFromRole" param.ns missing user object in audit log

  • SERVER-65797 Remove invalid index specs in memory before parsing for listIndexes

  • SERVER-66087 Call curl_global_init before threading enabled

  • SERVER-66111 Curl implementation of HTTPClient should respect default timeouts

  • SERVER-66319 dbcheck_no_history_on_secondary.js disables dbCheck failpoint too early

  • SERVER-66379 $or to $in conversion flawed

  • SERVER-66384 Enable command line customization of NINJA_BUILDDIR

  • SERVER-66418 Bad projection created during dependency analysis due to string order assumption

  • SERVER-66433 Backport deadline waiting for overlapping range deletion to finish to pre-v5.1 versions

  • SERVER-66461 Run notarization earlier in the build process

  • SERVER-66520 add index build UUID to BackgroundOperationInProgress error messages

  • SERVER-66556 Prevent potential race when releasing cursors during shutdown

  • SERVER-66559 Expand the internalQueryMaxAddToSetBytes param from 32 to 64 bits

  • SERVER-66658 Shard registry might be accessed before initialization

  • SERVER-66727 Time-series bucket can be created that violates max time-span

  • SERVER-66769 Update spawnhost setup script to support Windows hosts via cygwin

  • SERVER-66799 Fix getParameterWithDetails.js failure on ephemeralForTest

  • SERVER-66843 Use defensive programming in DeadlineFuture destructor

  • SERVER-66860 FSM tests should not reuse same database names

  • SERVER-66902 Multiversion setup is consistently failing on the mongodb-mongo-v5.0 Evergreen project

  • SERVER-66955