5.0 Changelog
On this page
- 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
5.0.21 Changelog
Sharding
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
Internals
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
SERVER-80499 Fix use-after-free in planShardedSearch
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
5.0.20 Changelog
Sharding
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
Internals
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
5.0.19 Changelog
Sharding
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
Query
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
Internals
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
5.0.18 Changelog
Sharding
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
Query
SERVER-48196 Upgrade the timelib to the latest to update the built-in timezone files to the latest
Internals
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
5.0.17 Changelog
Sharding
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
Write Operations
SERVER-75517 illegal format of _id possible via upsert
Internals
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
5.0.16 Changelog
Sharding
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
Query
SERVER-63049 Track usage of agg accumulators
Write Operations
SERVER-75517 illegal format of _id possible via upsert
Internals
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
5.0.15 Changelog
Sharding
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
Query
SERVER-58712 Inconsistent update performance on collections with multiple secondary indexes on same key
Operations
SERVER-67704 Add count of cpu sockets to FTDC metadata
SERVER-67705 Add count of NUMA zones to FTDC metadata
Build and Packaging
SERVER-38232 Mongod on Ubuntu 16/18 does not create a pid file
Internals
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 fileSERVER-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
5.0.14 Changelog
Sharding
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)
Query
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
Operations
SERVER-67793 log_progress_msg in init.d does not print message
Build and Packaging
SERVER-48203 Support --install-action for Ninja builds
SERVER-64289 Platform Support: Add support for RHEL7 PPC in 5.0.X
SERVER-69507 Rpath should only be set on dynamic builds
Internals
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
5.0.13 Changelog
Sharding
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
Write Operations
SERVER-50454 Avoiding sending the "keyValue" field to drivers on duplicate key error
Internals
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
5.0.12 Changelog
Sharding
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)
Replication
SERVER-62636 setFeatureCompatibilityVersion 4.4 succeeds on 5.0 binVersion that has indexes with conflicting options
Internals
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
5.0.11 Changelog
Sharding
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
Query
SERVER-43155 Queries which exceed maxTimeMS may return NetworkInterfaceExceededTimeLimit
SERVER-66072 $match sampling and $group aggregation strange behavior
Build and Packaging
SERVER-61894 Support the 'showRawUpdateDescription' option in change stream specs
SERVER-63159 Implement the $_internalApplyOplogUpdate aggregation stage
Internals
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
5.0.10 Changelog
Sharding
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
JavaScript
SERVER-61234 JS object-based types are not properly auto-serialized when directly returned by server-side JS functions
Build and Packaging
SERVER-66627 Backport the install-devcore target
Internals
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 Remove JSON.send usage in perf projects
SERVER-67014 Say that "the client driver may require an upgrade" in warning message for deprecated op codes in 5.0
SERVER-67106 The _flushRoutingTableCacheUpdates() command should be able to also serve requests referencing collection views.
SERVER-67167 DIsable or_to_in.js from running in the parallel suite
SERVER-67220 [5.0] set_fcv_prepared_transaction.js is not resilient to StaleConfig errors
SERVER-67405 Handle empty string for is_patch evergreen expansion
SERVER-67513 Disable or_to_in for jsCore_compatibility for v5.0
WT-8425 Push updates with the same commit timestamps in the out_of_order_ts_updates vector in hs_rec.c.
WT-8669 Assert that the timestamps are not OOO in __hs_insert_record
WT-9249 Compare and fix the start durable timestamp if it is greater than ooo timestamp
WT-9251 Perform log flush before the metadata checkpoint
5.0.9 Changelog
Sharding
SERVER-62175 Mongos fails to attach RetryableWrite Error Label For Command Interrupted In _parseCommand
SERVER-62432 Ensure safe access to ShardingDDLCoordinator instance state documents
SERVER-64822 Sharding an empty collection releases the critical section too early
SERVER-66041 Chunk cloner must never consider too big a chunk with only one document
Query
SERVER-63642 Add serverStatus metrics to measure multi-planning performance
Build and Packaging
SERVER-42470 Generate additional configuration for libunwind
SERVER-64332 Notarize MongoDB builds for macos
SERVER-66386 Update AMI images for package tests
Internals
SERVER-57546 Increase test-specific timeouts for roles lock acquisition
SERVER-58337 Log deprecation warning and bump serverStatus counter upon receipt of OP_QUERY command
SERVER-60758 Prevent dbVersion refreshes from failing transactions in txn_recover_decision_using_recovery_router.js
SERVER-61018 Create a generic histogram type
SERVER-61110 Fix locking in AuthorizationContract::contains
SERVER-61460 Resmoke should merge config_svr options with mongod_options rather than overriding them
SERVER-62941 Update FTDCServerStatusCommandCollector to include oplog metrics from serverStatus command
SERVER-62992 Remove need for resmoke.ini
SERVER-63254 Add Index usage metrics to serverStatus
SERVER-63796 Enable Feature flag for PM-2750
SERVER-63850 Add the count command to API version 1
SERVER-64664 ninja tool should not consider install files generated source
SERVER-64815 Prevent buildindexes_false_commit_quorum.js from running in multiversion tests
SERVER-65137 detect namespace changes when refreshing Collection after yielding
SERVER-65166 Use compareOptimes in abort_in_progress_transactions_on_step_up.js
SERVER-65184 Avoid concurrent election and stepdown in downgrade_default_write_concern_majority.js
SERVER-65271 serverStatus should allow fine-grained metrics exclusion
SERVER-65636 Remove limits on number of LDAP connections per host
SERVER-65861 Remove enterprise-rhel-83-s390x from mh_variants on 5.0
SERVER-65995 Reduce Evergreen cron frequency on older branches
SERVER-66089 Initial sync should do transaction table read with a later afterClusterTime
SERVER-66117 Disable qualify_shortname in mock libkrb5 configuration
WT-8250 Increase the maximum expected space available after compaction in test_wt7989_compact_checkpoint
WT-8450 Report stats in hs_cleanup_stress, don't validate them
WT-8481 Split cppsuite search near tests and update their logging levels
WT-8622 Read in last_ckpt_base_write_gen at start of recovery
WT-8860 Save the mongod logs as a test artifact in many-collection-test
WT-9019 Disable cyclomatic-complexity test on 5.0
WT-9029 Remove object_target_size option from WT_SESSION::create
WT-9044 Disable code coverage measurement on mongodb-5.0
WT-9054 Correctly configure split stress options in format.sh
WT-9096 Fix search near returning wrong key/value sometimes when key doesn't exist
5.0.8 Changelog
Sharding
SERVER-62690 Shard is shutting down before finishing draining in test
SERVER-65533 Operations with {readConcern:available} do not treat the collection as UNSHARDED
Write Operations
SERVER-65261 Deleting from a capped collection via collection scan reports number of documents deleted incorrectly
Build and Packaging
SERVER-44074 Platform Support: Add Enterprise RHEL 8 (zSeries)
Internals
SERVER-55173 Segmentation fault in WiredTigerSession::releaseCursor
SERVER-56003 ninja + icecream with changing compilers doesn't regen run-icecc.sh
SERVER-56731 Consider running server tests on newer SLES 12 service pack
SERVER-58506 Command to expose settability for Server Parameters
SERVER-60105 Inserts into timeseries collections are not observable from any opcounter
SERVER-60485 Tasks which run on the MigrationUtilExecutor must not wait for shutdown to complete
SERVER-61032 Convert all references to /opt/mongodbtoolchain/gdb to a versioned equivalent
SERVER-61663 Dynamically split concurrency_metrics and concurrency_replication_metrics into smaller tasks
SERVER-61879 Refreshes to recover migrations must never join ongoing refreshes
SERVER-62205 Include sanity check for max chunk size argument of [auto]splitVector
SERVER-62229 Fix invariant when applying index build entries while recoverFromOplogAsStandalone=true
SERVER-62299 Platform Support: Add support for Debian 11
SERVER-63010 Ensure that unpacking measurements doesn't overwrite pushedown addFields that are computed on meta data
SERVER-63387 StreamingCursor should return backup blocks in the order they were retrieved from the WiredTiger backup cursor
SERVER-63479 Correct $$SEARCH_META ban in sharded environments
SERVER-63531 commitQuorum incorrectly includes buildIndexes:false nodes and error message incorrectly says that only voting nodes are eligible
SERVER-63910 Generalize this error message related to the critical section
SERVER-64031 serverStatus should not take PBWM lock
SERVER-64184 Track usage of allowDiskUse:true in agg command
SERVER-64485 Use _id to determine the update type in extractUpdateType()
SERVER-64554 abortIndexBuild oplog entry has no effect when run with --recoverFromOplogAsStandalone
SERVER-64732 [v5.0] BSONColumn decompression of interleaved arrays
SERVER-64757 Improve error messages when scons fails to generate-ninja on Windows
SERVER-64983 Release Client lock before rolling back WT transaction in TransactionParticipant::_resetTransactionState
SERVER-65024 Multiple documents with the same _id value make reIndex invariant
SERVER-65032 Pin python package BaseResponse for ocsp suite
SERVER-65182 Fix split_horizon_hostname_startup.js to use an assert.soon when getting the replsetconfig
SERVER-65200 Package task not run as part of task group
SERVER-65211 Use expansion to get binaries from the current branch
SERVER-65284 Create collection coordinator should always perform cleanup on subsequent execution
SERVER-65430 Disable capped_deletes.js on ephemeralForTest
SERVER-65718 Fix mypy error
WT-7662 Format timed out with prepare-conflict
WT-8260 Create a Python suite test to validate new EVENT_HANDLER JSON format
WT-8708 Fix timestamp usage error in test/checkpoint
WT-8924 Don't check against on disk time window if there is an insert list when checking for conflicts in row-store
5.0.7 Changelog
Sharding
SERVER-60109 Ensure vector clock is recovered on step-up
SERVER-61249 refine_collection_shard_key_basic.js relies on a best-effort refresh that might not happen in case of failover
SERVER-61444 Resharding uses of bumpCollectionVersionAndChangeMetadataInTxn are not idempotent
SERVER-61755 Migration recovery should handle refined shard key
SERVER-62072 _configsvrReshardCollection may return without having waited for unsetting "reshardingFields" to replicate to majority
SERVER-62521 Distributed locks might not be released on definite error when using a DDL coordinator
SERVER-62761 [v5.0] receiveChunkWaitForRangeDeleterTimeoutMS is being passed on 4.4 binaries
SERVER-62906 Add a check in the createCollection/shardCollection path verifying the collection name length
SERVER-62907 Vector clock components must survive CSRS non-rolling restart
SERVER-63722 Rename collection participants get stuck upon errors different from stepdown/shutdown
SERVER-63742 Default topology time in shard can lead to infinite refresh in shard registry
SERVER-64517 RecoverableCriticalSection is not properly recovered on startup
SERVER-64580 Step downs while sharding a collection in mixed binaries shards might crash the old binary
Replication
SERVER-54374 Race between signalOplogWaiters and StorageEngine::loadCatalog
Query
SERVER-40691 $nin:[[],...] queries are not indexed
Operations
SERVER-21070 Add option to gather collection stats
Internals
SERVER-51456 Database Profiler outputs incorrect value of property "keysDeleted" for a remove operation when a write conflict occurs
SERVER-53993 Attach client strand before releasing the opCtx in AsyncCommandExecution tests
SERVER-56300 Add append range functionality to BSON obj and array builders
SERVER-56558 Robustify validate_db_metadata_command.js test
SERVER-56931 instrument ASIO set_option failures better
SERVER-57662 Wait for config.system.sessions collection to exist on the config server before refreshing logical session cache
SERVER-58069 ASSERT_THAT matcher framework for unit tests
SERVER-58152 Create Feature flag for Remove Faulty Mongos From Cluster Topology
SERVER-58310 ThreadPoolTaskExecutor is memory unsafe when task cancellation occurs around the same time an exhaust network response is received
SERVER-58499 Add a new error code LoadBalancerSupportMismatch
SERVER-59220 Connectivity probes in ocsp_server_refresh.js should use fresh shells
SERVER-59223 Improve ecs scp robustness
SERVER-59290 Re-evaluate sync source after incrementing config version
SERVER-59356 Create dummy FaultManager singleton, FaultStatus enum and dummy unit test
SERVER-59357 Create dummy Fault class and dummy unit test for it
SERVER-59358 Create FaultFacet interface, mock implementation and unit test running mock that imitates a failure
SERVER-59360 Create HealthObserver interface, mock implementation and unit test invoking the periodic check with mocked failure
SERVER-59361 Implement periodic health check thread pool
SERVER-59362 Setup Fault Manager State Machine
SERVER-59364 Should move to the OK state after performing a successful round of health checks when in the StartupCheck state
SERVER-59365 Should not transition to OK state if initial health checks are not completed successfully
SERVER-59366 Progress monitor for periodic health check
SERVER-59367 Should create in-memory Fault instance when entering the TransientFault state
SERVER-59370 Should Transition to ActiveFault state when in the TransientFault state for kActiveFaultDuration
SERVER-59382 Enforce non-critical facets not entering ActiveFault state
SERVER-59390 Should provide the ability to perform periodic health checks against config server
SERVER-59397 implement randomization for health check periods
SERVER-59496 Fault class should be a container of active fault facets
SERVER-59522 HealthCheckStatus should track fault status and lifetime
SERVER-59567 Periodic check should invoke observers, simulate HealthObserver Mock failure
SERVER-59608 Coverity analysis defect 120502: Parse warning
SERVER-59912 Initial no-op scaffolding of the Ldap health checker
SERVER-60079 Common health observer code to incorporate generic patterns from Ldap observer
SERVER-60316 FaultManager should start with periodic checks disabled
SERVER-60412 Host memory limit check does not honor cgroups v2
SERVER-60587 Implement FaultFacet
SERVER-61016 Swallow connection reset-related errors received during ASIOSession creation on outbound connection.
SERVER-61095 Improve transport_layer_asio_test.cpp
SERVER-61104 Robustify find_and_modify_invalid_query_params.js
SERVER-61220 Integration test for Progress monitor
SERVER-61315 Ldap health check executor should support aborted tasks
SERVER-61368 FaultManager test suite should use real thread pool
SERVER-61438 Fix race in health_observer_test.cpp
SERVER-61490 transport_layer_test: asio connect race
SERVER-61592 Querying with ms precision does not return expected results (TS collection)
SERVER-61662 SCons configure checks should always run with verbosity
SERVER-61706 make sure that the new config has reached all nodes in cluster_x509_rotate
SERVER-61769 Attempting to run an aggregation with $out or $merge in a transaction on a sharded cluster leaves idle cursors open
SERVER-61871 use tassert for state machine programmer errors
SERVER-61872 Fix thread pool starvation in FaultManager
SERVER-61873 LDAP health observer runtime params
SERVER-61914 add fault facet details to FaultImpl::toBSON
SERVER-61921 Link failure in noSSL mode in FaultManager
SERVER-61956 fix data race when accessing the state machine's state
SERVER-61977 Concurrent rollback and stepUp can cause a node to fetch from a timestamp before lastApplied once it has stepped down.
SERVER-62017 Enable all feature flags by default in the sys-perf all feature flags variant
SERVER-62084 Serializer for FaultFacetType is broken
SERVER-62085 Use more bits for hashedMultikeyMetadataPaths in validation
SERVER-62096 /proc/<id>/smaps is not available
SERVER-62098 Guard healthCheckContexts with mutex in fault_manager.cpp
SERVER-62192 Handle feature flag disabled for implicit sharding accessed collection
SERVER-62242 $indexOfArray does not work with duplicate values in array
SERVER-62285 validate cachedir add push failure debug messages
SERVER-62368 Range deleter must honor rangeDeleterBatchDelayMS
SERVER-62379 Fix deadlock between ReplicationCoordinator and BackgroundSync on stepUp
SERVER-62466 _lastTransitionTime stat field in FaultManager is never changed
SERVER-62511 Race in dbcheck_no_history_on_secondary.js
SERVER-62513 RunDBCheckInBackground should retry on Interrupt errors
SERVER-62514 dbcheck_write_concern.js should prevent primary from stepping down
SERVER-62569 IDL Compatibility Checker script doesn't properly handle array types
SERVER-62651 Add enable all feature flags by default feature to Enable all feature flags by default to microbenchmark project.
SERVER-62668 Synchronize access to ImpersonatedUserMetadata in OperationContext.
SERVER-62680 validate cachedir make local tmp to ensure successful copy
SERVER-62682 PrimaryOnlyService Does Not Call _rebuildCV.notify_all() leading to calls to waitForConditionOrInterrupt not being triggered
SERVER-62712 validate cachedir isolate cache errors to only the cache debug log file
SERVER-62876 Stop testing tenant migrations with capped collections
SERVER-62948 Ensure FTDC collectors don't have a read timestamp
SERVER-63010 Ensure that unpacking measurements doesn't overwrite pushedown addFields that are computed on meta data
SERVER-63073 Fix ShardNotFound handling in shard_removal_triggers_catalog_cache_invalidation.js
SERVER-63079 Avoid using projection parser in $setWindowFields
SERVER-63097 stepdown_race_with_transaction.js should use the "uses_transactions" tag.
SERVER-63141 Difference in $lookup/$redact/$let behaviour with pipeline optimization
SERVER-63197 Pin microbenchmarks genny version
SERVER-63201 Relax restriction of deletion ops in applyOps command.
SERVER-63203 Chunk splitter never splits if more than 8192 split points are found
SERVER-63214 Ignore hash inconsistency between whole dbs when collection hash mismatch between image collections
SERVER-63234 Better logging to explain LDAP health check flakiness
SERVER-63239 Do not throw exception in AutoSplitVector on empty ranges
SERVER-63240 clearJumboFlag might persist a ChunkVersion with a wrong format
SERVER-63250 Fix implicitly sharding timeseries collections feature flag check
SERVER-63279 Pushing predicates on the time-series metaField past unpacking can cause incorrect results
SERVER-63288 Add debug log messages for queryable http calls
SERVER-63417 Oplog fetcher should not retry when a node is known to be down
SERVER-63428 Robustify oplog applying code for update operation
SERVER-63432 Transferring large file to repo
SERVER-63471 waitForPrimaryOnlyServices finish rebuilding before testing stepDown in no_disconnect_on_stepdown.js
SERVER-63497 Fix icecream debugging
SERVER-63505 Ensure arbiter recognizes primary node in rollback_views.js
SERVER-63512 Use optimized (no isSelf calls) reconfiguration on heartbeat reconfig
SERVER-63531 commitQuorum error message incorrectly says that only voting nodes are eligible
SERVER-63646 _raise_if_unsafe_exit uses wrong return_code
SERVER-63859 Disallow collMod with expireAfterSeconds on a view
SERVER-63876 [5.0] Secondary nodes crash when applying collMod with index.expireAfterSeconds option
SERVER-63968 Prohibit enumeration of builtin roles on $external database
SERVER-63974 Pin version of itsdangerous python dependency
SERVER-63986 Disallow 4.x running update_with_dollar_fields.js
SERVER-64182 Re-enabling health checks should check if another pending check was already scheduled
SERVER-64304 Using --recoverFromOplogAsStandalone can result in index builds crashing the server
SERVER-64369 Must not allow deletes from capped collections in fCV 4.4
SERVER-64403 Find queries with SORT_MERGE collation-encode the missing sort attribute
SERVER-64555 [5.0] Allow new unique index data formats to exist
WT-7922 Handle missing WiredTiger version file
WT-7954 Use longer flush_tier timeout in test_tiered04
WT-8074 Panic in reconciliation if inserting content into the history fails
WT-8149 Updating metadata salvage csuite test to handle salvaging table metadata without salvaging file metadata
WT-8198 Switch the bulk load cursor to a scratch buffer
WT-8320 Select updates restored from history store irrespective of visibility
WT-8362 Remove or rewrite HS entries of a key when OOO tombstone is written to datastore
WT-8417 Restructure assert testing in search near 01 cpp for concurrency
WT-8422 Clear the on-disk cell time window if it is obsolete
WT-8424 Use consistent toolchain in little-endian
WT-8477 Enforce the use of Pymongo 3.12.2 in our Evergreen tests
WT-8598 Avoid checkpoint cleanup always on shutdown
WT-8605 Disable the perf tests for non-develop branches in Evergreen
WT-8649 WT_SESSION methods cannot release scratch buffers unless reset or closing
WT-8743 Configure hs_cleanup configuration to stress the cache less
WT-8753 Add tombstone when rolling back in-memory, prepared, reconciled updates
WT-8799 Disable documentation update on mongodb-5.0
WT-8874 Disable compatibility tests on mongodb-5.0
WT-8879 Set the OOO flag when the selected tombstone is globally visible
WT-8894 Find the path to the mongod executable for many-collection-test
5.0.6 Changelog
Sharding
SERVER-45149 replSetStepDown command in txn_two_phase_commit_failover.js should not timeout
SERVER-56127 Retryable update may execute more than once if chunk is migrated and shard key pattern uses nested fields
SERVER-56227 Add user-facing command to set allowMigrations to false for a sharded collection
SERVER-58622 DDL coordinator handle write concern error incorrectly when removing coordinator document
SERVER-60624 txn_commit_optimizations_for_read_only_shards.js pauses replication on coordinator and can leave transaction stuck in prepare
SERVER-60682 TransactionCoordinator may block acquiring WiredTiger write ticket to persist its decision, prolonging transactions being in the prepared state
SERVER-60860 ReshardingCollectionCloner uses primary read preference when nearest was intended
SERVER-61003 ReadConcernMajorityNotAvailableYet errors from ShardRegistry must be retried
SERVER-61105 The sessions migration logic during moveChunk pollutes the logs
SERVER-61268 Fixing the release of a recoverable critical section on secondaries
SERVER-61416 Indefinitely retry errors in rename coordinator
SERVER-61459 ShardingCatalogManager::assignKeyRangeToZone() reads stale version of CollectionType while running locally on config server primary
SERVER-61461 update_shard_key_doc_moves_shards.js fails due to spurious refreshes from secondaries
SERVER-61628 Do not reschedule range deletion task when numDeleted < numDocsToRemovePerBatch
SERVER-61637 Review range deleter batching policy
SERVER-61689 ActiveMigrationsRegistry::lock method doesn't properly handle its exceptions
SERVER-61759 Unsetting the AllowMigrations flag should abort ongoing migrations
SERVER-61816 cancel_coordinate_txn_commit_with_tickets_exhausted.js can hang forever due to race condition between transaction reaper and transaction coordinator
SERVER-61945 Resharding collection cloning may fail with NamespaceNotSharded when "nearest" read preference chooses secondary
SERVER-61950 ReshardingOplogFetcher waits on network request completing without interruption, potentially preventing shard step-up from ever completing
SERVER-61976 [Resharding] Shards can error while refreshing their shard version following step-up, stalling the resharding operation
SERVER-62065 Upgrade path from 3.6 to 4.0 can leave chunk entries without history on the shards
SERVER-62171 Add logs to output of runConcurrentMoveChunk in sharding_statistics_server_status.js
SERVER-62178 Resharding can fail with NamespaceNotSharded if recipient primary fails over before creating temporary resharding collection
SERVER-62207 ReshardCollection with small maxTimeMS can crash the shard due to incorrect BSON object lifetime
SERVER-62245 MigrationRecovery must not assume that only one migration needs to be recovered
SERVER-62296 MoveChunk should recover any unfinished migration before starting a new one
Replication
SERVER-59721 Node may become unable to sync from other members after performing rollback to stable timestamp
Query
SERVER-57588 Inconsistent query results when an array position is indexed whose value is an array
SERVER-59754 Incorrect logging of queryHash/planCacheKey for operations that share the same $lookup shape
SERVER-62147 Exhaust query using the OP_QUERY protocol is broken when more than one getMore batch is required
Storage
SERVER-30846 Run dbCheck as background workload in FSM tests
SERVER-55483 Add a new startup parameter that skips verifying the table log settings
SERVER-58409 Startup RecordId initialization is flawed with durable history and reconstructing prepared transactions
Operations
SERVER-28953 Capture df (disk full) statistics in FTDC
Internals
SERVER-49748 Initial sync should clone admin.system.version before any other collections
SERVER-54468 Enable Feature flag for Minimal support for sharding time-series collections
SERVER-56167 Guarantee hang analyzer collects core dumps for sharded clusters, at minimum
SERVER-57037 Improve precision of operator counters
SERVER-57092 Use real test name for JS runner resmoke suites
SERVER-57289 redact should not convert BSONArray into BSONObj
SERVER-57312 Pin transitive Python dependencies and use the pinned file for installation in Evergreen
SERVER-57772 Failpoints on mongos rewrite state change error codes in writeConcernError
SERVER-58035 Remove db.runCommandWithMetadata from mongo shell
SERVER-58135 ReplSetTest initiate failing in replica sets with chaining disabled
SERVER-59428 Use more robust regex matching in rollback resumable index build fixture
SERVER-59779 Call asCluster() before replSetFreeze in ReplSetTest
SERVER-59781 multi_statement_transaction.js does not retry transaction on StaleConfig
SERVER-60048 CheckReplDBHash should not fail for cases where we expect retryable findAndModify images to be inconsistent after a restart
SERVER-60217 [v5.0] enableReconfigRollbackCommittedWritesCheck should be applied on 4.4
SERVER-60310 OCSP response validation should not consider statuses of irrelevant certificates
SERVER-60334 Pause the WiredTigerSizeStorer during Rollback To Stable
SERVER-60392 Fix timing in priority_takeover_two_nodes_equal_priority test.
SERVER-60513 Run burn_in_tags compile on -large distro
SERVER-60517 Enforce eviction_dirty_target < eviction_dirty_trigger in the fuzzer
SERVER-60685 TransactionCoordinator may interrupt locally executing update with non-Interruption error category, leading to server crash
SERVER-60788 merge_causes_infinite_loop.js attempts to expose a problem that no longer exists
SERVER-60809 Add ability to not idLookup after $search
SERVER-60959 Insert to a Time-Series getting error collection ErrorCodes::TimeseriesBucketCleared
SERVER-61005 rs.initiate() fails with "Invariant failure" under specific startup options
SERVER-61012 Instantiation of TEMPLATE rule sometimes has a command in generated ninja
SERVER-61097 SizeStorer can cause deadlocks with cache eviction
SERVER-61121 Make TransactionMetricsObserver support TxnNumberAndRetryCounter
SERVER-61122 Log TxnNumberAndRetryCounter in metrics and log methods inside TransactionParticipant and TransactionRouter
SERVER-61188 When storeImageInSideCollection=true, pre-image noop entries for collection with preImageRecordingEnabledForCollection=true are assigned wrong opTimes
SERVER-61194 Prevent time-series bucket OID reuse with coarse granularity
SERVER-61201 Creating a view can lead to a deadlock
SERVER-61214 Ensure having the latest known entry of the catalog cache when creating config.system.sessions
SERVER-61216 The --cache-disable flag results in a python stacktrace
SERVER-61275 Destruct the size storer after the session cache has shutdown
SERVER-61307 Add context to parsing errors for $setWindowFields' partitionBy expression
SERVER-61358 validate cachedir incorrectly re-raising InvalidChecksum
SERVER-61427 Unique index builds can cause a loss of availability during commit due to checking many false duplicates
SERVER-61479 Increase the number of retries to connect to a replica set following a stepdown
SERVER-61532 Opcounters to detect constrain violations need to be exposed.
SERVER-61550 Modify auto_workload_path in perf.yml to be relative to cwd
SERVER-61590 Presence of system.buckets collection should not assume that the collection is time-series collection.
SERVER-61591 Robustify currentop_shell.js test
SERVER-61602 timeseries_min_max.js assumes measurements are returned in insertion order
SERVER-61650 Disconnect nodes before restarting replication in sync_source_selection_ignores_minvalid_after_rollback.js
SERVER-61681 Wait for replSetGetStatus to update in replSetGetStatus_member_wall_times.js
SERVER-61690 Adjust stored fields protocol for atlas search
SERVER-61738 Revive dbCheck.js and make it deterministic
SERVER-61743 The -fno-builtin-memcmp flag shouldn't be applied except on x86_64 platforms
SERVER-61748 dbCheck should not hold a strong database lock during batches
SERVER-61754 dbCheck should not hold a strong collection lock during batches
SERVER-61757 Add a dbCheck command option to customize the batch size
SERVER-61791 pin pymongo
SERVER-61805 Use port to check primary node in timeseries_retryable_write_downgrade_oplog_rollover.js
SERVER-61846 Prevent redact from throwing BSONObjectTooLarge
SERVER-61852 dbCheck should tryLock the collection with backoff
SERVER-61858 Wait for node to become primary before disconnecting in sync_source_selection_ignores_minvalid_after_rollback.js
SERVER-61877 Remove catalog consistency verification from dbCheck
SERVER-61883 [v5.0] Read support for compressed time-series buckets
SERVER-61910 initiate_takes_stable_checkpoint.js doesn't account for closing connections in rollback
SERVER-61931 Allow ClusterManager role to operate against system.buckets.* collections
SERVER-61955 Expose dbCheck as a generally available command
SERVER-62022 Reduce dbCheck info logging in production, log start and stop
SERVER-62023 Improve dbCheck observability
SERVER-62037 Fix replica set definition in the system perf yaml file for linux-1-node-15gbwtcache
SERVER-62041 Add a maximum batch execution time to dbCheck
SERVER-62164 Remove several obsoleted build variants across all stable branches
SERVER-62210 Fix dbCheck progress meter handling of dropped and recreated collections
SERVER-62212 Support writeConcern for dbCheck
SERVER-62226 Disable dbcheck_no_history_on_secondary.js on EFT
SERVER-62243 Wait for vector clock document majority-commit without timeout
SERVER-62277 Performance regression from dbstats due to occupied disk space calculation
SERVER-62336 Tolerate SnapshotTooOld errors in dbCheck testing
SERVER-62380 Wait for majority commit point to be advanced on each node before starting rollback test in rollback_set_fcv.js
SERVER-62382 Several Amazon Linux 2 tests on the 5.0, 5.1, 5.2 and master waterfalls are not running
SERVER-62419 recover_multiple_migrations_on_stepup.js fails when executed in config server stepdown suite
SERVER-62423 Fix replsetinitiate_works_with_keyfile_profile_verbose_options.js to work on ephemeralForTest
SERVER-62592 Make timeseries_sharding_admin_commands.js clearJumboFlag test more resilient
SERVER-62706 dbcheck.js: handle replica sets with mixed debug/release members
WT-8395 Inconsistent data after upgrade from 4.4.3 and 4.4.4 to 4.4.8+ and 5.0.2+
WT-8534 Allow retrieving checkpoint snapshot for backup restore recovery
WT-8576 Enable logging in test checkpoint
5.0.5 Changelog
Sharding
SERVER-51329 Unexpected non-retryable error when shutting down a mongos server
SERVER-55382 Ignore error from retryable write being converted to transaction and that transaction failing in random_moveChunk_update_shard_key.js
SERVER-56227 Add user-facing command to set allowMigrations to false for a sharded collection
SERVER-57686 We need test coverage that runs resharding in the face of elections
SERVER-58343 Re-enable reshard_collection_failover_shutdown_basic.js
SERVER-59719 shardsvr{Commit, Abort}ReshardCollection may return unrecoverable error on stepdown, leading to fassert() on config server
SERVER-59806 Optimized path of shard collection fails to succeed with a large number of chunks
SERVER-60730 shardsvrDropDatabase should always join existing coordinator
SERVER-60751 move_chunk_critical_section_non_internal_client_abort.js does not consider config server stepdowns
SERVER-60804 Remove shard version checks from cursor_valid_after_shard_stepdown
SERVER-60945 Increase the resharding critical section timeout value for resharding_large_number_of_initial_chunks.js
SERVER-61027 Port permitMigrations changes
SERVER-61066 Make shardsvr DDL commands check primary status after marking opCtx as interruptible
SERVER-61289 Make resharding_retryable_writes.js more robust to timing
SERVER-61473 Resharding coordinator calls ReshardingMetrics::onCompletion() multiple times on transient errors, leading to config server crash
SERVER-61482 Updates to config.reshardingOperations wait for PrimaryOnlyService to be rebuilt while holding oplog slot, stalling replication on config server indefinitely
SERVER-61483 Resharding coordinator fails to recover abort decision on step-up, attempts to commit operation as success, leading to data inconsistency
SERVER-61607 Accept DuplicateKey as a possible error in resharding_nonblocking_coordinator_rebuild.js
SERVER-61633 Resharding's RecipientStateMachine doesn't join thread pool for ReshardingOplogFetcher, leading to server crash at shutdown
Replication
SERVER-54909 In replSetGetStatus, report last durable and last applied operation wall times for all members
SERVER-60946 Race condition in replsetprio1.js when initiating replset with nodes having different priorities
Aggregation
SERVER-59924 Error executing aggregate with $out with "available" read concern on sharded clusters
Storage
SERVER-58736 Avoid quadratic behavior in rollback with many collections
Internals
SERVER-54776 Enable Feature flag for PM-2191
SERVER-55535 Performance tests to exercise change streams optimizations
SERVER-57131 Fix trivial race in topology_listener_test
SERVER-57164 Invariant failure in a $group-by-variable optimization
SERVER-57171 Make the killop test more resilient
SERVER-57486 Prevent periodic index checks in transactions_stale_shard_version_errors.js test
SERVER-58636 Initial syncing node can miss final oplog entry when calculating stopTimestamp against a secondary sync source
SERVER-59329 Make sure that withTemporaryOperationContext throw an error if the node is no longer a primary
SERVER-59432 Downgrade invariant and add additional tassert for group on system variable optimization
SERVER-59654 Add Evergreen task for time-series update fuzzer
SERVER-59662 Create a concurrency test with time-series inserts and interrupt generating commands
SERVER-59858 Add observability for tasks scheduled on the reactor thread
SERVER-59871 startup_recovery_for_restore_restarts.js needs to make sure a checkpoint happens after failpoint
SERVER-59879 Adjust maxTimeMS value to allow for slower execution in the parallel test suite
SERVER-60393 increase replica_sets_jscore_passthrough time limit to 3hr.
SERVER-60424 TenantOplogFetcher times out on recreating aggregation cursor
SERVER-60632 Inconsistent error on mongos when renameCollection target already exists
SERVER-60670 use a separate branch instead of a specific commit for TPCC
SERVER-60671 Remove dagger
SERVER-60756 Add additional logging for failed updates in multi_statement_transaction_atomicity_isolation.js
SERVER-60762 $setWindowFields partitionBy an array should consistently error
SERVER-61021 Documents may be retrieved out of order in timeseries_delete.js
SERVER-61039 Sharded time-series listIndexes should report the view's namespace
SERVER-61164 Accept error code 48 (Inappropriate authentication) as a valid response for LDAP liveness check
SERVER-61178 Use less concurrency in find_cmd_with_indexes_timeseries.js
SERVER-61208 Balancer might be running when it shouldn't in transactions_stale_shard_version_errors.js
SERVER-61269 Adding log to awaitdata_getmore_cmd.js
SERVER-61283 [5.0] Add requires_fcv_50 to timeseries_insert_kill_op.js and timeseries_insert_idle_bucket_expiration.js
SERVER-61291 Fix forward compatibility with checkout_idl_files_from_past_releases.py
SERVER-61309 Fix time-series bucket lock reacquisition logic
SERVER-61360 reduce Debian 9 variants jlink to prevent OOM cases
SERVER-61405 Consider removing fCV check from $$SEARCH_META
SERVER-61597 Use deterministic order for random_moveChunk_timeseries_inserts.js
WT-3445 Add multiple tables to format tester.
WT-5008 Migrate Jenkins "wiredtiger-perf-btree" job to Evergreen
WT-5010 Migrate Jenkins "wiredtiger-perf-checkpoint" job to Evergreen
WT-5011 Migrate Jenkins "wiredtiger-perf-log-consolidated" job to Evergreen
WT-5012 Migrate wiredtiger-perf-evict to Evergreen
WT-5013 Migrate Jenkins "wiredtiger-perf-stress" job to Evergreen
WT-5580 Dump the wtperf command into logs in Evergreen wtperf test
WT-6001 Avoid reading the page into cache if it needs to be rewritten
WT-6022 NVRAM cache
WT-6116 Turn non-timestamp testing back on
WT-7694 Fixes to have bucket prefixes properly used in object names.
WT-7820 Retrieve the on-disk durable timestamp to compare with newer update timestamp
WT-7845 Add an oldest_id for tiered and its metadata.
WT-7912 Fix prefix search near optimisation to handle scenarios where the key range is split across pages.
WT-8004 Create a read order for the architecture guide
WT-8030 Add sanity checks related to eviction trigger setting
WT-8046 Keep non persistent configuration settings between wiredtiger_open calls in test/format
WT-8065 Update documentation about cursor and prefix_key configuration
WT-8076 Modify tiered_abort csuite test to work with cmake
WT-8114 Revert allow setting the prepare timestamp smaller than or equal to the latest active read timestamp with roundup prepare config
WT-8151 Make durable_start_ts equal to stop_ts if stop_ts is less than durable_start_ts and greater than start_ts
WT-8157 Fix format-abort-recovery-stress-test timeout condition
WT-8163 Consider more eviction scenarios to give up checkpoint-cleanup
WT-8167 Remove unused getters from the cppsuite code
WT-8173 Fix row column store node in architecture guide diagram
WT-8178 Push JSON output generated from wtperf_run.py to Cedar/Evergreen
WT-8179 Push out.json generated from wtperf_run.py to Atlas
WT-8188 Use compact progress stats in compact related tests
WT-8189 Add useful information for compact analysis to WT verbose messaging
WT-8192 Extend the verbose API to support the assignment of verbosity levels per event category
WT-8194 Fix ASAN leaks when tcmalloc is enabled
WT-8196 Add warning options to the cppsuite files
WT-8221 Compare write generation number before performing RTS
WT-8224 Fix coverity complains about unused variable
WT-8228 Add variable-length column store support to the compact tests
WT-8232 Fix hs18 test to use release evict cursor to evict the page
WT-8233 Fix data-validation-stress-test-checkpoint ignoring failures
WT-8237 Unassign NULL value to config after freeing, it stays unused.
WT-8241 Skip value return for largest key
WT-8253 Fix disk space issue in checkpoint stress tests
WT-8254 Implementation of new WiredTiger internal API to define verbose messages with an associated severity level
WT-8255 Create a Python suite test to assert legacy uses of the verbose interface still work as intended
WT-8256 Create new tests capturing different verbose configuration scenarios
WT-8270 Updating the time window clear obsolete stage of reconciliation to correctly consider global visibility.
WT-8271 Capture git branch and commit status in perf test result output
WT-8275 Streamline compact stats
WT-8280 Temporarily disable prefix assert
WT-8281 Fix out of order handling with history store stop timestamp
WT-8283 Use the new verbose API in compact files
WT-8284 Improve verbose logging for transactions when rollback is required
WT-8285 Simplify CMakes use of third party libraries
WT-8286 Create stress test for prefix search
WT-8291 Call _exit() instead of exit() without an exec
WT-8294 Push the results from performance tests to one collection
WT-8297 timestamp order check fired on logged table in recovery
WT-8298 Switch Evergreen performance tests to use ubuntu2004-large instances
WT-8314 Fix the block cache returning blocks for the wrong table
WT-8316 format backward compatibility mode fixes
WT-8317 Never store overflow keys on internal pages
WT-8318 Add format.sh support for a directory of CONFIG files
WT-8321 Update timeout for smoke tests to 60 minutes
WT-8331 change format to allow quote characters
WT-8335 Support compiling both a static and shared WiredTiger library in CMake
WT-8336 Disable unsafe-loop-optimizations flag when compiling c++ files
WT-8337 format direct I/O test fails to turn off backups
WT-8339 Add missing comma to wtperf monitor header
WT-8342 Coverity: CID 121074: UNINTENDED_INTEGER_DIVISION in src/support/float.c
WT-8345 API to configure cache_max_wait_ms at the session level
WT-8346 Migrate Jenkins "wiredtiger-perf-stress" remaining tests to Evergreen
WT-8347 Slipup in test_checkpoint modify changes
WT-8349 In-memory format runs can create a CONFIG with illegal cache size
WT-8350 Fix test/format problems where the wrong type of value was used to turn a configuration value off
WT-8354 Historic format builds used in compatibility runs need their previous syntax
WT-8355 Coverity analysis defect 121096: Uninitialized pointer read
WT-8357 Add more Evergreen expansions into the performance test output
WT-8358 Pass ops and args fields to wtperf via command line
WT-8359 Separate smoke tests from stress tests in Evergreen
WT-8363 Validate stats output by performance tests
WT-8364 Fix CMake bug when building cppsuite with TCMalloc
WT-8368 Fix verbose message output produced by '__wt_verbose_multi'
WT-8394 Revert Validate stats output by performance tests
5.0.4 Changelog
Sharding
SERVER-40865 The ShardServerCatalogCacheLoader does not serialize read operations with other operations for the same collection
SERVER-49897 Insert no-op entries into oplog buffer collections for resharding so resuming is less wasteful
SERVER-53335 Queries, updates, and deletes with non-"simple" collations may miss documents when using hashed sharding
SERVER-54231 Resharding can leave behind local collection on former primary shard that doesn't own any chunks
SERVER-54623 Decrease number of jobs in causal consistency passthrough suites
SERVER-55412 Mirrored reads should propagate the shard version field
SERVER-55429 Abort migration earlier when receiver is not cleaning overlapping ranges
SERVER-55557 Range deletion of aborted migration can fail after a refine shard key
SERVER-56985 Complete TODO listed in SERVER-56500
SERVER-57217 Don't report remainingOperationTimeEstimatedSecs in currentOp metrics for resharding for donors and coordinators
SERVER-57266 Create IDL representations for resharding metrics time intervals.
SERVER-57276 Capture max/min percent complete in FTDC metrics as seen by the commit monitor
SERVER-57479 Remove resharding_test_util.js
SERVER-57654 Call Pipeline::dispose() if Pipeline::getNext() throws in ReshardingCollectionCloner
SERVER-57655 Call Pipeline::dispose() if Pipeline::getNext() throws in ReshardingTxnCloner
SERVER-57665 Remove the unused disallowWritesForResharding() method
SERVER-57675 random_DDL_CRUD_operations.js may attempt to rename to a same destination ns twice
SERVER-57686 We need test coverage that runs resharding in the face of elections
SERVER-57760 Introduce dedicated OpCounters-like metrics for resharding and use them in ReshardingOplogApplier
SERVER-57761 Increment insert opcounter as part of resharding collection cloning
SERVER-58082 Fail resharding operation if allowMigrations has already been set to false
SERVER-58304 "metrics" field in resharding's donor, recipient, and coordinator documents isn't marked as optional
SERVER-58343 Re-enable reshard_collection_failover_shutdown_basic.js
SERVER-58407 Resharding components do not retry on FailedToSatisfyReadPreference when targeting remote shard, leading to server crash
SERVER-58433 ReshardingCoordinatorService Transaction In bumpCollectionVersionAndChangeMetadataInTxn Possibly Too Large
SERVER-58592 Make ReshardingCoordinatorService more robust when stepdowns happen near the end of a resharding operation.
SERVER-58871 Set fixed db primary in write_concern_basic.js
SERVER-58914 Create ReshardingDonorWriteRouter class with function stubs
SERVER-58915 Implement ReshardingDonorWriteRouter functionality along with unit tests
SERVER-58960 Measure the overhead from ShardingWriteRouter on the write codepath
SERVER-58980 Prevent Resharding Coordinator StepDownStepUpEachTransition test race between stepdown and done
SERVER-58990 Resharding always write new collection timestamp
SERVER-59023 Resharding can fail with NamespaceNotSharded following a primary failover on a recipient shard
SERVER-59160 Disable balancer in test_stacked_migration_cleanup.js
SERVER-59208 Allow retryable write in resharding_replicate_updates_as_insert_delete.js to fail with ShardCannotRefreshDueToLocksHeld
SERVER-59500 DDL coordinators must not release dist locks on stepdown
SERVER-59585 ReshardingOpObserver performs an invalid CollectionShardingRuntime cast on config servers
SERVER-59694 Resharding Prohibited Commands Incorrectly Assumes Consistency In Config.Cache.Collections Collection
SERVER-59769 Balancer conflicts with chunk migration tests
SERVER-59775 ReshardingDonorOplogIterator triggers an fassert() when it continues to run in member state SECONDARY following a stepdown
SERVER-59803 Set maxTimeMs for catalog cache refresh aggregation
SERVER-59811 ReshardingOplogFetcher can see the postBatchResumeToken move backwards in time when switching sync sources, stalling the resharding operation
SERVER-59812 ReshardingMetrics::onStepDown() is called while data replication components are still running, leading to an invariant failure
SERVER-59849 Add test to verify behavior of ReshardingOplogFetcher when pre/post image cannot be fetched
SERVER-59890 Exclude migration_coordinator_shutdown_in_critical_section.js test from the config stepdown suite
SERVER-59903 Do not wipe out renamed tags upon resuming the rename of sharded metadata
SERVER-59916 T{1, 2}Starts{First, Second}AndWins In WriteConflictHelpers Does Not Synchronize Committing Of Failed Transaction
SERVER-59923 Retry reshardCollection command from background thread in ReshardingTest fixture
SERVER-59927 Resharding's RecipientStateMachine::_restoreMetrics() doesn't retry on transient errors, leading to fassert() on stepdown
SERVER-59965 Distributed deadlock between renameCollection and multi-shard transaction
SERVER-60094 ReshardingOplogApplicationRules does not version all writes
SERVER-60142 Shard can migrate on top of orphans after filtering metadata was cleared
SERVER-60161 Deadlock between config server stepdown and _configsvrRenameCollectionMetadata command
SERVER-60220 ReshardingCoordinator::installCoordinatorDoc should update in memory state before calling logChange
SERVER-60266 Retry WriteConcernError exceptions in DDL coordinators
SERVER-60291 Resharding Prohibited Commands Does Not Wait For The Recipient To Be Done
SERVER-60413 Fix the critical section reason used by the moveChunk command
SERVER-60508 Shard server OnReplicationRollback throws when recovering critical section on time-series collection
SERVER-60592 DDL participant commands need to ensure they make a write with their txnNumber
SERVER-60731 Postpone database critical section release in drop database coordinator
SERVER-60737 Remove incorrect chunk timestamp check from ShardServerCatalogCacheLoaderTest
SERVER-60774 Resharding may apply through reshardFinalOp without transitioning to strict consistency, stalling write operations on collection being resharded until critical section times out
SERVER-60811 Drop database could drop new collections after stepdown
SERVER-60858 _configsvrReshardCollection command which joins existing ReshardingCoordinator may miss being interrupted on stepdown
SERVER-60859 ReshardingCoordinator waits on _canEnterCritical future without cancellation, potentially preventing config server primary step-up from ever completing
SERVER-60916 CPS Restores failed with a snapshot with documents in reshardingOperation
SERVER-61026 Invert order of shards receiving drop collection participant command
SERVER-61052 Resharding Donor & Recipient's Coordinator Doc Updates Can Time Out Waiting for Replication on Coordinator Doc, Leading to Fatal Assertion
SERVER-61066 Make shardsvr DDL commands check primary status after marking opCtx as interruptible
SERVER-61108 ReshardingCoordinatorService, Config Collection Deletes Can Time Out Waiting for Replication on Coordinator Doc, Leading to Fatal Assertion
Replication
SERVER-58988 Avoid sync source selection cycle during primary catchup.
SERVER-59170 Exclude max_doc_size.js from tenant_migration_multi_stmt_txn_jscore_passthrough suite
SERVER-59646 Check that the difference in ping times is greater than changeSyncSourceThreshold before evaluating sync source in nodes_in_primarys_datacenter_dont_sync_across_datacenters.js
SERVER-60153 More INFO level logs during election
Query
SERVER-51806 bulk key insertion phase of index build holds IX lock without yielding
SERVER-55516 Remove tags for Time-series tests in sharded passthroughs
SERVER-57321 $mod match expression incorrectly handles NaN, Infinity and large values
SERVER-57376 CollectionImpl and IndexCatalogImpl stats are uninitialized and can be written to the logs
SERVER-60586 out_max_time_ms.js does not correctly enable "maxTimeNeverTimeOut" failpoint leading to spurious test failure
Aggregation
SERVER-59308 Match After $lookup-$unwind not applied correctly to $lookup results
SERVER-59613 $range expression should error if it exceeds memory limit
SERVER-59924 Error executing aggregate with $out with "available" read concern on sharded clusters
Storage
SERVER-58130 Changing time-series collection validator is acknowledged by server without errors
SERVER-59057 Do not enforce fast count in validate command for config.transactions collection
Operations
SERVER-53242 Always log collmod command
SERVER-59883 Have mongo shell message about using mongosh respect the --quiet flag
Internals
SERVER-52310 Enable feature flag for Integration work to support new $search parameters
SERVER-53350 Expose methods on ReshardingTest fixture for sending replSetStepUp, SIGTERM, and SIGKILL to shards and config server while resharding is running
SERVER-53351 Add resharding fuzzer task with step-ups enabled for shards
SERVER-53913 ReshardingDonorService instances to load metrics state upon instantiation
SERVER-54206 Create a non-blocking API for the Fetcher class (or create an alternate class)
SERVER-54726 Fix typo in 'numScannedAferResume'
SERVER-54774 Architecture Guide updates for PM-2191
SERVER-54775 Create Feature flag for PM-2191
SERVER-55711 Coverity analysis defect 118014: 'state' variable shadowed in checkState()
SERVER-56416 mongod --version returns with extraneous log line on M1 laptops
SERVER-56602 Track usage of match expressions in serverStatus
SERVER-56639 Timestamp index ident drops for startup recovery
SERVER-56801 Update placeholder links for the reconfig check in PSA sets
SERVER-56813 Have Resharding be [RRFaM] aware
SERVER-56887 setIndexCommitQuorum command returns {ok: 1} when run against a mongos on a non-existent index build
SERVER-57000 Fix handling of correlated pipeline with facet
SERVER-57229 killOp_against_journal_flusher_thread.js must ensure the JournalFlusher doesn't reset the opCtx between finding the opId and running killOp
SERVER-57295 Rotate audit log on startup
SERVER-57315 Enable shardCollection command for a time series collection
SERVER-57350 ShardKeyPattern::parseShardKeyPattern() - NaN representation is being cast to integer
SERVER-57437 Implement insert routing for sharded time series collection
SERVER-57565 Ensure time series measurements do not update orphan buckets on sharded cluster
SERVER-57566 Implement sharding admin commands behaviour for time series collection
SERVER-57567 Update sharded passthrough suite to handle time series collections
SERVER-57568 Implement query routing behaviour for sharded time series collections
SERVER-57570 Disable updating granularity on sharded time-series collection
SERVER-57572 Rewrite secondary indexes on mongos for sharded time-series collections
SERVER-57573 Implement orphan filtering logic for $sample stage on sharded time-series collections
SERVER-57589 Enhance testing for cluster collStats and indexStats commands to ensure top-level 'timeseries' summation works
SERVER-57603 timeseries::MinMax::minUpdates/maxUpdates should consider calls to timeseries::MinMax::min/max when determining updates to include
SERVER-57605 Expose Decimal128 equality comparison helper to shell
SERVER-57697 Measure latency/throughput of ReshardingOplogApplier::_applyBatch
SERVER-57700 Measure latency/throughput of resharding::data_copy::fillBatchForInsert in ReshardingCollectionCloner::doOneBatch
SERVER-57717 Add time-series stub to update command
SERVER-57718 Add time-series stub to delete command
SERVER-57733 Determine whether an update/delete's query depends only on a time-series collection's metaField
SERVER-57734 Determine whether an update modifies only a time-series collection's metaField
SERVER-57735 Translate a single update on a time-series collection's metaField into an update on its buckets collections
SERVER-57736 Translate a delete on a time-series collection's metaField into a delete on its buckets collection
SERVER-57742 Create a non-specialized version of the OperationLatencyHistogram class
SERVER-57780 Improve BlackDuck timeout handling
SERVER-57784 TryUntilLoop Does Not Synchronize Destructor and Promise resolution
SERVER-58112 Add explicit synchronization to TaskExecutor's exhaust command promises
SERVER-58122 Replace searching logs for invariant failure with failpoint usage in resync_majority_member.js
SERVER-58139 Avoid leaking state from NetworkInterfaceTest::CancelLocally
SERVER-58148 mirrored_reads.js assertion does not consider mirrored read failure
SERVER-58166 Resumable index build rollback tests can run out of RamLog space
SERVER-58170 Prohibit dropping system.views if timeseries collections are present
SERVER-58175 Round time values before routing inserts to sharded timeseries collections
SERVER-58183 _applyPrepareTransaction does not ensure prepareConflictBehavior is kIgnoreConflictAcceptWrites on retry attempts
SERVER-58203 improve $unionWith stage
SERVER-58263 Fix absl map erase loop in TenantMigrationAccessBlockerRegistry
SERVER-58331 Fail time-series updates and deletes in multi-document transactions
SERVER-58370 StringMap element use-after-free in RollbackImpl
SERVER-58385 recovery oplog application updates multikey info on wrong collection
SERVER-58386 assign unique collection names to test cases in null_query_semantics.js
SERVER-58390 Test time-series metaField-only deletes with collation
SERVER-58393 Enable "collation" for time-series metaField-only updates
SERVER-58394 Translate multiple ordered updates on a time-series collection's metaField into updates on its buckets collections
SERVER-58396 Translate multiple unordered updates on a time-series collection's metaField into updates on its buckets collections
SERVER-58406 Enable debug logging when the TestingProctor is enabled
SERVER-58412 Changing settings.chainingEnabled in replica set configuration should affect change in sync sources
SERVER-58480 Add the necessary parameters to the ContinuousTenantMigration hook to allow for proper transient error retry
SERVER-58485 Retry transaction on transient errors in api_params_transaction.js
SERVER-58492 Test time-series metaField-only deletes with let
SERVER-58493 Test time-series metaField-only deletes with hint
SERVER-58519 Fix metaField-only time-series deletes with concurrent collection drops
SERVER-58583 Query analysis for mongocryptd does not handle expressive projections in find
SERVER-58617 Allow updates on a time-series collection with no metaField
SERVER-58721 processReplSetInitiate does not set a stableTimestamp or take a stable checkpoint
SERVER-58722 assign unique collection names to test cases in wildcard_index_multikey.js
SERVER-58739 Complete TODO listed in SERVER-58334
SERVER-58774 Clean up timeseries_update_delete_util.h and update references to queryOnlyDependsOnMetaField()
SERVER-58777 Inserts and updates disagree on whether an empty subdocument is a level of nesting
SERVER-58796 Enable "let" for time-series metaField-only updates
SERVER-58797 Enable "hint" for time-series metaField-only updates
SERVER-58798 Test "arrayFilters" for time-series metaField-only updates
SERVER-58803 Test that time-series metaField-only deletes close in-memory buckets
SERVER-58804 Ensure time-series metaField-only updates close in-memory buckets
SERVER-58811 Unit test query functions in timeseries_update_delete_util.h
SERVER-58861 ephemeralForTest sorted data interface does not work on big endian machines
SERVER-58872 Add require_fcv_51 tag for sharded timeseries tests
SERVER-58877 Ban spilling to disk in SpillableCache if there is no storage engine available.
SERVER-58888 $unionWith explain with mode "executionStats" does not account for stages which are pushed down
SERVER-58896 Fix metaField-only time-series updates with concurrent collection drops
SERVER-58899 Set curOp namespace to view collection for time-series updates
SERVER-58903 Blacklist index_many2.js from tenant migration stepdown/kill/terminate passthrough suites
SERVER-58930 mongodb-enterprise-unstable-server conflicts with mongodb-enterprise-unstable-shell
SERVER-58967 Set curOp namespace to view collection for time-series deletes
SERVER-59024 Unit test update functions in timeseries_update_delete_util.h
SERVER-59036 Use a unique bucket collection name in clustered_index_types.js
SERVER-59054 Enforce timeouts for generated fuzzer tasks
SERVER-59067 Fix TLS Race condition
SERVER-59072 Disallow updates on time-series collections where upsert:true
SERVER-59074 Do not acquire storage tickets just to set/wait on oplog visibility
SERVER-59088 Create Feature flag for Minimal support for sharding time-series collections: update and delete
SERVER-59092 Support $jsonSchema operator for time-series deletes
SERVER-59094 shardCollection command should ensure that time-series collection is created properly
SERVER-59104 Remove usages of findNthChild() in time-series update/delete code
SERVER-59108 Resolve race with transaction operation not killed after step down
SERVER-59110 Update connection error message in powercycle
SERVER-59120 Create unit tests for commitChunksMerge
SERVER-59126 drop collection on time-series collection should drop the underlying buckets collection on config server
SERVER-59140 Validate shard key pattern for timeseries shardCollection command
SERVER-59141 Review RPM spec files for potential errors
SERVER-59143 hard fail if "--ninja" tool option is used with ninja module in place
SERVER-59150 non_durable_writes_on_primary_can_reach_majority.js does not wait for durable timestamp on secondary to advance
SERVER-59154 Add more comprehensive time-series update document test cases
SERVER-59159 $min/max window function null semantics are different than their accumulator counterparts
SERVER-59164 All write commands on sharded time-series namespace should translate to buckets namespace, on mongos
SERVER-59173 Audit error messages for time-series updates and deletes
SERVER-59174 Report number of documents updated/deleted for time-series updates/deletes
SERVER-59180 Implement update rewrite and routing for sharded time-series collections
SERVER-59181 Implement delete rewrite and routing for sharded time-series collections
SERVER-59184 Add tests to verify correctness of Time Series index and bucket collection after chunk migration
SERVER-59190 IndexAccessMethod can be destructed during index build bulk load yield
SERVER-59191 SPIKE: git.get_project fails to clone
SERVER-59194 Exclude timeseries_update_concurrent.js from running in parallel with other tests
SERVER-59196 Add tests for explain command for sharded timeseries collection
SERVER-59214 include query results in oplog_visibility.js assertion message
SERVER-59218 Only replace the top-level metaField with "meta" for time-series updates/deletes
SERVER-59226 Deadlock when stepping down with a profile session marked as uninterruptible
SERVER-59294 Check action type for oidReset
SERVER-59298 Generated fuzzer tasks should use timeout_secs not exec_timeout_secs
SERVER-59299 Improve $match stage
SERVER-59321 Update suffix var to v5.0 in compile expansions
SERVER-59409 Race between reconfig replication and stepup can cause RSM to be stuck in reporting ReplicaSetNoPrimary
SERVER-59410 Clean up time-series update and delete tests
SERVER-59413 Fix possible race in tenant_migration_fetch_committed_transactions_retry.js
SERVER-59425 Ninja fails to install archive targets locally
SERVER-59445 Increase storage log verbosity in oplog_sampling.js
SERVER-59456 Start the LDAPReaper threadpool
SERVER-59459 mongodb fails to build with glibc-2.34
SERVER-59476 validate_commit_message does not allow wiredtiger imports to be reverted
SERVER-59483 tenant_migration_collection_ttl.js must account for race between recipient cloner and donor TTL sweep
SERVER-59491 Add "requires_multi_updates" tag to geo_update2.js
SERVER-59505 Time-series query on mixed, nested measurements can miss some events
SERVER-59515 Fix defaults in MergeAuthzCollection command
SERVER-59525 TenantMigrationRecipientAccessBlocker isn't being initialized correctly on recovery
SERVER-59591 LockerNoop::isW() always returns true allowing multiple operations think they are holding the global exclusive lock at the same time
SERVER-59606 Do not set dynamic timeouts on tasks with tests that have no runtime history
SERVER-59635 Mark ConfigSvrMoveChunkCommand as interruptible on stepdown
SERVER-59649 multiversion generated suite filenames should be different from normal tasks
SERVER-59662 Create a concurrency test with time-series inserts and interrupt generating commands
SERVER-59666 Renaming system.buckets collection should be disallowed
SERVER-59669 Unprotected variable in the concurrent test TransientSSLParamsStressTestWithManager
SERVER-59672 Fix stopping replication in step_down_during_draining3.js
SERVER-59676 DocumentSourceFindAndModifyImageLookup can hit invariant when used in a shard
SERVER-59693 ReshardingTest fixture must accommodate nodes going into ROLLBACK while attempting to run replSetStepUp
SERVER-59701 Error when working with some timezones when using external timezones database
SERVER-59720 Correctly handle $rename in time-series metaField-only updates
SERVER-59727 TenantMigrationAccessBlockerRegistry::_remove doesn't remove when both mtabs are present
SERVER-59765 $dateAdd/$dateSubtract do not detect an overflow for certain 'amount' values
SERVER-59778 Robustify timeseries_query.js test
SERVER-59796 Wait for replication before stopping replication on secondaries in catchup.js
SERVER-59804 Using a separate branch for YCSB in system_perf.yml
SERVER-59805 Provide a way to check for and to remove invalid index catalog options
SERVER-59843 Complete TODO listed in SERVER-56639
SERVER-59865 Update repl arch guide to reflect new implicit default write concern formula
SERVER-59866 Stop fCV from waiting for majority when currentCommittedSnapshot is dropped
SERVER-59867 Split horizon mappings in ReplSetConfig/MemberConfig should be serialized deterministically
SERVER-59868 Fix index build race in durable_history_index_usage.js
SERVER-59876 Large delays in returning from libcrypto.so while establishing egress connections
SERVER-59885 Wait for replica set to stabilize before validating collections
SERVER-59925 Stress test and fix deadlock in expiring idle buckets
SERVER-59934 Dropping a View and creating a Collection on same namespace may be replicated out-of-order
SERVER-59943 Multiversion setup should not download assets from test branches
SERVER-59952 Fix multiversion burnin_tests error during resmoke process
SERVER-59970 Fix return value from authenticate command
SERVER-60007 Implement command to drop collection if its UUID differs from the expected
SERVER-60025 queue document crashes the server due to producing invalid runtime object
SERVER-60038 Ban setWindowFields in transaction with read concern snapshot
SERVER-60062 Fix duplicate uuid and server description deep copy found in topology description clone
SERVER-60096 Add rollbackHangCommonPointBeforeReplCommitPoint failpoint to RVR
SERVER-60145 generated task resmoke config files should be based on task names
SERVER-60150 Add variant to 5.0 with some feature flags
SERVER-60201 Clean up time-series update and delete util functions
SERVER-60218 Improve $group stage
SERVER-60223 Container hosts should look for evergreen binary at /
SERVER-60228 RPM external dependency scanner is deprecated
SERVER-60259 set require_multiversion in task generation
SERVER-60263 stitch_support library fails to load due to missing static initializers
SERVER-60269 Enable ShardedTimeSeriesUpdateDelete feature flag
SERVER-60270 Add tags to window functions read concern test
SERVER-60283 Disable tests incompatible with the ephemeralForTest storage engine
SERVER-60285 Create FSM test for deletes on sharded time-series collections
SERVER-60290 Update Windows external auth test distro
SERVER-60299 Backport PCRE bugfix for Bugzilla #2613
SERVER-60322 Failed index build initialization during rename collection between dbs may not clean itself up from collection metadata
SERVER-60326 Windows Server fails to start when X509 certificate has empty subject name
SERVER-60340 Don't forward mongo ports through SSH tunnel in powercycle
SERVER-60343 Single-phase index builds perform un-timestamped catalog writes on abort
SERVER-60348 Add featureFlagTimeseriesUpdatesAndDeletes to 5.0 backport builder
SERVER-60406 $searchMeta fails on unsharded collection in sharded cluster when there are no search results
SERVER-60418 drop_sharded_timeseries_collection would not support step downs
SERVER-60420 The slow 'shardCollection' path performs heavy work under the critical section
SERVER-60424 TenantOplogFetcher times out on recreating aggregation cursor
SERVER-60430 [v5.0] tenant_migration_recipient_access_blocker_rollback.js holds a failpoint that prevents previous instance from completing
SERVER-60450 Add error check for $dateSubtract when negating amount value
SERVER-60451 Index builds code can access an invalid BSONObj because the cursor was saved&restored at a lower level
SERVER-60452 Fix time-series shard key validation when the collection does not exist
SERVER-60456 LDAPBindOptions go out of scope during heavily delayed binds on Windows
SERVER-60469 Retryable deletes reserve two optimes for preImage chaining despite not capturing a preImage
SERVER-60495 Retry FailedToSatisfyReadPreference in DDL coordinators
SERVER-60497 renameCollectionForApplyOps should skip system.buckets rename check
SERVER-60511 getPinnedOplog return value should always be std::min compared with the pinned timestamp
SERVER-60518 Best effort checks in range deleter can leave orphans
SERVER-60523 Standalone fixture incorrectly handles directory creation exceptions
SERVER-60544 Replace remaining references to slaveDelay in replication system
SERVER-60548 Timeseries insert path segfault
SERVER-60550 migration_util function may miss some response errors when submitting remote commands through sendToRecipient()
SERVER-60554 Reduce ConnectionAttempts in ssh connection options in powercycle
SERVER-60588 $multiply incorrectly throws an error in some cases in the classic engine
SERVER-60593 Robustify sample_timeseries.js test
SERVER-60606 Race condition during initial sync when index builds start in data cloning phase
SERVER-60651 Backport the autoSplitVector logic to v5.0
SERVER-60661 [5.0] Add test to ensure that sharded time-series collections work correctly when the feature flag is off
SERVER-60739 Change chunk size in timeseries_balancer.js to split chunks sooner
SERVER-60740 Robustify timeseries_multiple_mongos.js test
SERVER-60762 $setWindowFields partitionBy an array should consistently error
SERVER-60766 Add 'does_not_support_transactions' for sharded time-series tests
SERVER-60801 Fix logkeeper snapshot location
SERVER-60869 Re-add logic to set feature compatibility version on arbiters
SERVER-60877 Correct inadvertent copy of MutableOplogEntry on replLogUpdate
SERVER-60896 Fast forward audit spooler before triggering filtered event
SERVER-60913 Package testing is failing on some platforms
SERVER-60948 Insert document in new collection in migration_id_index.js to await successful index build on secondary
SERVER-60971 Remove calls to BF suggestion service
SERVER-61094 Generating KeyStrings from MultiIndexBlock can result in memory limits not being respected
SERVER-61096 ResetDbPath sometimes errors while recreating dbpath on Windows
WT-5009 Migrate remaining wiredtiger-perf-lsm tests to Evergreen
WT-5270 Create wtperf script for evergreen
WT-5743 Rewrite cells when the transaction ids are cleared for VLCS
WT-5939 Fix naming conflict resulting in "cannot remove directory" error in test_config06 (OSX only)
WT-6077 Add new stats to track compact progress
WT-6193 Re-enable VLCS testing in format-test
WT-6669 Enable VLCS coverage and checkpoint tests in evergreen
WT-6900 Write "schema" subpage for Architecture Guide
WT-6903 Write "dhandle/btree" subpage for Architecture Guide
WT-6907 Write "snapshots" subpage for Architecture Guide
WT-6909 Eviction architecture guide
WT-6913 file system and os interface architecture guide
WT-7169 Commit ts should not be lesser than the last durable ts in test_timestamp22.py
WT-7250 Fix the test to perform explicit eviction instead of relying on low cache size
WT-7294 Re-enable VLCS evergreen endianness tests
WT-7392 Added evicted flag to dhandle for use by session sweep
WT-7494 Add Python test to trigger update restore eviction during recovery
WT-7601 Fix typo in operation tracking documentation
WT-7695 Dump entire tree when key out-of-order found in __cursor_key_order_check_row
WT-7745 Add macro to identify uris for btree objects
WT-7757 Skip obsolete leaf pages without having to read them
WT-7844 Add tiered_abort stress test for tiered storage.
WT-7885 Ensure WiredTiger testing uses tcmalloc where possible
WT-7902 Retry the alter command after a system wide checkpoint
WT-7914 Update the documentation only when required
WT-7942 Release timestamp lock in test/format when all_durable timestamp is not found
WT-7949 Change local store cache and bucket directories to be relative to WT_HOME
WT-7957 Tiered storage should look in local system for objects
WT-7959 Skipped_pages is less than expected_pages_skipped in test_cursor17
WT-7980 Create interface to "log:" cursor which switches log files before returning them
WT-7987 Create Unit Test to check compact does not rewrite overflow items
WT-7989 Compact quits when running at the same time as a system checkpoint
WT-7992 Provide API to return the last key in a table regardless of visibility
WT-7993 If gathering handles and not in aggressive eviction mode, have eviction sleep to let checkpoint grab a contentious spinlock.
WT-8001 Fix Inconsistent API behaviour when setting global oldest and stable timestamps
WT-8007 Update script to correctly generate new test for the CPP test suite framework
WT-8011 Add format support for randomly choosing RS or VLCS
WT-8017 Re-enable VLCS format stress testing in evergreen.
WT-8019 VLCS snapshot-isolation search mismatch
WT-8022 Verify WT_CURSOR.modify return values in format test program
WT-8023 Use global transaction information to assess if a session has active transaction
WT-8024 Add link text to cross-references in Arch Guide
WT-8026 Run PPC/zSeries/macOS mainline builds less frequently in Evergreen
WT-8034 Use the PR branch when docs are compiled in PR testing
WT-8035 Handle prefix enabled lexicographical comparisons for string key formats
WT-8036 Added connection panic flag in two assert statements in wt_evict_thread_run and _wt_evict_thread_stop.
WT-8039 Add a new flag for API check instead of clearing prepared flag which may incorrectly force a roll back
WT-8041 Rollback to stable unpacks values repeatedly
WT-8042 Create an evergreen job to run test/checkpoint variation
WT-8043 Tidy the "ripcip" argument into the visibility code
WT-8044 Prefix enabled search near only returns matching keys
WT-8048 Remove split_8 timing stress configuration
WT-8055 Fix issue when compact quits when running at the same time as a checkpoint
WT-8057 Add a test to verify that changing compact is not resulting in data loss
WT-8059 Add a check in salvage when no overflow items are found
WT-8067 Fix the code that ensures to insert the newest history store value as full update
WT-8068 Improve __rollback_row_modify control flow
WT-8069 Coverity analysis defect 120706: Redundant test
WT-8070 Remove discrepancy between prefix_key and prefix_search
WT-8075 Coverity analysis defect 120712: 'Constant' variable guards dead code
WT-8077 Mark the page dirty once the prepared updates are resolved
WT-8078 Implement tiered storage local retention caching
WT-8079 Add breakpoint to verify error macros, clean up API processing
WT-8081 Fix tiered hook functions to provide default for config string
WT-8086 Create cpp test for prefix search near entries
WT-8092 Prefix early exit when keys are present in the insert list
WT-8094 Fix use after free in csv extractor
WT-8101 Enable diagnostic mode for the CPP tests in evergreen
WT-8103 Skip a dhandle if it isn't a btree
WT-8104 Fix memory leaks noted by ASAN
WT-8108 Use temporary files and rename in local store
WT-8112 Skip null check, per coverity
WT-8113 Remove dead code, per coverity
WT-8115 Define macros only when necessary in cpp files
WT-8116 Fix issues related to inheritance in the cpp testing framework
WT-8119 Add targeted compact testing to the existing testing framework
WT-8121 Create a long running stress test which inserts a large amount of data over a long period
WT-8125 Update hs_cleanup cppsuite test to use the new thread_context logic
WT-8126 Mark btree as dirty only if not newly created when instantiating a deleted row-store leaf page
WT-8146 Stop the tracking component when a CPP test ends
WT-8147 Detect invalid syntax in cppsuite configs
WT-8148 Fix comment typo in util_verify.c
WT-8161 Reduce verbosity of CMake Evergreen smoke
WT-8162 Refactor uses of SMOKE arg in 'define_c_test' helper
WT-8164 Disable rollback_to_stable10 python test on Windows
WT-8168 Fix unused variables in search near cpp tests
WT-8171 Implement a C style test in the CPP testing framework
WT-8193 Wrong corner case in VLCS rollback-to-stable
WT-8199 Make s_all accept Python PEP8 compliant line breaks
WT-8203 Fix the layering violation in accessing the page
WT-8204 Fix possible race condition in "wt7989_compact_checkpoint" CSuite test
WT-8214 Only publish the docs from the WiredTiger develop Evergreen project
WT-8225 Fix data race in zstd get context
WT-8226 Fix largest_key failed to consider prepared update
5.0.3 Changelog
Security
SERVER-57716 Partial certificate chain in PEM causes validation failure in OCSP
Sharding
SERVER-27383 Require --replSet with --configsvr
SERVER-50937 Make resharding coordinator support recovery
SERVER-55824 Make ssl_get_more.js start shards as replicaset
SERVER-57487 Update chunks during setFCV 4.4 «--» 5.0 must not block balancing for long periods
SERVER-57953 _flushReshardingStateChange attempts to refresh shard version while another refresh already pending, leading to invariant failure
SERVER-58081 _flushReshardingStateChange from coordinator races with donor shard acquiring critical section, stalling the resharding operation
SERVER-58315 Change jstests to not use standalone nodes as shards nor config server
SERVER-58342 Allow specifying of reshardCollection zones to be empty
SERVER-58603 ensureTempReshardingCollectionExistsWithIndexes may hit an invariant if collection was previously dropped
SERVER-58702 Fix comment in ReshardingDataReplication and update its member declaration order
SERVER-58720 DropDatabaseCoordinator must not re-execute destructive logic after removing CSRS metadata
SERVER-58781 ReshardingCoordinatorObserver should not fulfill promises if the "donors" or "recipients" fields are empty
SERVER-58868 Enable/Remove a commented moveChunk + AllowMigrations test
SERVER-58917 Wait until donors/recipients are aware that coordinator has persisted decision before expecting successful collMod, createIndexes, and dropIndexes in resharding_prohibited_commands.js
SERVER-58926 ReshardingDonor should not try to set the stop time of the critical section if it the critical section was already released
SERVER-59114 ReshardingOplogFetcher stops fetching new oplog entries if remote donor shard responds with Interruption exception
SERVER-59292 completion future can be set more than once because of WithAutomaticRetry
Replication
SERVER-58133 Use split replication tasks because they are timing out because of "majority" implicit default write concern
SERVER-58987 Fix read_only_test.js to avoid start point beyond end point during replication recovery.
SERVER-59083 catchup_takeover_with_higher_config.js needs to be excluded from multiversion suite for last-continuous
SERVER-59131 Wrap rawMongoProgramOutput search in an assert.soon in implicit_default_write_concern_upgrade_shards.js
SERVER-59212 Make sure node stepped down before waiting for catchup takeover in catchup_takeover_with_higher_config.js
SERVER-59478 Move serverStatus command before taking RSTL in catchup_takeover_with_higher_config.js
Query
SERVER-54791 Excessive file descriptor usage during index build with external sort
SERVER-57448 fix ExpressionParams::parseTwoDParams() to handle int values in key patterns that are out of bounds
SERVER-57667 Improve processing speed for resharding's collection cloning pipeline
Storage
SERVER-58744 applyOps on capped collections can violate the multi-timestamp constraint
Build and Packaging
WT-7830 Migrate the python setup scripts to use cmake
Internals
SERVER-52007 Create feature flag for Integration work to support new $search parameters
SERVER-53001 Complete TODO listed in SERVER-47323
SERVER-53437 Architecture Guide updates for Change the Default Write Concern to Majority
SERVER-54735 Executor shutdown can cause AsyncTry-until to set its result with ErrorCodes::BrokenPromise
SERVER-55589 replSetMaintenance command does not take the RSTL
SERVER-55664 Support clustered _id indexes in ephemeralForTest
SERVER-55760 Cancelation tests for AsyncTry are racy
SERVER-55966 AsyncTry no longer handles exceptions from until() lambda, leading to process crash
SERVER-56235 Evaluate index types that are dependent on a collection not being clustered, rather that it not being time-series
SERVER-56492 Normalize time-series metadata with array type
SERVER-56580 Promote build-tools=next to stable
SERVER-56763 Validate collection epoch when not holding a DB lock for $merge
SERVER-56800 Fail addShard if CWWC disagrees with existing CWWC on cluster
SERVER-56844 Fassert shard server on startup if DWCF=w:1 and no CWWC set
SERVER-56845 Fail addShard if DWCF=w:1 and no CWWC is set
SERVER-56846 Fail reconfig for shard server if it would change DWCF and CWWC is not set
SERVER-57086 Do not set inherited maxTimeMSOpOnly deadline on hello command in v4.4
SERVER-57140 Fix up perl relics from migrated shell scripts
SERVER-57262 Allow nodes to vote for candidates with higher config
SERVER-57279 Update the fCV constant in the logkeeper snapshot workload
SERVER-57360 Log additional debug info for the "invariant (_requests.empty());" in ~LockerImpl
SERVER-57387 create_view_does_not_take_database_X.js should check its insert
SERVER-57435 Exclude views_coll_stats.js from causally_consistent test suites
SERVER-57465 remove_newly_added_field_after_finishing_initial_sync.js does not wait until the new configuration has been replicated
SERVER-57520 Make set_audit_config.js test start shard as replicaset
SERVER-57575 Investigate create_view_does_not_take_database_X.js failures on Windows
SERVER-57585 oplog_visibility.js prints null 'next' timestamp for missing oplog entry
SERVER-57599 DocumentSourceBucketAuto returning eof when disposed
SERVER-57615 Reset CWWC to w:majority for tests that don't create/stop the replica set
SERVER-57616 Wait for secondary to load signing keys in disable_cluster_time_gossiping_in_unreadable_state.js
SERVER-57617 Have the OplogFetcher in Tenant Migrations do an aggregation query instead of a find
SERVER-57630 Enable SSL_OP_NO_RENEGOTIATION on Ubuntu 18.04 when running against OpenSSL 1.1.1
SERVER-57651 Prevent integer overflow in Query Planner parsing of hint parameter
SERVER-57657 disable_cluster_time_gossiping_in_unreadable_state.js shouldn't modify a response's $clusterTime
SERVER-57700 Measure latency/throughput of resharding::data_copy::fillBatchForInsert in ReshardingCollectionCloner::doOneBatch
SERVER-57737 The index builds code path can throw WCEs and invalidate an active cursor by calling abandonSnapshot without calling save/restore cursor.
SERVER-57740 ShardingTest use X509 also with preferTLS mode
SERVER-58051 Mongod.exe does not release file handles on rotated logs on windows 10
SERVER-58060 Add new aggregation stage to downconvert RRFaM images to oplog entries
SERVER-58068 Multi updates interrupted by a tenant migration should wait for the migration to complete
SERVER-58119 single_node_set_new_hostname.js needs to call replSetReconfig with an assert.soonNoExcept
SERVER-58152 Create Feature flag for Remove Faulty Mongos From Cluster Topology
SERVER-58160 Increase egress timeout in cluster_x509_roate.js
SERVER-58184 Checkpoint thread causes assertions when raced with recovering prepared transactions on startup
SERVER-58264 Only run cron jobs in Evergreen on the master branch
SERVER-58293 mongocryptd does not include server API fields in explain command response
SERVER-58353 Fix disabled Replication tests failing in multiversion suites due to changing latest release to 5.1
SERVER-58392 Unpin durable history on rollback to refetch
SERVER-58399 Duplicate errInfo field in write errors when operation fails document validation
SERVER-58402 Increase timeout of shutdown command in shutdown_primary.js
SERVER-58420 Gracefully handle the demotion of data-types in umask
SERVER-58432 Include dochub link in log line 5578800 when warning about deprecation/removal of old op codes
SERVER-58438 Tenant migration retryable write prefetching pipeline could be very slow under load
SERVER-58464 Invariant failure during time-series insert with concurrent shutdown
SERVER-58565 Adjust timeout for replica_sets_jscore_passthrough
SERVER-58581 Add SEARCH_META variable that populates from mongot
SERVER-58582 Create $documents stage and implement collectionless unionWith
SERVER-58588 Implement $searchMeta stage
SERVER-58594 ReplicationCoordinatorImpl::handleHeartbeatResponse_forTest doesn't use _mutex when reading _rsConfig
SERVER-58620 New recipient primary can complete migration before donor renames collection in tenant_migration_resume_collection_cloner_after_rename.js
SERVER-58626 Mark capped_max1 as tenant_migration_incompatible.
SERVER-58637 Temporarily disable null_query_semantics.js from multiversion passthroughs
SERVER-58669 createIndexes, dropIndexes, and collMod may still fail with ReshardCollectionInProgress after resharding operation completes
SERVER-58676 Ban pipelines that set SEARCH_META variable in sharded collections
SERVER-58682 check_todos.py should be no-oping in the waterfall
SERVER-58698 [Linux Repeated Execution builder] disable concurrency_replication_multi_stmt_txn
SERVER-58740 Reserve multiple oplog slots when writing retryable findAndModify with storeFindAndModifyImagesInSideCollection=true
SERVER-58806 Use replica_sets_jscore_passthrough_gen task on Enterprise MacOS
SERVER-58812 tenant_migration_timeseries_retryable_write_oplog_cloning.js should get donorDoc before being garbage collected
SERVER-58815 Have internal findAndModifyImageLookup set the synthetic oplog entry to timestamp of findAndModify - 1
SERVER-58823 The refineShardKey command should mark its operation context as interruptible at step down/step up
SERVER-58855 Improve/Fix the Race Condition in out_max_time_ms.js
SERVER-58857 Change stream accidentally filters out rename event from reshardCollection [5.0 Only]
SERVER-58886 Allow 'vars' result to be returned from a sharded search query but fail on SEARCH_META access
SERVER-58898 Prevent writing to "local" db from waiting for writeConcern
SERVER-58904 Escaped or single-quoted DESTDIR causes malformed .ninja and resmoke.ini
SERVER-58919 sharding_jscore_passthrough_wire_ops_gen needs to be marked as a generated task.
SERVER-58948 idl_tool: support generated idls
SERVER-58973 Fix failure deprecated_wire_ops_mongos.js with v5.0 windows debug build
SERVER-58984 awaitable_hello_fcv_change.js doesn't account for window between awaitable hello requests due to reconfig
SERVER-59000 Enforce dependencies for generated tasks
SERVER-59025 Increase storage log verbosity in oplog_slow_sampling_logging.js
SERVER-59040 add operations_longer_than_stepdown_interval tag to background_unique_indexes.js
SERVER-59044 Handle empty time series collection for $sample in the TrialStage
SERVER-59056 [5.0] Fix primary check in timeseries_retryable_write_downgrade.js
SERVER-59071 Using $sample can trigger invariant when connecting directly to shards
SERVER-59091 Avoid fetching namespace from durable catalog for every key inserted in index build
SERVER-59093 Temporarily disable the failing jstest suite for ephemeralForTest on evergreen
SERVER-59101 remove unnecessary LIBDEPS edge from pipeline library
SERVER-59117 xcode next builders hit dyld 512 library limit
SERVER-59121 ssh connection failure during check_disk command in powercycle should cause ssh failure exit
SERVER-59135 Make mongocryptd targets in MSIs depend on libsasl2
SERVER-59158 Support running checkFCV() shell helper with mongos connection
SERVER-59188 Coverity analysis defect 120391: Uninitialized scalar field
SERVER-59197 Delete fam image entries when the corresponding session documents are deleted
SERVER-59203 Don't rely on mocks to test generating tasks for build variants
SERVER-59204 unowned filter BSONObj stored in PlanCache entry debugInfo
SERVER-59217 convert spaces to tabs for package files
SERVER-59236 Add function to legacy shell to recursively copy directories
SERVER-59242 update to snmp 5.9.1
SERVER-59291 Consider adding 'enableSearchMeta' query knob
SERVER-59324 Remove feature flag performance variant from sys-perf on 5.0.
SERVER-59353 Have shell strip featureFlagRetryableFindAndModify when launching mongod version <= 4.4
SERVER-59362 Setup Fault Manager State Machine
SERVER-59404 Avoid powercycle_smoke_skip_compile reaching task timeout
SERVER-59431 [v5.0] disable parallel task in EFT builder
SERVER-59516 Create opCtx outside of lock in oplog fetcher
SERVER-59573 Add setParameter which can be used to restore inactive cursor timeout in sessions
SERVER-59640 [5.0] Add coverage for geoSearch command in views_all_commands.js test
WT-6755 Documentation: populate developer glossary
WT-6910 Write "history store" subpage for Architecture Guide
WT-6911 Write "block manager" subpage for Architecture Guide
WT-6915 Write "log files" subpage for Architecture Guide
WT-7006 Write Connection subpage for Architecture Guide
WT-7007 Backup architecture guide page
WT-7198 Fix test_backup15 failure with backup mismatch
WT-7352 Fix test_hs01 conflict between concurrent operations in cursor modify
WT-7363 Add support for dumping history store output in hex format
WT-7521 Remove excess ckplist invalidations
WT-7592 Remove log_flush("sync=background") support
WT-7599 Update the CONFIG file based on the release that is about to run for compatibility tests
WT-7663 Change local store extension to allow only readonly FS operations
WT-7673 Investigate and fix manydbs test failure on Windows
WT-7718 Rename 'build_cmake'
WT-7838 Ability for ordered timestamp assertion to do more than a log message
WT-7842 Remove explicit ulimit -n call in many-collection-test
WT-7860 Improve code coverage reporting
WT-7866 Update cache_hs_insert limits in cppsuite-hs-cleanup-stress
WT-7876 Update rollback to stable test to use correct boolean values and update statistic checking logic
WT-7880 Fix history store record issue when the update following the prepared update is in history store
WT-7891 Remove doc typos
WT-7893 Remove ignored message from wiredtiger_open in test_encrypt08
WT-7895 Fix arch-data-file.dox documentation build failure
WT-7897 Enable verbose logging for test_backup15 to aid debugging
WT-7900 Fix insertion of new records in test format for column-store
WT-7901 test suite cleanup
WT-7905 Fix incorrect builtin behaviour for builds in CMake
WT-7907 Add dependencies to swig module definition in CMake build
WT-7908 Make variable-length column store work again with the static tests
WT-7909 Create a new method to check for running user transactions before starting rollback-to-stable operation
WT-7918 Support setting a prepare timestamp at current read timestamp
WT-7928 VLCS checkpoint and additional test suite improvements
WT-7931 Evicting modifies using the evict cursor in test_multiple_older_readers_with_multiple_mixed_mode() to ensure that eviction happens.
WT-7934 Upload perf results from many-collection test to Altas
WT-7935 Add arm64 implementation of rdtsc equivalent instruction
WT-7936 Update the format.sh script to run recovery tests
WT-7937 Fix s_docs to use sh, not bash syntax
WT-7938 Fix rollback-to-stable memory leak on error
WT-7940 Update mongod path for many-coll test
WT-7941 Add an Evergreen task to test abort/recovery using test/format
WT-7943 Do not assert timestamps when rolling back a prepared transactions
WT-7945 Move rollback handling to the operation layer in the cppsuite.
WT-7947 Allow CMake to take in a specific Python version
WT-7952 Minor docs build fixes
WT-7953 Teach s_string to not look inside getopt option lists.
WT-7955 Copy format.sh and CONFIG.stress to the test/format build directory with CMake
WT-7956 RTS to skip deleted or stable RLE cells
WT-7961 Sometimes lag oldest timestamp in timestamp_abort.
WT-7964 Fix rollback to stable incorrectly not rolling back updates at snap_max
WT-7965 Update connection base write generation number at the end of recovery checkpoint
WT-7968 In timestamp_abort skip setting timestamps when all_durable moves backwards
WT-7970 Set the stable timestamp before starting the checkpointer and clock threads
WT-7974 More column-store fixes and tests
WT-7984 Fix a bug that could cause a checkpoint to omit a page of data
WT-7994 Add docs compile task to PR testing
WT-7995 Fix the global visibility that it cannot go beyond checkpoint visibility
WT-7996 More column-store C testing
WT-7998 Minor fixes on Cache subpage of Architecture Guide
WT-7999 Fix the assert to handle an update in the middle with max stop timestamp
WT-8005 Fix a prepare commit bug that could leave the history store entry unresolved
WT-8006 sync/checkpoint cleanup code isn't appropriate for VLCS
5.0.2 Changelog
Security
SERVER-57727 Race conditions in x509_invalid.js
Sharding
SERVER-47372 config.cache collections can remain even after collection has been dropped
SERVER-48651 Avoid lock timeout errors in refine_collection_shard_key_basic.js
SERVER-50521 Write reshardBegin no-op oplog entry after temporary resharding collection is created
SERVER-54948 Calling shardCollection after enableSharding from a different MongoS is not causally consistent
SERVER-55574 Migration distlock acquisition fails to catch status
SERVER-56647 Make dropDatabase resilient to network partitions
SERVER-56648 Make dropCollection resilient to network partitions
SERVER-56649 Make renameCollection resilient to network partitions
SERVER-56650 Make createCollection resilient to network partitions
SERVER-57204 Extend the _configsvrSetAllowMigrations command to take the collection uuid to make it idempotent
SERVER-57380 Improve "InvalidOptions: read concern level snapshot is only valid in a transaction" message during cluster incompatibility
SERVER-57488 Create command to remove tags matching a ns from config.tags that can be run as retryable write
SERVER-57496 Proactively evict cached entries after drop database/collection
SERVER-57559 Implement LSID cache for DDL coordinators
SERVER-57759 Run movePrimary command before sharding the source collection in the ReshardingTest fixture
SERVER-57850 Increase timeout when waiting for migration on authCommands.js
SERVER-57870 Drop database sharded FSM doesn't guarantee that operations will be completed
SERVER-57944 Targeter is not being clean completely after failed refresh on batch write executor
SERVER-58021 mongos should retry write upon getting ShardCannotRefreshDueToLocksHeld error from shard
SERVER-58048 Resharding's initial split points for hashed shard keys don't match the sampled values
SERVER-58089 Coverity analysis defect 120194: Uninitialized pointer field
SERVER-58115 Outdated information can remain in the catalog cache after a collection is renamed
SERVER-58143 shardsvrDropCollectionParticipant should be killable on stepdown
SERVER-58167 Use scoped database critical section during dropDatabase
SERVER-58266 Stop forcing database version refreshes in chunk manager targeter
SERVER-58271 Stop forcing collection version refreshes in chunk manager targeter
SERVER-58273 Solve deadlock caused by uninterruptible lock guard in drop db participant command
SERVER-58321 Check recipient document existence instead of donor twice in resharding abort command
SERVER-58364 ShardServerCatalogCacheLoader::waitForCollectionFlush should be interruptible
SERVER-58465 Fix the cleanup of the Routing Info in the rename operation
SERVER-58535 _shardsvrRenameCollection should be interrupted on stepdown
SERVER-58589 Remove ShardingFullDDLSupportTimestampedVersion feature flag
SERVER-58624 Change the resharding critical section timeout value for reshard_collection_basic.js
SERVER-58649 Do not assume that the collection is always sharded in ShardServerProcessInterface::checkRoutingInfoEpochOrThrow method
SERVER-58747 The ShardServerCatalogCacheLoader doesn't interrupt ongoing operations on step up
SERVER-58749 Drop database coordinator must acquire collection distributed lock
SERVER-58775 Mark ConfigsvrSetAllowMigrationsCommand's opCtx as killable on stepdown
Replication
SERVER-37904 Allow a node to override the cluster chaining (enabled/disabled) setting
SERVER-58258 Wait for initial sync to clear state before asserting 'replSetGetStatus' reply has no 'initialSync' field
SERVER-58625 Add multi_update tag to geo_update1.js to exclude from certain passthrough suites
Query
SERVER-54078 [SBE] Improve perf of the bestbuy_agg_merge_wordcount benchmark suite
SERVER-58127 Fix benchRun() memory leak for parsing benchRun() args under exception
SERVER-58372 Robustify deprecated_wire_ops_mongos.js
Storage
SERVER-50287 drop_index.js fails when run in passthrough suite with stepdown
SERVER-56019 timeseries_index.js hangs in burn_in_tests burn_in:replica_sets_initsync_jscore_passthrough subtask
SERVER-56877 insert operations may fail to set index to multikey after aborted multikey catalog update
Operations
SERVER-58510 Fix 'use after free' issue in getExecutorForSimpleDistinct() function
Build and Packaging
SERVER-54729 MongoDB Enterprise Debian/Ubuntu packages should depend on libsasl2-modules and libsasl2-modules-gssapi-mit
SERVER-55446 Stand up an Apple Silicon compile-only builder on the Xcode 12 enabled hosts.
Internals
SERVER-56446 Can't use ReplSetTest.restart() in _auth suites with waitForConnect: false
SERVER-56568 Disable vptr UBSAN checks in dynamic builds and remove LIBDEPS_TYPEINFO
SERVER-56620 Nodes should explicitly clear arbiter durableOpTimeAndWalltime
SERVER-56625 validate cachedir race condition when cleaning bad cachefile
SERVER-56980 Robustify jstests/core/query_hash_stability.js
SERVER-57002 Refactor Evergreen task creation to support building multiple tasks
SERVER-57003 Generate all tasks for a build variant in a single task
SERVER-57064 Log create index and dropIndex(es) on mongos
SERVER-57176 The 'validateFeaturesAsPrimary' flag should be set to false while a node is in recovery phase
SERVER-57268 add multikey query to validate_multikey_restart.js
SERVER-57302 Generate implicit multiversion tests uses invalid name
SERVER-57327 evergreen ninja builders fail to copy install file
SERVER-57396 Enable visibility support by default on platforms where it is applicable
SERVER-57425 Avoid killing opCtx while holding the SessionCatalog mutex
SERVER-57450 Newly added tests do not show up in generated dynamic resmoke suites
SERVER-57474 profile_operation_metrics.js not resilient to query yielding
SERVER-57521 fCV change unconditionally closes outgoing connections that have not finished their hello handshake
SERVER-57576 validate_cache_dir should print the stacktrace
SERVER-57580 Simplify multiversion handling in evergreen.yml and task generation
SERVER-57642 Invariant Failure on src/mongo/db/query/plan_yield_policy.cpp 75 | Aborting
SERVER-57650 Make MigrationChunkClonerSource interruptible when waiting response to recipient commands
SERVER-57676 Wait for a checkpoint before releasing the "hangOplogCapMaintainerThread" in oplog_rollover.js
SERVER-57729 Cannot drop time-series collection if buckets collection does not exist
SERVER-57742 Create a non-specialized version of the OperationLatencyHistogram class
SERVER-57750 use a more distinct read command in quiesce_mode.js so that internal ops don't set off the failpoint
SERVER-57756 Race between concurrent stepdowns and applying transaction oplog entry
SERVER-57771 SBE explain does not report correct trial period statistics for a winning sort plan in "allPlansExecution" section
SERVER-57790 Minimise the impact of fCV upgrade/downgrade between 4.4 and 5.0 with large routing tables
SERVER-57798 Direct user to MongoDB Compass download page when failing to install MongoDB Compass due to a connection issue using ./install_compass
SERVER-57837 Adding TSBS to system_perf.yml
SERVER-57869 Shell getShardDistribution helper does not accumulate chunk counts on 5.0.0-rc1
SERVER-57926 Adjust log level from the evergreen scons splunk task
SERVER-57928 create_collection.js should use a dedicated database name and avoid dropping the test database
SERVER-57951 Incorrect data files archived by hook_test_archival.py
SERVER-57983 Integer overflow for $range in Classic Engine
SERVER-58020 cache-dir: prevent same buildsig with different content race condition
SERVER-58022 tenant_migration_resume_oplog_application.js should account for resumeTokens being part of an application batch
SERVER-58086 Investigate why debug symbols are not marked for download in some tasks
SERVER-58087 Reduce overhead of activated generated tasks
SERVER-58159 Extend relaxation of index ident reconciliation invariant for single-phase index builds
SERVER-58169 Log timestamps info on hitting invariants around stable timestamp calculation
SERVER-58187 Improve Connection Reaper and MongoLDAP performance
SERVER-58191 [Migrate Protocol] Allow delete_during_migrate.js to tolerate chunk migration failures due to timeout in catchup phase in slow variants.
SERVER-58197 Pass ranges by reference when constructing a Sorter from existing ranges
SERVER-58202 mark several tests as requires_sharding
SERVER-58208 Allow top-level $graphLookup stages to run in parallel on shards
SERVER-58249 findAndModify_flip_location.js should account for racey upserts when run in multiversion suites against 4.4 binaries
SERVER-58250 Inefficient usage of memory tracking map for $group and $setWindowFields
SERVER-58280 initial sync hangs on hiding dropped index when index builds are active
SERVER-58283 Add a new versioning file to set MONGO_VERSION and MONGO_GIT_HASH
SERVER-58332 pipeline MemoryUsageTracker: change StringMap to unordered_map for pointer stability
SERVER-58335 Remove SBE build variants from the 5.0 branch
SERVER-58357 [ephemeralForTest] TemporaryKVRecordStore fails to register commit handler in WCE loop
SERVER-58395 Resharding metrics should set donorState/RecipientState to kUnused if they are not initialized for currentOp report.
SERVER-58400 Generated timeouts need to take repeated execution into account
SERVER-58480 Add the necessary parameters to the ContinuousTenantMigration hook to allow for proper transient error retry
SERVER-58515 [ephemeralForTest] disable parallel task in EFT builder
SERVER-58532 Take when a build is ASAN into account when calculating timeouts
SERVER-58576 Improve tests for task generation
SERVER-58651 Kill ssh tunnel process in exit handler in powercycle
SERVER-58662 Disable tsbs on variants with older versions of mongodb
SERVER-58707 Move
bench_test*.js
tests out of parallel test jobSERVER-58734 Add evergreen task for new change stream fuzzer
SERVER-58746 Build failure on macOS 10.12; mongodb 5.0.0 requires macOS 10.13+?
SERVER-58794 _configsvrCreateDatabase and _flushDatabaseCacheUpdates should accept any API version parameters
SERVER-58816 errors_on_committed_transaction.js incompatible with multiversion tests in v5.0
SERVER-58936 Unique index constraints may not be enforced
WT-6280 Fail eviction if out of order handling races with checkpoint
WT-6729 Quiesce eviction prior running rollback to stable's active transaction check
WT-6782 test_prepare_hs02 WT_ROLLBACK failure: conflict between concurrent operations
WT-6902 Metadata subpage for Architecture Guide
WT-6914 Write "database files" subpage for Architecture Guide
WT-7279 Allow multiple terminate calls for storage source extension
WT-7343 Write a script that executes many-collection-test.py
WT-7473 Resolve "TODO: tiered" comments in code
WT-7507 Update salvage for a history store and timestamp world
WT-7520 Add start and stop values to automatic flag generation code
WT-7524 Refactor functions to obtain checkpoint list; Clear delete on skipping checkpoints
WT-7539 Add a configuration option that allows the user to specify debug modes.
WT-7543 Pass in the correct test name when constructing the default config path
WT-7553 Loosen the restrictions around evicting fast-truncate pages to avoid cache-stuck failures
WT-7556 Fix test_rollback_to_stable10 failure cache_hs_ondisk is 0
WT-7603 Sort statistics to fix JSON output
WT-7605 Drop support for million-collection-test
WT-7609 Report on time taken to start and shutdown the database in many-coll-test
WT-7616 Create a pass or fail test based on many collection workgen workload
WT-7619 Add a new optimization to skip pages in cursor traversal when all entries on the page are deleted
WT-7626 We only ensure update restore eviction happened in test debug mode09
WT-7628 Return an error message when supplied invalid command line args in the test framework
WT-7629 Run clang format on .cxx files in the codebase.
WT-7632 Fix invalid argument in test_rollback_to_stable14
WT-7640 Fix test_backup02 failure where checkpoint tables differ due to checkpoint cursor not supported
WT-7660 Rename poc_test to base_test in the cpp test framework and add insert_operation logic
WT-7667 Fix workgen JSON output
WT-7668 Overload the update method for the hs_cleanup test
WT-7670 Modify test tag format and tag additional python tests
WT-7676 Reformat wtperf backup to only read in files instead of wt_copy_and_sync
WT-7679 Create an evergreen test for many-dhandle-stress
WT-7683 Add python test hook to call flush_tier() during connection.close()
WT-7687 Stop tiered manager thread before internal thread
WT-7689 Fix double free in __curhs_insert
WT-7690 Fix coverity error when enum is compared against 0 (incr_backup:table_changes)
WT-7692 fix make check test failure on osx10 14 cmake
WT-7696 Fix coverity error - Unused variable in _rollback_to_stable_btree_apply_all
WT-7698 Decrease max_latency value in many dhandles scenario for workgen
WT-7703 Fix timeout in test_checkpoint_snapshot04
WT-7705 Add an assert to ensure that there are no updates on the new disk image in update restore
WT-7707 Simplify insert splits to use the splitting WT_REFs key
WT-7708 Add an assert to ensure the durable timestamp is larger than stable timestamp at the end of prepared commit
WT-7715 Fix uninitialized bool in txn_ckpt.c
WT-7717 Change macros in local_store.c to use WT namespace
WT-7719 Change default value of ENABLE_STRICT to "OFF" (CMake Usability Improvements)
WT-7720 Update POSIX CMAKE doxygen documentation (CMake Usability Improvements)
WT-7723 Delete the updates in the history store if they are rolled back or is the first stable update on the update chain
WT-7724 Fix race when running concurrent checkpoint and flush_tier
WT-7725 Add missing brackets around parameter in macro definition
WT-7726 Separating out the validation portion from the database model
WT-7727 Fix null pointer passed to memcpy() during 'format' test.
WT-7729 Fix to write out correct tiered information on checkpoint
WT-7730 Shifting the oldest and stable timestamps to match the commit timestamp format
WT-7732 Add a timeout configuration for flush_tier
WT-7739 Switch back to using MacOS 10.14 for Evergreen compile task
WT-7741 Fix misaligned address in crc32-x86.c
WT-7742 Fix misaligned address in wt3184_dup_index_collator/main.c
WT-7743 Fix integer overflow within wt2999_join_extractor csuite test
WT-7744 Fix null pointer within wt3338_partial_update csuite
WT-7746 Improve directory syncing with CMake helper 'create_test_executable'
WT-7748 Fix CMake library probes for libraries not on the default linker path
WT-7749 Assorted fixes for (and from) building and testing on NetBSD
WT-7751 Add an assert to ensure we never select an update that has been written to the history store for data store
WT-7752 Update packing code according to documentation
WT-7754 Fix race when updating block manager file handle
WT-7755 YSCB: Add a native implementation of YCSB to WTPERF.
WT-7756 RTS to clear the HS flag of an update following tombstone
WT-7758 Force evict a page when the update chain is too long
WT-7761 Improve debug_print to include timestamp, thread_id and reorder args in cppsuite.
WT-7762 Create stressful configs for the two tests add them to evergreen.
WT-7763 Coverity issues found in the stress testing framework
WT-7765 Fix signed integer overflow in intpack-test3
WT-7766 Fix null pointer passed to memset in test_wt3338_partial_update
WT-7767 Code cleanup for curhs_remove and __txn_fixup_prepared_update
WT-7770 Fix issue linking TCMalloc in CMake
WT-7776 Add a hard limit on the number of modify updates before we instantiate a complete update
WT-7778 Fix null dereferencing, and return of incorrect allocation size
WT-7780 Guarantee log message sequencing in the test framework.
WT-7781 Avoid skipping python tests for 3rd party ext libraries in CMake builds
WT-7782 Separate implementation from headers in cppsuite test framework
WT-7784 Enable RTS to use checkpoint snapshot on timestamp tables
WT-7787 Don't read pages for checkpoint cleanup when the cache is in aggressive mode
WT-7789 Change tiered python tests to fail without extension library
WT-7795 Fix CppSuite failure "expected ) before PRIxMAX"
WT-7796 Scan the tracking table and delete parts of it that are obsolete.
WT-7797 Disable postrun stats in CppSuite testing
WT-7799 Do not report failure of wiredtiger_open in python tests to output
WT-7802 Remove data store same transaction update squash logic
WT-7804 Fix test_hs24 committing mixed mode update from the wrong value
WT-7807 Remove unused arg in backup_config
WT-7811 Fix test_hs24 not commiting from 0 timestamp
WT-7813 Stop inserting to history store if we see a prepared update
WT-7815 Properly initialize prev_upd_ts for ordered timestamp assertion
WT-7817 Make tiered storage address cookies backward compatible
WT-7825 Fix test_hs24 key order
WT-7831 Clear transaction ids from previous run when repack the cell
WT-7832 Add an encryptor extension that uses the libsodium cryptography library.
WT-7836 Fixing a number of small issues in the cppsuite test framework
WT-7837 Clear updates structure in wt_hs_insert_updates to avoid firing assert
WT-7841 add "only unencrypted" checksum configuration, switch checksum default to "on"
WT-7843 Add missing macros to define PRIxMAX
WT-7846 Disable test_tiered08
WT-7851 Fix illegal checksum configuration in compatibility-test-for-newer-releases
WT-7852 Don't release eviction server lock when evicting pages
WT-7856 Enable flush test with open cursor in test_tiered04
WT-7864 Add support to run.py for running lists/ranges of scenarios in a test
WT-7865 Disable timeout assert while waiting for eviction to quiesce prior to RTS and test
WT-7870 Fix measurement of cyclomatic code complexity
WT-7871 Remove comment that is no longer true
WT-7874 Remove two other stale comments
WT-7883 Remove incorrect wt_free statement
WT-7889 Find/replace existing uses of WT with WiredTiger in reference guide
WT-7890 Fix CMake syntax error in config_lib
5.0.1 Changelog
Replication
SERVER-58398 Tenant migration hung indefinitely
Internals
SERVER-58142 TenantOplogBatcher should transition to complete when the next batch callback is called with error status
SERVER-58171 Changing time-series granularity does not update view definition
SERVER-58489 Collection creation stuck in an infinite writeConflictRetry loop when having a duplicate name as a view
SERVER-58546 Add log message to applyOps to preview which oplog entries will be applied