Docs Menu

Docs HomeMongoDB Manual

5.0 Changelog

On this page

  • 5.0.22 Changelog
  • 5.0.21 Changelog
  • 5.0.20 Changelog
  • 5.0.19 Changelog
  • 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-40459 Optimize the construction of the balancer's collection distribution status histogram

  • SERVER-79086 Deletion of ReshardingCoordinatorService state document is not idempotent

  • SERVER-79327 Missing verification in refine collection shard key

  • SERVER-79682 ShardsvrReshardCollection Can Hang If Stepdown Occurs Shortly After Stepping Up

  • SERVER-80236 Race in migration source registration and capturing writes for xferMods for deletes

  • SERVER-80712 Avoid leaving the replica set shard partitioned at the end of linearizable_read_concern.js

  • SERVER-52149 Create feature flag for Make taking self-managed backups in 4.4+ as safe as possible

  • SERVER-52452 Enable feature flag for Make taking self-managed backups in 4.4+ as safe as possible

  • SERVER-60156 Add a way to bypass storageValid() for time-series updates

  • SERVER-60176 Delta-updates should only validate the diff for storage

  • SERVER-68132 Remove Feature Flag for PM-2076

  • SERVER-68791 Expand the stacktrace API to return a loggable BSONObj

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

  • SERVER-73470 Log index inconsistencies detected by queries in the health log

  • SERVER-73497 Create an interface for the HealthLog

  • SERVER-74303 Add a sizeStorer call to the onRollback handler for dataSize and numRecords changes

  • SERVER-76341 Add range deletion throughput statistic

  • SERVER-77638 Add logging on completion of resharding

  • SERVER-78149 Implement the mongos fsync (lock : true) command

  • SERVER-78150 Implement the mongos fsyncUnlock command

  • SERVER-78151 Add fsyncLock status to the mongos currentOp command

  • SERVER-78153 Unlock the config server primary via the mongos fsyncUnlock command

  • SERVER-78156 Test the mongos fsync with lock command with distributed transactions

  • SERVER-78217 Renaming view return wrong error on sharded cluster (2nd attempt)

  • SERVER-78252 Block chunk migrations for hashed shard keys if you don’t have the shard key index

  • SERVER-78253 Allow folks with hashed shard keys to drop the hashed index

  • SERVER-78342 nReturned in slow query is incorrect when no docs are matched

  • SERVER-78384 mongos should allow --port 0

  • SERVER-78505 Database cache does not use the 'allowLocks' option correctly

  • SERVER-78529 Create feature flag

  • SERVER-78530 Enable feature flag

  • SERVER-78687 Set up copybara syncing between 10gen/mongo and 10gen/mongo-copybara

  • SERVER-78793 Add a timeout to the mongos FSync Lock Command

  • SERVER-79025 Mongos Fsync with lock command should use mongos fsyncUnlock command

  • SERVER-79126 Pin pyyaml in another place

  • SERVER-79251 Test dropping hashed shard key index mid chunk migration aborts migration

  • SERVER-79471 Mirrored reads should include databaseVersion in addition to shardVersion

  • SERVER-79552 $group rewrite for timeseries returns incorrect result if referencing the metaField in an object

  • SERVER-79632 Stop range deletion when hashed shard key index does not exist

  • SERVER-79781 TestGetDestinedRecipientThrowsOnBlockedRefresh should not run two refreshes without resetting the catalog cache loader mock return value

  • SERVER-79926 Investigate OCSP failure possibilities

  • SERVER-79975 [Classic] Optimize large group keys

  • SERVER-80021 Make $convert round-trip correctly between double and string

  • SERVER-80100 Fix typo in excluding compound_wildcard_index_hiding.js and sparse_index_internal_expr.js

  • SERVER-80140 Use the $currentOp to verify that fsyncLockWorker threads are waiting for the lock

  • SERVER-80157 ExclusionProjectionExecutor forces Document cache to load excluded fields

  • SERVER-80203 Normalization of time-series meta field can break insert targeting

  • SERVER-80234 Catalog cache unit tests of allowLocks should block the refresh

  • SERVER-80484 Disable libfuzzer on v5.0

  • SERVER-80491 Expose more granular metrics around balancing round

  • SERVER-80499 Fix use-after-free in planShardedSearch

  • SERVER-80643 large_events_failed_metric.js fails because change steram pre-images are not supported in v5.0

  • SERVER-80678 Remove an outdated test case

  • SERVER-80703 Avoid traversing routing table in MigrationDestinationManager

  • SERVER-80737 [5.0] slow_query_log_stats_not_block_on_RSTL.js requires lock-free reads support

  • SERVER-80809 Make _logOplogEntriesForInvalidResults resilient to non-existing oplog

  • SERVER-80982 Rename collection coordinator should use the view catalog to check if a view exists

  • SERVER-81106 Recipient shard doesn't wait for the collection version to be locally persisted before starting the cloning phase

  • SERVER-81155 Use move semantic to avoid copying all chunks in createCollection coordinator

  • SERVER-81201 Limiting the memory usage during the cloning phase on the recipient shard

  • SERVER-81202 Use host environment when signing

  • SERVER-81431 Add canaries_only task to older mongo branches

  • SERVER-81904 Address test-only issue in UpdateChunkMapRandom unit test

  • SERVER-81966 Avoid modification of previous ChunkMap instances during refresh

  • SERVER-81985 FlushRoutingTableCacheUpdates command should not be allowed on databases

  • SERVER-82003 powercycle tests are missing variables

  • SERVER-82070 Classic window function $stdDevSamp handles empty window frame incorrectly

  • WT-8614 Make format.sh more verbose for failure diagnosis

  • WT-10207 Fix log slot flags and remove debugging added for WT-9796

  • WT-10624 Fix regression on x86 for search and insert

  • WT-11064 Skip globally visible tombstones as part of update obsolete check

  • WT-11168 Remove the page image reuse logic

  • WT-11359 Update spinlock tasks to limit disk usage

  • SERVER-60466 Support drivers gossiping signed $clusterTimes to replica set --shardsvrs before addShard is run

  • SERVER-67529 Resharding silently skips documents with all MaxKey values for their fields under the new shard key pattern

  • SERVER-78036 Handle the race between the getting and setting of the LogicalTimeValidator during sharding initialization

  • SERVER-79771 Make Resharding Operation Resilient to NetworkInterfaceExceededTimeLimit

  • SERVER-50606 NetworkInterfaceTest needs to be more permissive with async op timeout

  • SERVER-59419 OperationContext::_ignoreInterrupts can be written to without synchronization by IgnoreInterruptionsGuard destructor

  • SERVER-61732 Prevent threads spawned outside ThreadContextTest from updating test counters

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

  • SERVER-71627 Refreshed cached collection route info will severely block all client request when a cluster with 1 million chunks

  • SERVER-73394 Remove misleading operationsBlockedByRefresh metrics

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

  • SERVER-77382 Null embedded metaField for creating a time-series collection leads to invalid BSON index spec

  • SERVER-78369 ignoreUnknownIndexOptions doesn't account for the 'weights' index field

  • SERVER-78950 Use sequential time series bucket IDs when possible

  • SERVER-78971 Skip shutting down Grid::getExecutorPool() when TestProctor is disabled

  • SERVER-78987 Remove the free monitoring code from mongodb/mongo repo

  • SERVER-79022 Update ASIO's Git hash in README.third_party.md

  • SERVER-79252 Add the system-perf bootstrap file to the task Files section

  • SERVER-79261 Add logging to ping monitor

  • SERVER-79382 Reset bucket OID counter when encountering a collision

  • SERVER-79397 Fix and test logic to internally retry time series inserts on OID collision

  • SERVER-79609 Fix findAndModify_upsert.js test to accept StaleConfig error

  • SERVER-79651 Only use two node replicasets in initial sync performance tests

  • SERVER-79861 Delete rosetta builders

  • SERVER-79885 Oplog fetching getMore should not set null lastKnownCommittedOpTime if it is not using exhaust cursors

  • SERVER-80183 Remove operationTime check from store_retryable_find_and_modify_images_in_side_collection.js

  • SERVER-80302 capped_large_docs.js is not resilient to replication rollback

  • SERVER-80488 Avoid traversing routing table in balancer split chunk policy

  • WT-7492 Ignore the evict drain wait msg in stdout.txt for test_cursor_random

  • WT-10380 Fix expected warning output in test_cursor_random: Eviction took more than 1 minute

  • WT-10432 Fix expected warning output for test_hs20 on macos

  • WT-10759 Do not retry to force evict history store pages during reconciliation

  • WT-11051 Fix newest start durable timestamp comparison in aggregate timestamp validation

  • WT-11221 Python tests fails due to unexpected "Eviction took more than 1 minute" warning in standard output

  • SERVER-44422 Allow findAndModify and delete one to target by query instead of extracted shard key

  • SERVER-62987 Wrong replication logic on refreshes on secondary nodes

  • SERVER-54344 Interruptible's Atomic timer parameter is not typesafe

  • SERVER-58618 Sleep intervals in interruptible_test cause imprecision

  • SERVER-58958 Temporarily disable Interruptible::WaitUntilDeadline test

  • SERVER-58959 Fix and reenable Interruptible::WaitUntilDeadline test

  • SERVER-71335 Debug symbols of server binaries used by system_perf.yml are archived in S3

  • SERVER-73841 Enable feature flag

  • SERVER-74143 A slow query report should not require the rstl lock to return storage statistics

  • SERVER-74451 Implement limit pushdown to mongot cursor

  • SERVER-74453 Implement support for getMore against a mongot cursor created with a user-defined limit

  • SERVER-74701 Add checksum verification for blackduck installer

  • SERVER-74954 Incorrect result when contained $or rewrites $elemMatch extra condition

  • SERVER-75648 Add limit pushdown info to explain output

  • SERVER-76299 Report writeConflicts in serverStatus on secondaries

  • SERVER-76404 Call the no-prefetch TaskExecutorCursor if there is an extractable limit

  • SERVER-76828 Increase test coverage for RoutingTableHistory and ChunkMap

  • SERVER-77299 Pooled LDAP connections may reference out-of-scope memory after timeout

  • SERVER-77654 Having more constraints on time-series collection timeField name

  • SERVER-77856 Provide Atlas with a way to choose a specific initial sync sync source

  • SERVER-78229 createIndexes should acquire the CollectionLock of the targeted nss before accessing the parent DatabaseShardingState

  • SERVER-78251 move_chunk_deferred_lookup.js can fail if mongos RSM is stale after stepup

  • SERVER-78333 DocumentSourceSearchMeta on 5.0/4.4 don't correctly specify involved collections

  • SERVER-78410 Suppress debug election log messages in rollback resumable index build tests

  • SERVER-78434 never implicitly shard a view in implicitly_shard_accessed_collections.js

  • SERVER-78525 Update jstests/noPassthrough/metadata_size_estimate.js to use a smaller document size

  • SERVER-78676 Replace c-string constructor with fill constructor in CurrentOpExhaustCursorTestFixture::initTestCollection on v5.0

  • SERVER-78751 $collStats should check for presence of time series options rather than relying on namespace checks

  • SERVER-78789 Distribute roles in metadata sizing test

  • SERVER-78828 LDAP host timing data can be inconsistent during sorting

  • SERVER-78888 Unschedule Mix js

  • SERVER-79136 Incorrect query result of $match + $group on metaField over time-series

  • SERVER-79592 [v4.4, v5.0] Avoid server crash when using positional projection with collation

  • WT-8340 Fix overflowed value in Btree atomic flags of 8 bit type

  • WT-10197 Track eviction timeline

  • WT-10424 cursor::search_near slow performance if many deleted items are present

  • WT-10449 Do not save update chain when there are no updates to be written to the history store

  • WT-10522 Fix a bug that leads to an unexpected aborted tombstone on update chain

  • WT-10585 Record the location of the last key in key order check

  • WT-10911 Investigate and update eviction timeline metrics that are showing up incorrectly

  • WT-11031 Fix RTS to skip tables with no time window information in the checkpoint

  • WT-11312 Fix incorrect flag check for accurate force eviction stat

  • WT-11374 Fix comparison of txnid to timestamp in row_modify (v5.0)

  • WT-11380 Temporarily disable compile-clang task on 5.0

  • SERVER-6491 Prevent dropping shard key index when alternative index doesn't exist

  • SERVER-64950 Use a named ErrorCode when asserting that you can't drop the last shard key index

  • SERVER-67732 mongod shutdown procedure doesn't shutdown the Grid::getExecutorPool()

  • SERVER-73848 Hashed shard keys with zones can cause issues with resharding

  • SERVER-76056 countDocsDeletedOnDonor name is misleading

  • SERVER-76546 _migrateClone can deadlock with prepared transactions on secondaries

  • SERVER-76948 Allow shard key fields to contain DBRefs

  • SERVER-78050 Chunk Migration Can Lose Data If Processing Deferred Modifications

  • SERVER-78414 Recipient shard in chunk migration can skip fetching changes to the migrated range, leading to lost writes

SERVER-75922 Partial unique indexes created on MongoDB 4.0 can be missing index keys after upgrade to 4.2 and later, leading to uniqueness violations

  • SERVER-62854 ShardingCatalogManager::removeShard should prevent concurrent remove shard commits

  • SERVER-64706 Create Feature flag for PM-2802

  • SERVER-67699 Add tracking for when change stream event exceeds 16Mb

  • SERVER-70242 Intracluster X509 authentication can trigger "Different user name was supplied to saslSupportedMechs"

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

  • SERVER-71387 Range-based window [+N, unbounded] can tassert

  • SERVER-71985 Automatically retry time series insert on DuplicateKey error

  • SERVER-73662 tlsClusterCAFile is not being used to validate client certificates on Windows

  • SERVER-73707 Evergreen timeout calculation fixes and cleanups

  • SERVER-73943 Pin code pages in memory in memory constrained systems

  • SERVER-73959 Add option to TaskExecutorCursor to not pre-fetch documents

  • SERVER-74471 Prune existing tests to stabilize the signal from the change stream perf suite

  • SERVER-74551 WriteConflictException unnecessarily logged as warning during findAndModify after upgrade to mongo 5.0

  • SERVER-74645 integration_tests_standalone[_audit] should not run a unqiue build

  • SERVER-74806 Write size estimation logic does not account for runtime/let constants

  • SERVER-74980 excessive logging of "Refreshed cached collection" log messages introduced in 5.0

  • SERVER-75280 Make shard_keys_with_dollar_sign.js use long timeouts for resharding crit sec

  • SERVER-75298 Reduce log error severity in sharding logging library

  • SERVER-75392 Update rounding functions in S2 geometry library

  • SERVER-75789 [v4.4] Require WT engine for read_ticket_exhaustion_with_stepdown test

  • SERVER-76006 break compile_dist_test into small chunks in a new kind of task group

  • SERVER-76180 [5.0] Remove TemporarilyUnavailable error code in transaction_too_large_for_cache.js

  • SERVER-76739 Archive data missing on evergreen task timeouts

  • SERVER-76824 Do not run mr_single_reduce.js in stepdown suites

  • SERVER-76826 $merge doesn't work with document that has dollar fields

  • SERVER-76934 Update computeDiff() code should safely error when there are duplicate fields in the objects

  • SERVER-76955 Add a multiversion_incompatible flag to fsm_workloads/map_reduce_drop.js in v5.0

  • SERVER-76983 mongos shutdown procedure doesn't shutdown the CatalogCache

  • SERVER-76988 Abort the reshardCollection operation when the zone information is too large

  • SERVER-77018 Deadlock between dbStats and 2 index builds

  • SERVER-77028 tlsClusterCAFile is not being used to validate client certificates on macOS

  • SERVER-77039 Re-blacklist map_reduce_drop.js from SERVER-71368 changes

  • SERVER-77074 mongod termination process should always shutdown and join the CatalogCached's thread pool

  • SERVER-77168 mongod crashes when restoring time series collection with auth enabled

  • SERVER-77196 NoPrefetch test in TaskExecutorCursorTest can deadlock

  • SERVER-77226 Fix permissions-checking when pinning code segments

  • SERVER-77266 createCollection command in rename_capped_collection_droptarget.js should ignore "cannot find ns" errors

  • SERVER-77273 Add gcc IPA pass cp ICE to oom_retry tool

  • SERVER-77298 Prevent fassert after killing opCtx as part of reconstructing prepared transactions after initial sync

  • SERVER-77357 [v5.0] Add ubuntu22 variants

  • SERVER-77383 ".msi.sha256" files have incorrect shasum

  • SERVER-77518 Disable pin_code_segments.js on 6.0 rhel-80-debug-ubsan

  • SERVER-77527 mongodbtoolchain/v3 stdlib unsafe against self-moves

  • SERVER-77534 Fix diff finder to handle deleted files correctly

  • SERVER-77603 [5.0] remove publish tasks for ubuntu22 variants

  • SERVER-77687 add ld OOM message to auto retry

  • SERVER-77710 Fix data race in AuditManager

  • SERVER-77769 SysPerf yml's compile-skip comment is incorrectly spaced

  • SERVER-78080 Use fully random bytes for 8 low-order bytes of OID value for time series bucket _id

  • SERVER-78126 For specific kinds of input, mongo::Value() always hashes to the same result on big-endian platforms

  • SERVER-78314 Create documentSourceWriterBatchBuffer server parameter

  • WT-7401 Silent test/format failure in the long-test Evergreen task

  • WT-8536 Update the LLVM symbolizer path in the evergreen.yml

  • WT-8539 Correct description for statistic for rolling back oldest pinned.

  • WT-8601 Timestamps do not work with logged tables.

  • WT-8709 RTS: Do not hold the oldest id of logged tables.

  • WT-8822 Disable logging in failing configs

  • WT-9117 test format exited with status 137 (Linux OOM killer)

  • WT-9721 Format stress tests generate cores even when successful

  • WT-10253 Run session dhandle sweep and session cursor sweep more often

  • WT-10285 test format fails with status 137 (Linux OOM killer) during sanitizer runs

  • WT-10469 Fix no timestamp tombstones not removing history store entries

  • WT-10488 test_schema_abort failed with invalid argument

  • WT-10512 Fix not inserting an out of order timestamp into the history store

  • WT-10671 Reset statistics when retrying test in test_checkpoint04.py

  • WT-10764 Add start and stop messages to rollback to stable

  • WT-10900 Segmentation fault on unit-test-macos on macos-1100

  • WT-10909 Simplify new test_backup29.py more

  • WT-10920 Minor cleanup to test_backup29.py

  • WT-11036 Add test of incremental backup after files are closed by dhandle sweep

  • WT-11122 Disable FLCS scenario in the long-test task for 5.0

  • WT-11140 Update Python path for Windows variants

  • WT-11167 failed: format-stress-sanitizer-ppc-test on rhel8-ppc [wiredtiger-mongo-v5.0]: memory leak detected

  • 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