7.3 Changelog
Important
MongoDB 7.3 is a rapid release and is only supported for MongoDB Atlas. MongoDB 7.3 is not supported for use on-premises. For more information, see MongoDB Versioning.
7.3.4 Changelog
Sharding
SERVER-82281 ShardingTest.js Does Not Merge Multiple SetParameters Properly
SERVER-89529 Retryable writes during resharding may execute more than once if chunk migration follows the reshard operation
Query
SERVER-37164 Incorrect query results on $gte null with sparse index
SERVER-91512 BlockToRowStage::doSaveState discards the unowned values while still deblocking values
Aggregation
SERVER-89344 Fix explain output for '$unionWith' queries
Internals
SERVER-81596 Fix Race in index_operations_abort_concurrent_outgoing_migrations.js
SERVER-82668 Remove fsync_deadlock.js from the sharding_csrs_continuous_config_stepdown suite
SERVER-84026 Ignore ConflictingOperationInProgress in random_moveChunk_update_shard_key_kill_sessions.js
SERVER-84143 Improve Windows Debugging capabilities for BSON and core dumps
SERVER-84315 Introduce new flag to control spilling strategy in $group
SERVER-84699 Add a check to validation to check for mixed-schema buckets for time-series
SERVER-85327 Use countDocuments() instead of itcount() when asserting document count in write without shard key concurrency workloads
SERVER-85532 Make shape helpers robust to invalid $hint
SERVER-86329 improve compile_upload_benchmarks required functionality
SERVER-86669 Invalid authoritative knowledge on secondary node after move primary locally creates the collection on the primary shard
SERVER-86829 Make concurrency_replication_for_export_import not run analyze_shard_key.js
SERVER-86879 concurrency_replication* tasks are not running on the UBSan DEBUG build variant
SERVER-86905 Inconsistent values for $$NOW across shards in find queries
SERVER-87267 Increase bucket_catalog memory usage threshold for timeseries_dynamic_bucket_sizing.js
SERVER-88255 Sys-perf: Replace mongotools compilation with the download of a static artifact
SERVER-88350 test_packages should only install_compass on the support platforms
SERVER-88417 processReshardingFieldsForRecipientCollection can use stale db info and incorrectly creates a recipient
SERVER-88439 Use after free in DocumentSourceLookup::clone
SERVER-88530 BF setup script for C++ unit tests doesn't set up unit test binary/debug symbols
SERVER-88811 Parsing oplog entries before the stable timestamp can fail
SERVER-89055 Fix persist_sampled_*_queries.js test cases to not share namespaces
SERVER-89313 Reevaluate the Changes for SERVER-86505
SERVER-89542 Serialize failpoint toggling in ldap_runtime_configuration.js
SERVER-89711 proxy_protocol.js should handle errors when running proxyprotocol.server
SERVER-89748 Retry _flushRoutingTableCacheUpdates command if it fails in retry_on_transient_error_basic.js
SERVER-89803 Robustify awaitdata_getmore_cmd.js to filter on specific ns when querying the oplog
SERVER-89844 Make $jsonSchema with dollar fields in all keyword fields reparseable
SERVER-89994 Allow direct shard operations which acquire locks only on non-user collections
SERVER-90086 Fix direct_shard_connection_auth checks for directConnectionChecksWithSingleShard
SERVER-90147 Upgrade timelib.h to 2022.10 and timezone files to 2024a
SERVER-90168 Disable LTO buildvariants that are incompatible with Bazel
SERVER-90217 Consider setting orphanCleanupDelaySecs on suites with balancer and failovers
SERVER-90234 Allow jsTestName() for SElinux tests
SERVER-90330 Creation of DDL coordinator hang indefinetly if executed on secondary node
SERVER-90391 Clarify headers and readme
SERVER-90545 Update stitch_support headers to be usable with cgo
SERVER-90727 Fix analyze_shard_key.js to ignore errors related to readConcern: available
SERVER-90777 Revert SERVER-71520
SERVER-90790 Add debugging code for CommonAsioSession constructor
SERVER-90833 Fix incorrect bounded sort optimization when time field is renamed by $addFields
SERVER-90869 Disallow dotted full-path renames for '$elemMatch' expressions
SERVER-90893 listDatabases inconsistent with concurrent DDL operations
SERVER-90958 $bucketAuto should group documents with same grouping keys in the same bucket
SERVER-90984 Fix exhaust hello stream to process SplitHorizonChange if response is from stale horizon.
SERVER-90995 Shadowing metaField should not be considered as a "computed" meta field
SERVER-91022 Prevent timeseries_groupby_reorder_expr.js from running timeseries_groupby_reorder.js
SERVER-91028 Wrong order when using index with collation
SERVER-91066 Set migrationCommitVersionError failpoint on all configsvr nodes in migration_coordinator_failover_include.js
SERVER-91114 Ensure findAndModify cmd executes before range deletion in write_without_shard_key_single_shard_data_placement_change.js
SERVER-91166 Transactions in retryable_write_error_labels.js should update different documents
SERVER-91176 Call awaitNodesAgreeOnAppliedOpTime in ignore_dbcheck_in_startup_recovery.js
SERVER-91178 Handle a snapshot read performed at a timestamp before collection drop
SERVER-91193 timeseriesBucketingParametersHaveChanged not properly cloned upon data migration/initial sync/restore
SERVER-91195 Provide a generic backportable solution not to miss top-level timeseries collection options
SERVER-91203 AutoGetters should establish capped snapshots for secondary namespaces
SERVER-91222 Make cluster_time_across_add_shard.js temporarily retry on KeyNotFound error after restarting the replica set
SERVER-91223 $log gives incorrect calculation with Decimal128
SERVER-91247 Ensure that DDLCoordinator creation does not survive node stepDown-stepUp
SERVER-91254 Error when deciding whether documents are inside a window in classic
SERVER-91258 Increase oplog size in change_streams_split_event tests
SERVER-91276 [v7.3] Fallback to public repo when trying to obtain backports_required_for_multiversion_tests file
SERVER-91322 set evergreen config options in the multiversion-config subcommand
SERVER-91324 Pin jepsen clones to a specific tag
SERVER-91339 $redact may corrupt memory if $$ROOT is used in the expression.
SERVER-91362 Performance: Do not copy JS "scope" object if a cached JsExecution exists
SERVER-91366 Fix possible crash in coordinator completion
SERVER-91379 Re-introduce eslint rule for missing semicolons
SERVER-91406 $changeStreamSplitLargeEvent returns Location7182803 error when used with non-renameable match expression
SERVER-91411 Check for timeseries options in timeseriesBucketingParametersHaveChanged
SERVER-91412 Unowned BSONObj use in splitVector
SERVER-91416 Serialize lookup's introspection sub-pipeline during query analysis
SERVER-91435 Regenerate test certs with legacy flag
SERVER-91473 Don't run index_count_scan.js in v7.3/7.2 multiversion tests
SERVER-91494 Avoid past-the-end access of group by field in DocumentSourceBucket
SERVER-91499 Append "-sysperf" to mongo version in sys-perf.
SERVER-91501 TTLMonitor can crash trying to deregister an already deregistered index
SERVER-91531 index_drop_before_running.js should wait for replication before asserting index drop on secondary
SERVER-91558 Make HedgeCancellationTest resilient to operation interruption
SERVER-91687 Fix LOG_V2DEBUG() numbers from SERVER-90790
SERVER-91699 Subtracted memory greater than the total memory
SERVER-91700 Boolean simplifier causes problems on upsert
SERVER-91701 Robustify max_time_ms_does_not_leak_shard_cursor.js test
SERVER-91758 mongos_rs_shard_failure_tolerance.js should retry NetworkInterfaceTimeLimitExceeded for a sharded find command on versions earlier than 8.0
SERVER-91778 Do not close cursor in the shell when cursor reaches limit
SERVER-91781 Wait for replication in merge_let_params_size_estimation.js
SERVER-91784 $project-$addFields on arrays can produce incorrect results
SERVER-91817 Make analyze_shard_key.js workload more robust
SERVER-91818 resharding_coordinator_recovers_abort_decision.js Should Be More Insistent When Stepping Up New Primary
SERVER-91831 uassert in NetworkInterfaceTL::setTimer can crash the server
SERVER-91859 analyze_shard_key_jscore_passthrough fails when it encounters CommandOnShardedViewNotSupportedOnMongod errors
SERVER-91894 Fix views_basic.js to reference correct database name
SERVER-91919 change_stream_pit_pre_image_deletion_asymmetric.js can use excessive amount of memory
SERVER-91985 Fix race in egress_connection_acquisition_to_wire_metrics.js
SERVER-92045 Mixed-schema time-series bucket validation check does not set valid flag on error
SERVER-92052 [v7.3] jstests/aggregation/sources/setWindowFields/time.js fails in SBE in v7.3
SERVER-92085 Skip tailable cursor invalidation test for config fuzzer
SERVER-92158 Disable hedged_reads.js on windows variants
SERVER-92159 [v8.0] Ignore InternalError in setfcv_aborts_reshard_collection.js
SERVER-92186 Implement simple API to get/set app_metadata from/to wiredtiger config strings
SERVER-92193 Index Bounds Builder tries to build geo bounds using non-geo index
SERVER-92199 Ban change_stream_lookup_single_shard_cluster.js from stepdown suites
SERVER-92201 currentop_shell.js may not wait long enough for all shards to be ready in sharded collection passthroughs
SERVER-92254 Fix deadlock in _shardsvrCompactStructuredEncryptionDataCommand
SERVER-92298 Remove unused ProjectionPathASTNode argument to speed up $project aggregation requests
SERVER-92375 Remove minor version from rhel8.x variant names
SERVER-92377 Clean up the system_perf.yml configuration
SERVER-92379 Reuse the mongodb-mongo-master compile for the mongocrypt library
SERVER-92382 Updating a prepareUnique index does not check whether constraints are being enforced
SERVER-92401 Use rhel79-selinux distro rather than rhel76-selinux distro in v7.x
SERVER-92415 Bump db-contrib-tool version to v0.8.3
SERVER-92417 [v7.3] Enable indexed plans for expressions with $$NOW, $$CLUSTER_TIME and $$USER_ROLES
SERVER-92547 Use the old rhel80 variant name on v4.2 and v4.4 multiversion tests
SERVER-92549 [v7.3] Fix sbe_multiplanner_index_check.js in classic engine
SERVER-92601 Remove the package_new_compile task
SERVER-92603 Or-to-in rewrite does not always avoid rewriting parameterized expressions
SERVER-92623 Pin the version of v5.0 to 5.0.28 in timeseries_collection_mixed_type.js
SERVER-92670 Fix indents in test yml on 7.3
SERVER-92689 Fix continuous multiversion tests on v7.3 branch
SERVER-92777 Fix the URL components for the RHEL8 artifact
SERVER-92939 Route tools download to the newest rhel version
SERVER-93005 Avoid duplicating read preference when running an exhaust query in the shell
SERVER-93014 Setting locally timeseriesBucketsMayHaveMixedSchemaData during MultiIndexBlock::commit might generate catalog inconsistencies
SERVER-93099 Allow collMod with timeseriesBucketsMayHaveMixedSchemaData=false
7.3.3 Changelog
Sharding
SERVER-89744 Resharding incorrectly builds {locale: "simple"} secondary indexes with collection's non-"simple" default collation
SERVER-89893 Change executor used by _flushReshardingStateChange from arbitrary to fixed
Aggregation
SERVER-90297 Empty field match expression causes change stream optimization rewrite failure
Storage
SERVER-30832 Fix dbCheck behavior on rollback
Internals
SERVER-58300 Generalize the concept of a shard-local collection
SERVER-77559 Implement file system log handler for resmoke
SERVER-77561 Rollout resmoke file system logging
SERVER-78556 Return default of internalInsertMaxBatchSize to 64
SERVER-80519 Turn on reshardingImprovements feature flag in resharding_recipient_service_test
SERVER-81454 Timeseries $geoNear throws unexpected error with lookup
SERVER-82764 Make "planningTimeMicros" incorporate time from the multi-planner trial period
SERVER-83193 Replace deprecated BatchedCommandRequest getters/setters for WC with the ones provided by OperationContext
SERVER-83712 Do not add $in length to plan cache key if there is no sort
SERVER-84531 Inserting mixed-schema buckets through the system.buckets collection doesn't set the timeseriesBucketsMayHaveMixedSchemaData flag
SERVER-84628 Startup warning in mongos for Read/Write Concern
SERVER-84761 MigrationSourceManager may fail to emit the migrateChunkToNewShard due to stale ChunkManager info
SERVER-85446 Retry on network error in multiversionconstants.py
SERVER-85721 Point evergreen task log lobster links to Parsley
SERVER-85775 Make InListData sort and dedup lazily
SERVER-85799 rollback_recovery_commit_transaction_before_stable_timestamp should wait for system to stablize before disabling failpoint
SERVER-86405 Exclude 'update_with_pipeline.js' from 'fcv_upgrade_downgrade_sharded_collections_jscore_passthrough'
SERVER-86667 Kickback machinery to translate views over sharded collections doesn't properly work under 'available' read concern
SERVER-86674 Primary catch-up may believe it is caught up when it is not
SERVER-86781 [v8.0] Update query stats upgrade tests to account for 7.0 backport
SERVER-86904 Conflict between initial sync setting the oldest timestamp and resharding pinning the oldest timestamp
SERVER-86945 $jsonSchema with $field in properties is not re-parseable
SERVER-87059 Setting the cluster cardinality parameter may cause setFCV to fail on retry
SERVER-87087 Validate unique index ordering check does not work for clustered collections
SERVER-87267 Increase bucket_catalog memory usage threshold for timeseries_dynamic_bucket_sizing.js
SERVER-87563 Failure to parse oplog entries should be less disruptive
SERVER-87705 Fix race in InvalidTTLIndexFixer
SERVER-87961 Time series $group rewrite may produce incorrect results when a preceding $project stage projects out accessed fields
SERVER-88068 Exclude hashed_index_with_arrays.js from fcv_upgrade_downgrade suite
SERVER-88072 Timeseries query errors instead of producing a correct response
SERVER-88098 Add try/catch to notablescan.js to reduce testnoise
SERVER-88172 Config can be used as primary shard even in cluster with dedicated config server
SERVER-88263 Move direct connection warnings to the collection acquisition (and AutoGetCollection)
SERVER-88264 Add an option to enable warnings for direct connections on single shard clusters
SERVER-88318 Fail dbcheck if one batch failed waiting for write concern
SERVER-88331 Don't process numeric paths in SBE
SERVER-88548 checkShardingIndex command must throw InvalidOptions when no suitable index is found
SERVER-88656 Make sharded time-series query kickback logs less scary
SERVER-88694 Do not emit error logs for self-recovering scenarios in BalancerStatsRegistry
SERVER-88833 mongos generates a reply for writes sent by client with w:0
SERVER-88885 Add a way to stop applying a dbcheck batch on secondary
SERVER-88978 Resharding coordinator should ensure participants have seen kAbort before dropping temp collection metadata
SERVER-89034 Always preserve 0-valued timestamps when migrating documents, add tests
SERVER-89100 Renaming timeseries collection should be disallowed on sharded cluster
SERVER-89331 Coverity analysis defect 141172: Wrapper object use after free
SERVER-89418 CursorManager loses track of registered cursors for queries with multiple executors
SERVER-89443 Rewrite insert_with_data_size_aware_balancing.js as a ShardingTest-based test
SERVER-89454 Disable ocsp on Debian variants
SERVER-89478 Use element_to_be_clickable instead of presence_of_element_located
SERVER-89490 Return ErrorCodes::NetworkTimeout in LDAP connection pool
SERVER-89495 Disable test parameters even when no setParameters are specified
SERVER-89496 Collect change stream queries using $_passthroughToShard for query stats
SERVER-89566 DocumentSourceVectorSearch clone should copy the original spec
SERVER-89567 failed: test_packages on debian12 [mongodb-mongo-v7.0 @ dfda1c8b] (debian12-org-7.0.4-23-gdfda1c8)
SERVER-89618 Must disable validation when reconstructing prepared transactions
SERVER-89623 Clone Jepsen repo in 10gen/mongo using specific tags
SERVER-89646 Add all Network Error Code Strings to List of Strings isNetworkError() Looks For In Exception Message
SERVER-89752 Make logkeeper buildIDs stay unique when branching
SERVER-89767 Remove redundant and incorrect suite names from multiversion tasks
SERVER-89831 Add extra logging to PlanCacheBase::getNewEntryState
SERVER-89854 Do not require parameterization for regex expressions
SERVER-89859 Make move_chunk_deferred_lookup.js more robust to slower variants
SERVER-89873 Don't call printAllThreadStacks() in execution control
SERVER-89904 Update Jepsen version for "jepsen-docker" tests
SERVER-89930 Validates the $densify stage properly if 'partitionByFields' contains the densifying field
SERVER-89933 Remove shard split performance test
SERVER-89936 Exclude latch tests from running in trySbeEngine build variant
SERVER-89939 Limit logs used for direct connection log ingestion to be once per hour
SERVER-89943 Feature flag util must retry upon errors in suites with stepdowns and kill primary
SERVER-89954 Move setClusterParameter failpoint inside FixedFCVRegion
SERVER-89970 Reduce flakiness of hedged_reads.js
SERVER-89992 Allow renaming a bucket collection without timeseries options in local catalog
SERVER-89994 Allow direct shard operations which acquire locks only on non-user collections
SERVER-90004 Fix perf of $jsonSchema Parsing
SERVER-90012 Fix dbcheck_skip_applying_batch_on_secondary_parameter for multiversion on backports
SERVER-90013 Avoid jsTestName in command_let_variables_expressions.js
SERVER-90054 Make scoped_db_connection_test not flaky
SERVER-90069 run_restore.js and run_restore_unsharded.js shouldn't enforce fast count
SERVER-90090 Update Amazon 2 distros to the latest
SERVER-90091 Robustify change stream split event tests against identical events
SERVER-90101 Add explain_skip.js to backports_required_for_multiversion.yml on v7.3
SERVER-90135 Ensure the Windows system CA stores are in a clean state at the start of ssl_linear tests
SERVER-90170 Do not use jsTestName() in explain_skip.js
SERVER-90173 Serialize ObjectId SBE type to key string correctly
SERVER-90184 Only load included SASL plugins on Windows
SERVER-90187 Cleanup multiversion binaries before running resmoke tests
SERVER-90248 Insert _id field into audit config cluster parameter
SERVER-90264 Remove slow step from compile
SERVER-90277 Resmoke tracing set up should catch KeyboardInterrupt and SystemExit
SERVER-90288 Bitwise query operators should interpret lowest addressable byte in BinData as least significant byte
SERVER-90332 Revert SERVER-78615
SERVER-90376 ReshardingRecipientService::_fetchBuildIndexMetrics() must not throw
SERVER-90388 Don't have command_let_variables_merge_only.js run on shard_merge_jscore_passthrough
SERVER-90394 Make the test update_node_clustertime_replset.js more resilient to $$NOW
SERVER-90417 Disable SBE for Time Series on 7.3
SERVER-90423 Mongod/s Initialization Enhancement: trigger signal handler thread pre fast clock source setup
SERVER-90438 Coverity analysis defect 155571: Using a moved object
SERVER-90443 Update testing for enterprise aggregate stage
SERVER-90461 Query on boolean incorrectly uses cached COUNT_SCAN
SERVER-90513 Check whether SSL_get0_verified_chain returns null before consuming it
SERVER-90543 Transaction participant should hold client lock when configuring opCtx
SERVER-90599 Remove unused link to liblzma (work ticket)
SERVER-90637 makeSnapshot test command must return a committed timestamp
SERVER-90681 Fix data race over the chunk jumbo flag
SERVER-90747 Handle $elemMatch with empty path in plan enumerator correctly
SERVER-90985 AddToSetNode::init() should uassert if argument to $each is invalid BSON
SERVER-90988 PrepareExecutionHelper destructor should use the cached value of CanonicalQuery::toStringShort that I specifically added just for that destructor to use
SERVER-90991 Bump timeout on compile_and_run_unittests_*_quarter
7.3.2 Changelog
Sharding
SERVER-84368 CreateIndex fails with StaleConfig if run from a stale mongos against a sharded non-empty collection
SERVER-86790 featureFlagCheckForDirectShardOperations is enabled by default under different FCV values across different branches
SERVER-89134 Test wrongly assumes multi writes outside of transactions are atomic
Query
SERVER-88949 Explain for classic multi planner displays incorrect skip amount
Storage
WiredTiger
WT-10807 Skip in-memory deleted pages as part of the tree walk
Internals
SERVER-72431 Make the commit of split chunks idempotent
SERVER-77073 Direct Shard operations shouldn't be allowed anymore (8.0 behavior)
SERVER-79049 Server returns unexpected CollectionUUIDMismatch with actual collection name equal to expected collection name
SERVER-80340 Handle and test dbCheck during initial sync
SERVER-81807 Cached SBE plans have let-bound constants baked in
SERVER-82349 Mongo 7 crashes on applyOps index delete/drops without a collection UUID
SERVER-82571 insert_with_data_size_aware_balancing.js may occasionally fail when run against slow machine/variants
SERVER-83370 PrepareUnique:true for time-series collections should error
SERVER-83956 Balancer wrongly emit warning message in multiversion clusters
SERVER-83984 WiredTiger verbosity level is suppressed
SERVER-84463 ReshardingCollectionCloner should use shardVersionRetry instead of withOneStaleConfigRetry
SERVER-84628 Startup warning in mongos for Read/Write Concern
SERVER-85306 Update sys-perf config to use HTTPs github links rather than SSH
SERVER-85368 Updates the genny module in sys-perf to point to mongo/genny instead of 10gen/genny
SERVER-85580 Undo any update on ScopedSetShardRole construction failure
SERVER-85583 Running an aggregate on a view may throw IllegalChangeToExpectedDatabaseVersion
SERVER-85681 Fix for negative value being passed to BasicBufBuilder::grow()
SERVER-85751 Remove $vectorSearch field validations
SERVER-85843 A write operation may fail with NamespaceNotFound if the database has been concurrently dropped (sharding-only)
SERVER-85892 $merge with pipeline after $documents returns error
SERVER-85969 Documentation Updates
SERVER-86033 Modernize batch_size.js
SERVER-86201 Cluster upserts performed through the ShardServerProcessInterface should use the operation context to configure their write concern
SERVER-86227 Disable exchange_producer.js from config_fuzzer
SERVER-86280 Reclassify some collection validation warnings/errors
SERVER-86327 Time-series single schema per bucket column is not maintained in some cases
SERVER-86365 Ticket stall detector should not be fatal in testing
SERVER-86375 Make index_build_memory_tracking.js less strict
SERVER-86380 Allow for multiple IdP configurations with the same issuer but unique issuer-audience pair
SERVER-86395 Investigate DuplicateKey error while recovering convertToCapped from stable checkpoint
SERVER-86407 validation does not produce complete results when it should
SERVER-86419 SBE and Classic behave differently for $bitsAnyClear on NumberDecimal infinity
SERVER-86433 Clear memory in the data_union stored on the endpoint before use
SERVER-86474 $_internalApplyOplogUpdate with $set: { foo: Timestamp(0, 0) } is not replicated correctly
SERVER-86478 Time-series bucket min/max does not track empty field names under certain circumstances
SERVER-86482 Hold authorization cache generation mutex for duration of invalidation
SERVER-86495 $vectorSearch should send non-altered/accepted match expressions to mongot in sharded environments
SERVER-86505 Write without shard key test should treat SnapshotUnavailable as transient error
SERVER-86583 Non-transactional snapshot read on unsharded collection may execute with mismatched sharding metadata
SERVER-86622 Resharding coordinator use possibly stale database info
SERVER-86640 Refactor out JWKS refresh from IdentityProvider into a IDPJWKSRefresher
SERVER-86642 Update IDP registration selection process
SERVER-86646 Fix decodeRecordIdStrAtEnd handling of unterminated size bytes
SERVER-86648 Resumable index build sorter files are not fsynced on shutdown
SERVER-86654 $regex $options doesn't re-parse correctly
SERVER-86672 CollMod coordinator use possibly stale database information
SERVER-86779 Fix case were azure generates 2 different html
SERVER-86796 Move direct connection checks into the collection acquisition (and autoGetCollection)
SERVER-86798 blacklist validate_db_metadata_command.js from tenant migrations suite
SERVER-86987 Ensure check_metadata_consistency.js use retriable writes when contacting config server
SERVER-87032 Query Stats appear not to be collected for whole-db and whole-cluster change streams
SERVER-87051 Relax checkHistoricalPlacementMetadataConsistency to tolerate the existence of resharding temp collections created through shardCollection
SERVER-87058 Chunk refresh from a secondary does not wait for majority writeConcern while flushing
SERVER-87158 Remove Bad Invariant from MultiUpdateCoordinator in 7.3
SERVER-87306 Prevent accessing OCSP manager ptr during shutdown
SERVER-87323 Future continuations must capture vector clock as shared pointer
SERVER-87343 Add awaitReplication() before stepping up secondary in range_deletions_has_index.js
SERVER-87348 Remove latch analyzer from multi client tests
SERVER-87379 Cache the value of CanonicalQuery::toStringShort in PrepareExecutionHelper
SERVER-87537 Make InternalSearchMongotRemoteSpec not strict
SERVER-87600 Delete older variants from system_perf.yml
SERVER-87610 Relax shardVersionRetry tripwires on the namespace of received stale exceptions
SERVER-87616 Create minimal trySbeEngine build variant on release configurations which have SBE
SERVER-87621 Make session_workflow_bm only iterate once under sanitizer builds
SERVER-87623 Make benchmark_repitions=1 for sanitizer builds
SERVER-87634 Add explain to agg key for query stats
SERVER-87905 BSONColumn validation integer overflow
SERVER-87930 Unittest CaptureLogs utility allows unsynchronized access to log statements
SERVER-87987 Timeseries optimization does not exclude the timeField though it's renamed by the $addFields and excluded by a project
SERVER-88013 Bump up time limits for wildcard, timeseries, and multiversion fuzzers on RHEL asan
SERVER-88017 Resolve lock-order-inversion TSAN error in TimestampKVEngineTest
SERVER-88063 Add RetryableWriteError label when write operation fails with StaleConfig and is direct to shard
SERVER-88097 Add the --release flag to the sys-perf compiles
SERVER-88111 random_DDL_CRUD_operations.js bulk insert should perform max internalInsertMaxBatchSize inserts
SERVER-88136 Fix arbiter_always_has_latest_fcv.js test to correctly test arbiter FCV behavior
SERVER-88149 Tag group_lookup_with_canonical_query_prefix.js with no_selinux
SERVER-88165 Only generate search meta pipeline when it will be used (followup)
SERVER-88173 BinData bit comparisons give wrong results in many cases
SERVER-88202 Fix possible integer overflow in BSON validation
SERVER-88262 Prevent timeouts in read_pref_with_hedging_mode.js
SERVER-88404 checkMetadataConsistency should refresh if it finds no cached info for database
SERVER-88419 NITL cancelCommand after shutdown
SERVER-88605 sys-perf configuration: update release version in commented out build variants
SERVER-88650 Deadlock in VectorClockMongoD during shutdown
SERVER-88651 Ensure resharding metrics object still exists when reporting currentOp info
SERVER-88706 Remove unused old compile logic from system_perf.yml
SERVER-88755 Make sure all sys-perf build variants specify a mongodb_setup_release
SERVER-88864 Make nodes_eventually_sync_from_closer_data_center.js more robust to transient slow heartbeat issues
SERVER-88942 Update db-contrib-tool version that includes fix for downloading old binaries
SERVER-88980 TenantMigrationDonorService might start waiting for forget migration without aborting migration upon recipient errors.
SERVER-89067 Invalidate all user requests matching a user name
SERVER-89068 Explicitly set exec_timeout and timeout_secs for the sys-perf project
SERVER-89156 Reduce resmoke jobs for replica_sets_auth on enterprise-suse12-64
SERVER-89163 Chunk Migration Destination Should Wait for Majority Before Engaging Critical Section
SERVER-89164 upgrade_to_use_multitenancy_support.js shouldn't send requests until the node is in SECONDARY state
SERVER-89178 Add the multiversion_incompatible tag to reshard_collection_resharding_improvements_recovery.js
SERVER-89235 internal_strip_invalid_assignment.js missing tag
SERVER-89250 Fix the "running under stepdown" checks performed by some JS tests
SERVER-89253 Make re-using compiled binaries in scons compile script more resilient
SERVER-89268 Missing 'let' variable incorrectly serialized as empty object
SERVER-89299 $setWindowFields aggregate commands generate unstable hashes
SERVER-89402 insert_with_data_size_aware_balancing.js is incompatible with test suites killing/terminating the CSRS primary
SERVER-89414 Harden shard removal in a store_historical_placement_data.js test teardown
SERVER-89467 ftdc_mirrored_reads.js should wait for metrics to converge before proceeding
SERVER-89474 Properly validate sortBy when parsing $setWindowFields
SERVER-89554 Fix evergreen/compiled_binaries_get.sh script
SERVER-89592 replication_consistency_markers_impl_bm should skip direct shard operation checks
SERVER-89611 Fix $group with empty object expression
SERVER-89641 Increase window for scoped_db_connection_test
SERVER-89653 Install db-contrib-tool with --no-cache-dir argument
SERVER-89690 query_stats_regex.js is missing diagnostic log messages
SERVER-89717 Fix jstests/core/command_let_variables_expressions.js so it can run in multiversion tests prior to 7,3
WT-9820 Waited xx seconds for checkpoint file creation in test_timestamp_abort
WT-12225 Fix RNG generator weakness around mongodb $sample stage
WT-12378 Not enough memory error on arm64-small
WT-12402 Add stats to track when eviction server skips walking a tree
WT-12431 table_verify_mirror fails with rows <= base_keyno
7.3.1 Changelog
Sharding
SERVER-87191 Update without shard key might miss documents
Write Operations
SERVER-88200 Time-series writes on manually-created buckets may misbehave
Internals
SERVER-86120 Return write error on failure to commit txn for retryable update that modifies doc shard key
SERVER-88360 Remove "Sharding catalog and local catalog collection uuid do not match" tripwire assertion