6.0 Changelog
On this page
6.0.8 Changelog
Sharding
SERVER-61127 Multi-writes may exhaust the number of retry attempts in the presence of ongoing chunk migrations
SERVER-76546 _migrateClone can deadlock with prepared transactions on secondaries
SERVER-78414 Recipient shard in chunk migration can skip fetching changes to the migrated range, leading to lost writes
Query
SERVER-46446 Log time spent waiting for remote operations
Internals
SERVER-45255 Capture Pressure Stall Information in FTDC for Linux hosts
SERVER-62939 Starting up ESE with no KMIP server available leaves a backtrace
SERVER-66945 Re-enable ESE on MacOS
SERVER-67196 Ensure hb stats get updated before sync source selection in initial_sync_chooses_correct_sync_source.js
SERVER-71825 Implement and test document split algorithm
SERVER-74143 A slow query report should not require the rstl lock to return storage statistics
SERVER-76910 Make PyKMIP test harness return errors on version mismatch
SERVER-77005 Leave LDAP users logged-in during LDAP downtime
SERVER-77168 mongod crashes when restoring time series collection with auth enabled
SERVER-77266 createCollection command in rename_capped_collection_droptarget.js should ignore "cannot find ns" errors
SERVER-77298 Prevent fassert after killing opCtx as part of reconstructing prepared transactions after initial sync
SERVER-77386 Make '$_resumeAfter' parameter work with clustered collections
SERVER-77459 Verify /proc/pressure/cpu is readable in procparser_test
SERVER-77527 mongodbtoolchain/v3 stdlib unsafe against self-moves
SERVER-77710 Fix data race in AuditManager
SERVER-77769 SysPerf yml's compile-skip comment is incorrectly spaced
SERVER-77833 Mock meta cursors in sharded tests for batchSize/limit pushdown
SERVER-77998 Allow 'full' when reading from /proc/pressure/cpu
SERVER-78126 For specific kinds of input, mongo::Value() always hashes to the same result on big-endian platforms
SERVER-78136 Add "updateSearchIndex" Permission to the "readWrite" built-in-role
SERVER-78174 [v6.0] Blocklist large_events_failed_metric.js test in older versions where tracking of large change stream events is not backported
SERVER-78292 Issue with Object.entries in mongotmock assertEmpty
SERVER-78314 Create documentSourceWriterBatchBuffer server parameter
SERVER-78492 Resharding fuzzer tests are being generated but not run in Evergreen
6.0.7 Changelog
Sharding
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-76948 Allow shard key fields to contain DBRefs
SERVER-77309 An interleaving might cause a migration to continue when it shouldn't
SERVER-78050 Chunk Migration Can Lose Data If Processing Deferred Modifications
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-58276 Add time-series bounded collection scan plans to query multi-planner
SERVER-63865 Handle missing index idents during standalone startup recovery after unclean shutdown
SERVER-64706 Create Feature flag for PM-2802
SERVER-66130 The Balancer workers need to be joined instead of detached to stop their activity without leaking memory
SERVER-67472 ban config_fuzzer from using emptycapped command
SERVER-67699 Add tracking for when change stream event exceeds 16Mb
SERVER-68329 Avoid dropping pools for any error thrown during connection setup
SERVER-69850 Compact can cause test timeout in the config_fuzzer test suite
SERVER-69884 selinux tests must skip if they have any tag beginning with "featureFlag"
SERVER-70242 Intracluster X509 authentication can trigger "Different user name was supplied to saslSupportedMechs"
SERVER-70267 Streaming group when id is on time
SERVER-70268 Unpack to BSONObj instead of Document for suitable queries
SERVER-70269 Avoid applying match filter to the unpacked document when the whole bucket matches
SERVER-70937 Disable multiversion testing between lts versions and dead rapid release versions
SERVER-71270 Time series optimization pushes $match on timeField before $project stage that removes the field from pipeline
SERVER-71387 Range-based window [+N, unbounded] can tassert
SERVER-71835 Allow change events over 16MB as intermediate results
SERVER-71839 Add 'canAppearOnlyOnce' stage constraint and stage-specific position check
SERVER-71985 Automatically retry time series insert on DuplicateKey error
SERVER-72250 In-memory Cluster Server Parameter cache is not updated transactionally
SERVER-72297 Add burn_in_tasks related configuration
SERVER-72880 Fix SELinux Test Executor Failures
SERVER-72921 Improve UX of generated multiversion tasks
SERVER-72928 Expand burn-in-tags to all required & suggested variants
SERVER-73007 CURL_OPT_SEEKFUNCTION not set for multi-pass authentication
SERVER-73423 CLUSTERED_IXSCAN with sort generates two duplicate plans
SERVER-73435 Re-enable create_database.js FSM test in config fuzzer crash suite
SERVER-73471 Use correct compile variants for burn_in_tags variant creation
SERVER-73662 tlsClusterCAFile is not being used to validate client certificates on Windows
SERVER-73734 Support evergreen nightly project in burn_in_tests.py
SERVER-73959 Add option to TaskExecutorCursor to not pre-fetch documents
SERVER-74301 Optimize serialization behavior for $changeStreamSplitLargeEvent
SERVER-74344 Ban use of sparse indexes on internal comparison expression unless explicitly hinted
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-74454 Add testing for limit pushdown of $search pipelines within $lookup
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-74716 Prevent "back-in-time" change stream resume token on MongoS
SERVER-74806 Write size estimation logic does not account for runtime/let constants
SERVER-74863 Implement $listSearchIndexes aggregation stage
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-75392 Update rounding functions in S2 geometry library
SERVER-75479 Use system python on macos for ssl tests
SERVER-75626 Special handling for macosx venv
SERVER-75648 Add limit pushdown info to explain output
SERVER-75911 Make connection pool sizing between mongod and mongot configurable by server parameters
SERVER-75913 Address Upgrade concerns regarding KMIP Activate
SERVER-75932 Allow Configuration of mongod to authenticate search query requests to local mongot, but not search index management requests to the local Envoy
SERVER-75989 Add support for OpenSSL 3.0 FIPS
SERVER-76006 break compile_dist_test into small chunks in a new kind of task group
SERVER-76102 handleRIDRangeScan() sets hasCompatibleCollation wrong in recursive cases
SERVER-76179 "/var/run/mongodb/"mongod.pid" deleted on each Mongod shutdown
SERVER-76278 Log extra migration information
SERVER-76331 Bump mongo-task-generator version to 0.7.5
SERVER-76378 Use estimated impersonation metadata size in calculating block chunks
SERVER-76392 Collection validation hook should not error when trying to validate a view
SERVER-76404 Call the no-prefetch TaskExecutorCursor if there is an extractable limit
SERVER-76457 Support storing BuildID to debug symbols mapping for sanitizer builds
SERVER-76489 movePrimary set wrong collection version on new primary shard
SERVER-76565 Redact transaction API error logging
SERVER-76600 Increase timeouts for aggregation_timeseries_fuzzer on tsan/asan variants
SERVER-76619 Add setParameter to enable libcurl's verbose logging
SERVER-76621 Thread pool task executor can cause memory leak when handling exhaust command.
SERVER-76651 Switch to using db-contrib-tool symbolize command in resmoke
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-76713 [v6.0] Platform Support: Add support for RHEL 7 PPC in 6.0
SERVER-76721 Robustify plan_cache_stats_shard_and_host.js to count plan cache entries only for specific plan cache key
SERVER-76739 Archive data missing on evergreen task timeouts
SERVER-76783 Backport search index commands to v6.0
SERVER-76812 Update eslint for arm workstations
SERVER-76826 $merge doesn't work with document that has dollar fields
SERVER-76859 Update ssl_fips.js for macOS
SERVER-76875 Exclude fields containing dots from indexes
SERVER-76983 mongos shutdown procedure doesn't shutdown the CatalogCache
SERVER-76988 Abort the reshardCollection operation when the zone information is too large
SERVER-77011 Upgrade ZLib on 6.0 branch
SERVER-77018 Deadlock between dbStats and 2 index builds
SERVER-77028 tlsClusterCAFile is not being used to validate client certificates on macOS
SERVER-77033 Tag plan_cache_stats_shard_and_host.js with requires_fcv
SERVER-77063 Failing bucket compression causes errors returned incorrectly for time-series inserts
SERVER-77074 mongod termination process should always shutdown and join the CatalogCached's thread pool
SERVER-77085 MultipleCursorsGetMoreWorks TaskExecutorCursorTest Should Allow getMores on cursors to occur in either order
SERVER-77154 Change server's internal client implementations to always use "hello" rather than "isMaster" for the connection handshake
SERVER-77185 Bug with implementation of $lookup in SBE
SERVER-77195 executor::ConnectionPool should appropriately handle the case where a connection is returned with a network error
SERVER-77196 NoPrefetch test in TaskExecutorCursorTest can deadlock
SERVER-77226 Fix permissions-checking when pinning code segments
SERVER-77230 Retry search/planShardedSearch commands when there is a network error
SERVER-77273 Add gcc IPA pass cp ICE to oom_retry tool
SERVER-77301 rewriteGroupByMinMax in timeseries doesn't respect collation
SERVER-77335 Enable sys-perf tasks needed for 6.0 vs 7.0 perf dashboard
SERVER-77383 ".msi.sha256" files have incorrect shasum
SERVER-77518 Disable pin_code_segments.js on 6.0 rhel-80-debug-ubsan
SERVER-77522 Stop writing contents of report.json to stdout in Jepsen list-append test
SERVER-77534 Fix diff finder to handle deleted files correctly
SERVER-77687 add ld OOM message to auto retry
SERVER-77868 Balancer secondary thread should reset state on step up
SERVER-78080 Use fully random bytes for 8 low-order bytes of OID value for time series bucket _id
SERVER-78169 Disable timeseries_lastpoint_top.js on 6.0
WT-7401 Silent test/format failure in the long-test Evergreen task
WT-8825 Fix test_checkpoint_snapshot05 expected value validation failure
WT-9038 Correctly handle overflow blocks that are being discarded in VLCS salvage
WT-9117 test format exited with status 137 (Linux OOM killer)
WT-9457 Preserve ckpt_most_recent value across restart
WT-9545 wt8246_compact_rts_data_correctness test read incorrect data on macOS
WT-9721 Format stress tests generate cores even when successful
WT-10424 cursor::search_near slow performance if many deleted items are present
WT-10432 Fix expected warning output for test_hs20 on macos
WT-10449 Do not save update chain when there are no updates to be written to the history store
WT-10488 test_schema_abort failed with invalid argument
WT-10522 Fix a bug that leads to an unexpected aborted tombstone on update chain
WT-10528 test_wt8246_compact_rts_data_correctness retry to insert the data during WT_ROLLBACK
WT-10624 Fix regression on x86 for search and insert
WT-10671 Reset statistics when retrying test in test_checkpoint04.py
WT-10764 Add start and stop messages to rollback to stable
WT-10909 Simplify new test_backup29.py more
WT-10920 Minor cleanup to test_backup29.py
WT-10935 Change patch build Python unit tests to run on ubuntu2004-large
WT-11027 failed: wiredtiger.so: cannot open shared object file: No such file or directory [wiredtiger-mongo-v6.0]
WT-11031 Fix RTS to skip tables with no time window information in the checkpoint
WT-11036 Add test of incremental backup after files are closed by dhandle sweep
WT-11051 Fix newest start durable timestamp comparison in aggregate timestamp validation
WT-11140 Update Python path for Windows variants
6.0.6 Changelog
Security
SERVER-74808 Invariant failure - isVersionInitialized()
Sharding
SERVER-72146 Make chunk migrations metrics more accessible from Atlas
SERVER-72430 MigrationDestinationManager::report() may access null _migrationCloningProgress
SERVER-73229 Logical sessions cache refresh ignores write errors from updating session document, leading to cursors being killed early
SERVER-73441 Make sure shard key bounds are valid when committing moveRange
SERVER-73645 Unhandled exception on BalancerCommandsScheduler
SERVER-73751 movePrimary shouldn't create indexes for sharded collections
SERVER-73877 Wait for shard to have a primary before doing a migration in prepare_transaction_then_migrate.js
SERVER-74380 Router role retry loop should allow namespaces different from the one it was created for
SERVER-75481 Consider ideal data size when balancing
SERVER-76004 Remove incorrect sharding tassert in getOwnershipFilter function
SERVER-76178 Fix moveRange authorization requirements
Query
SERVER-48196 Upgrade the timelib to the latest to update the built-in timezone files to the latest
SERVER-72224 Clustered collections with non-"simple" default collation miss documents when querying on _id using "simple" collation
Write Operations
SERVER-75517 illegal format of _id possible via upsert
Aggregation
SERVER-74930 $avg is returning the sum instead of the average in aggregate $group
Internals
SERVER-51835 Mongos readPreferenceTags are not working as expected
SERVER-54150 Recovery from a stable checkpoint should fassert on oplog application failures
SERVER-57056 Syslog severity set incorrectly for INFO messages
SERVER-61100 Fix multiversion tests that assert last-lts/last-continuous incompatibility
SERVER-64000 Create a unlock/relock scope guard
SERVER-65700 list-append's Evergreen report generator masks failures if a single iteration succeeds
SERVER-66012 Use a WiredTiger version cursor to print metadata of extra index entries during validation
SERVER-66795 Improve throttling on migration batches issued by the Balancer
SERVER-66927 Remove reference to silentFail from mongo repo
SERVER-67105 $in queries do not use clustered index
SERVER-67183 Higher throughput Chunk Migration - reimplement for fetching and insertion
SERVER-67504 Make mongotmock aware that requests can come from different shards
SERVER-67780 Incorrect $group rewrite for timeseries collection when the accumulator uses meta field
SERVER-68328 Add ResumableChangeStreamError label to ReadConcernMajorityNotAvailableYet errors
SERVER-68388 Limit concurrency setting and update server parameter name
SERVER-68648 Enable feature flag
SERVER-68670 Cache imbalanced collections for balancing
SERVER-68841 Enable Black Duck on 6.0
SERVER-69783 use integral type for TTL index test case in ttl_index_options.js
SERVER-69952 Filtering on dates outside of the 32 bit epoch range returns wrong results
SERVER-70640 Add migrationConcurrency to serverStatus
SERVER-70912 All LDAP bind state must be attached to connection object
SERVER-71009 Make sure the select chunks operation doesn't take too long
SERVER-71053 Fix dataSize can be negative and incorrect on rollback
SERVER-71307 Aggregations with $search should fail if the resolved collation is non-simple
SERVER-71636 Explain executionStats does not work for $lookup on sharded collection
SERVER-71792 Log list of cursors a range deletion is going to wait on
SERVER-72107 Parsing strings in KeyString can throw Overflow error
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-72574 Ability to dump lock manager upon lock request timeout
SERVER-72619 Refactor and add more testing for migration_chunk_cloner_source changes
SERVER-72686 Add support for $collStats agg stage on timeseries collection
SERVER-72689 Create feature flag for sharded sort in search on version 6.0
SERVER-72690 Enable feature flag
SERVER-72774 A node in quiesce mode can win election
SERVER-73125 Builtin variable $$NOW is not available in document validation
SERVER-73169 Disallow project_with_collation.js from running in suites that terminate a node
SERVER-73204 Update mongos planning for $search pipelines to support a custom sort
SERVER-73222 Add searchFeatures to planShardedSearch command
SERVER-73264 Fix wrong invariant in MigrationChunkClonerSource::commitClone
SERVER-73383 Defragmentation may start over right after finishing
SERVER-73385 RenameCollectionCoordinator wrongly releases critical section for destination ns.
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-73608 Create skeleton for PinnedConnectionTaskExecutor
SERVER-73610 Introduce connection-leasing from ConnectionPool and NetworkInterface
SERVER-73611 Implement RPC functionality of PinnedConnectionTaskExecutor
SERVER-73613 Let TaskExecutorCursor use pinned transport connections
SERVER-73822 Time-series $group rewrite ignores certain accumulators
SERVER-73854 Add testing for custom sort in $search within $lookup and $unionWith sub-pipelines
SERVER-73869 Increase concurrency suite idle timeout on macos-*
SERVER-73943 Pin code pages in memory in memory constrained systems
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-74112 Make MongotTaskExecutor's NetworkInterface skip authentication
SERVER-74131 Multiplanning together with subplanning causes server crash in mapReduce queries
SERVER-74156 Package plist files with macosx releases
SERVER-74179 Use initiateWithHighElectionTimeout() in primary_casts_vote_on_stepdown.js to prevent unexpected elections
SERVER-74287 create scons OOM retry tool
SERVER-74303 Add a sizeStorer call to the onRollback handler for dataSize and numRecords changes
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-74422 Blacklist partial index JS test from multiversion suite on 6.0
SERVER-74449 Single phase index build (index creation with empty collections) does not abort migrations
SERVER-74469 Make the ShardingCatalogManager set the 'validAfter' field of a chunk when it is migrated
SERVER-74501 Fix MigrationBatchFetcher/Inserter completion reliance to not spawn an extra cleanup thread
SERVER-74554 Fix KMIP client interoperability with legacy KMIP Servers
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-74720 The default 'shardingStatistics' serverStatus section takes locks
SERVER-74845 Create mechanism to ignore ignore fork option with systemd
SERVER-74871 Clean up Jepsen tests
SERVER-74891 Change binary download urls to accommodate 4.0 binaries
SERVER-74895 Expect command errors in validation when querying $collStats, and improve the error message
SERVER-74943 Change assert statement in fle2_contention_update
SERVER-74987 v6.0 multiversion tests should also check 'featureFlagBucketUnpackWithSort50'
SERVER-74997 Reduce the timeout of tlsOCSPVerifyTimeoutSecs to 4 seconds
SERVER-75066 Check for parent directory before writing to SCons cache
SERVER-75082 Make balancer migrations throttling configurable
SERVER-75172 Use unique collection name in partial_index_logical.js
SERVER-75183 Add a server parameter that enables/disables TaskExecutorCursor connection-pinning
SERVER-75205 Deadlock between stepdown and restoring locks after yielding when all read tickets exhausted
SERVER-75243 Disable broken timeseries_lastpoint_top.js test
SERVER-75261 "listCollections" command fails with BSONObjectTooLarge error
SERVER-75299 Reduce severity of BalancerStatsRegistry logs
SERVER-75356 explain command for a find with $expr and let parameters fails if the collection is sharded
SERVER-75360 Include $search result count (total hits) in slow query log
SERVER-75361 Temporarily disable selinux tests in evergreen
SERVER-75369 Fix the overflow of total possible enumeration count in LockstepOr enumeration strategy
SERVER-75417 Complete construction of KillCursorsCommandReply
SERVER-75422 Increase timeout for replica_sets_jscore_passthrough on windows-enterprise-inmem
SERVER-75431 Get rid or fix best effort check for primary db on rename path in sharded clusters
SERVER-75443 PinnedConnectionTaskExecutor::join needs to wait for all networking to finish
SERVER-75444 Do not run multiversion that requires 4.0 on Enterprise Amazon Linux 2 arm64
SERVER-75467 [v6.0] Temporarily disable failing multiversion tests
SERVER-75468 [v6.0] Re-enable multiversion tests after 4.0 bug has been resolved
SERVER-75501 Don't run Sys-perf fCV variants on stable branches
SERVER-75519 Split task sharded_collections_jscore_passthrough due to timeout
SERVER-75521 Tag bucket_unpacking_with_sort tests on 6.0
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-75639 Remove dedicated executor for moveChunk/moveRange commands
SERVER-75652 Migrate from notary client to garasign for push task
SERVER-75725 Control TaskExecutorCursor's connection-pinning behavior with a server parameter
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-75811 Retry on network errors in fcbis_cannot_vote_twice_same_term
SERVER-75877 Fix unit tests ooming in v6.0
SERVER-75892 Exclude pin_code_segments_on_startup.js from linux platforms without ulimits configured
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-76077 Existing 'bucketSize' field in index spec from removed haystack index prevents server startup
SERVER-76098 Allow queries with $search and non-simple collations
SERVER-76139 sync_source_changes.js should wait for node to no longer be newly added before asserting on selected sync source
SERVER-76172 Fix BalancerChunkSelection unit test on slow build variants
SERVER-76241 Add search_pinned_connections_auth to relevant tasks in evergreen_nightly.yml on 6.0
SERVER-76273 SessionCatalogMigrationDestination is not interruptible on stepdown
SERVER-76274 Move microbenchmarks to their own task distro
SERVER-76321 Buffer overrun while deserializing compound group key spilled to disk in SBE hash agg implementation
SERVER-76446 [v6.0]Schedule the non-microbenchmark sys-perf tasks to run monthly on 6.0
SERVER-76498 Update push task to run on rhel8.7-small
SERVER-76502 Make isEnabled checks for featureFlagUserWriteBlocking safe
SERVER-76519 MIgrate crypt_push task to Garasign
SERVER-76549 Remove symbolization from macos variants
SERVER-76550 Balancer is unable to drain shards with big chunks
WT-8932 Investigate slow run of unit-test on PPC host
WT-9481 Fix compilation warnings with debug builds
WT-9661 Add retry on rollback for insert cursor API call
WT-10133 Consider retry on rollback for more cursor API calls
WT-10197 Track eviction timeline
WT-10253 Run session dhandle sweep and session cursor sweep more often
WT-10288 Print the stack traces of core dumps from Evergreen testing for 6.0
WT-10384 Mirror mismatch in test format
WT-10447 cppsuite-hs-cleanup-stress: no space left on device (6.0)
WT-10487 Failing many-collection-test task on large-scale-tests
WT-10551 Incremental backup may omit modified blocks
WT-10585 Record the location of the last key in key order check
WT-10900 Segmentation fault on unit-test-macos on macos-1100
WT-10932 Disable many-collection-test on release branches
6.0.5 Changelog
Sharding
SERVER-71219 Migration can miss writes from prepared transactions
SERVER-71368 Stop excluding tests that drop collection/database in sharded suites
SERVER-72430 MigrationDestinationManager::report() may access null _migrationCloningProgress
SERVER-73916 Improve ReshardingTest fixture error reporting when reshardCollection has already failed before any failpoints are waited on
SERVER-74124 Disallow sharding with wildcard shard key pattern
Query
SERVER-73534 Serialization of 'sbe::TypeTags::ArraySet' to 'KeyString' can segfault
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-53870 Improve view creation performance over time
SERVER-54284 ExceptionFor<ErrorCodes::WriteConflict> should resolve to WriteConflictException
SERVER-61909 Hang inserting or deleting document with large number of index entries
SERVER-65990 Test BUS w/ changing BucketMaxTimeSpan
SERVER-66050 findSelfInConfig should attempt fast path for every HostAndPort before trying slow path
SERVER-66355 Pass dbName to validateViewDefinitionBSON in DurableViewCatalog::onExternalInsert
SERVER-66374 Exclude fle2_retryable_writes from large transactions format builder
SERVER-66469 Filtering timeseries with date-field does not include results from before 1970
SERVER-66793 Disable bucket unpacking with sort for clustered collections with out of order buckets
SERVER-66836 Make restarting from failpoint atomic in FCBIS
SERVER-67111 Investigate fixes to testClusteredTailableCursorCappedPositionLostWithTTL
SERVER-67183 Higher throughput Chunk Migration - reimplement for fetching and insertion
SERVER-67416 Always sort fieldpath string sets using custom comparator
SERVER-67446 Ensure consistent wildcardProjection and columnstoreProjection specs in catalog
SERVER-67722 Shard cursor is not killed on MaxTimeMSExpired
SERVER-67950 Make stronger assertions in bucket_unpacking_with_sort_granularity_change.js
SERVER-68122 Investigate replicating the collection WiredTiger config string during initial sync
SERVER-68388 Limit concurrency setting and update server parameter name
SERVER-68434 Equality to null can incorrectly use a cached partial ixscan which does not cover the predicate
SERVER-68594 Add vscode format/lint on save
SERVER-68647 Create feature flag
SERVER-68648 Enable feature flag
SERVER-68739 Add WiredTiger session statistic without affecting slow op statistics
SERVER-68836 Properly handle NaN and 0 in for LDAPTimeoutMS
SERVER-69648 [SBE] Improve
visit(ExpressionConcatArrays*)
andvisit(ExpressionObject*)
SERVER-69902 Stop bucket_unpacking_with_sort_plan_cache.js from running in parallel with fsyncLock tests
SERVER-70167 Resumed create coordinator may incorrectly try to release the critical section
SERVER-70219 Use "linearizable" readConcern for spill_to_disk_secondary_read
SERVER-70321 Collmod coordinator must not resume migrations on retriable errors
SERVER-70360 Do not allow extremely large write concern wTimeout values
SERVER-70369 Create serverParameter for migrationConcurrency
SERVER-70395 Slot-Based Engine too aggressively uses disk for $group and is slow
SERVER-70427 Remove chef+kitchen package test infrastructure
SERVER-70566 Make assertion in backup_restore.js print error code
SERVER-70640 Add migrationConcurrency to serverStatus
SERVER-70747 Rename collection used in bucket_unpacking_with_sort_extended_range.js
SERVER-70830 Unit test WiredTigerOperationStats
SERVER-71049 crypt_shared emits log messages to stdout when loaded by libmongocrypt
SERVER-71053 Fix dataSize can be negative and incorrect on rollback
SERVER-71068 Partial indexes should not check fCV during startup
SERVER-71328 Ensure correct filtering metadata on donor shard after multiple failures
SERVER-71392 Track usage of JSON Schema for validation
SERVER-71608 Segmentation fault: in mongo::LockManager::lock
SERVER-71632 Re-enable dropDatabase FSM test in stepdown suites
SERVER-71680 $operationMetrics fails to account for "keysSorted" or "sorterSpills" when $group is pushed down to SBE
SERVER-71750 Revert refactor into handleWriteConflictException in writeConflictRetry loop
SERVER-71751 Skip transaction_too_large_for_cache.js for in-memory variants
SERVER-71771 Defragmenter should cap chunk size estimation
SERVER-71840 Change assert.eq statement in fle2_contention_update
SERVER-71924 Reduce verbosity of chunk merge change log event
SERVER-71950 Fail and log the operation when out-of-order keys are detected in WiredTiger
SERVER-71969 Update system_perf.yml for compile-variant and compile_variant.
SERVER-72046 Concurrent chunk migration testing
SERVER-72182 Consider adding Enterprise RHEL 8.0 (large transactions format) build variant to mongodb-mongo-v6.0 Evergreen project
SERVER-72185 TSBS perf test definition depends on a personal github repo
SERVER-72194 oplog_rollover.js should wait for the durable timestamp to advance
SERVER-72449 backup_restore.js should check for code 2 when killing child resmoke client
SERVER-72512 Indexes reported as valid when unable to return inconsistencies due to memory limit
SERVER-72535 Sharded clusters allow creating the 'admin', 'local', and 'config' databases with alternative casings
SERVER-72576 Notarize archive-dist binaries on macOS
SERVER-72619 Refactor and add more testing for migration_chunk_cloner_source changes
SERVER-72620 $indexStats doesn't include the "shard" field when run on unsharded collections
SERVER-72677 Full validation doesn't always report information about indexes
SERVER-72825 Remove all outdated entries from backports_required_for_multiversion_tests.yml
SERVER-72827 Filter out historic runtimes of non-passing tests
SERVER-72831 Fix use after move in sharding_util::processShardResponses
SERVER-72868 Complete TODO listed in SERVER-30949
SERVER-72877 Mongos retargeting logic in stepdown hooks should skip views
SERVER-73003 Use correct project when getting historical test runtime data
SERVER-73009 Decreasing order sort on clustered collections on replica sets returns increasing order
SERVER-73110 bucket_unpacking_with_sort_extended_range.js fails in sharded passthrough
SERVER-73157 Move out_max_time_ms tests to serial_run suite
SERVER-73164 increase maxTimeMS for index build in index_max_time_ms.js
SERVER-73176 Only print error message if there were in fact errors in getHostFQDNs
SERVER-73183 WiredTigerKVEngine::getSanitizedStorageOptionsForSecondaryReplication should skip inMemory
SERVER-73216 Upgrade BlackDuck to Detect v8
SERVER-73228 Remove active directory server from jstests/external_auth/ldap_mongos_health_checking.js
SERVER-73232 Change the default log-verbosity for _killOperations
SERVER-73235 Replace invariant with uassert in geometry_container
SERVER-73264 Fix wrong invariant in MigrationChunkClonerSource::commitClone
SERVER-73266 Deadlock among createIndexes, index build commit, and step down
SERVER-73368 Evergreen push task is failing to update v6.0-latest tarball in S3
SERVER-73389 Checkpoint vector clock in drop database coordinator
SERVER-73390 Mitigate database version regression bug on drop database
SERVER-73398 Invariant may be hit when downgrading from v6.0 due to moveChunk request without max key
SERVER-73481 Validate does not detect out-of-order keys with {full: false}
SERVER-73520 [6.0] Backport setProfilingFilterGlobally command
SERVER-73598 Extend FLEQueryInterface to test if a document exists by id
SERVER-73636 Coverity analysis defect 135025: Inefficient vector resizing with reserve.
SERVER-73697 Do not split out match expression on meta field when it's not renameable
SERVER-73706 Save WTRecordStoreUassertOutOfOrder fail point state to prevent concurrency bugs in testing
SERVER-73707 Evergreen timeout calculation fixes and cleanups
SERVER-73719 Comment out Legacy Build Variants in Sys-perf
SERVER-73745 Zero initialize IndexKeyBucket struct
SERVER-73852 Allow timeseries bounded-sort optimization on 5.0, on 6.0 binary
SERVER-73904 Update FreeBSD spidermonkey configuration
SERVER-73905 Implement getCurrentNativeThreadId for FreeBSD
SERVER-73938 Make sure chunk migration can handle a retryable internal transaction whose oplog entries have been truncated
SERVER-73998 Fix system_perf.yml and perf.yml microbench buildvariant definitions
SERVER-74097 Sharded find with expected collection UUID does not handle all cases of concurrent DDL operations
SERVER-74335 Spill to disk tests for $group must be tagged as "requires_persistence" on the v6.0 branch
WT-8848 Add API to roll back and indicate that a transaction has exceeded a configurable limit of pinned dirty data
WT-8981 Enable evergreen testing for RHEL8 on PPC
WT-9774 Avoid rolling back transactions in test_stat08 and re enable the test
WT-9879 Fix overcounting of session txn dirty bytes statistic
WT-10027 Session txn dirty statistic is incorrect
WT-10461 Fix key out of order in skip list on weakly ordered architecture
WT-10506 Introduce stable toolchain cmake files that point to the latest
WT-10584 Add missing read barriers in __cursor_skip_prev
6.0.4 Changelog
Sharding
SERVER-68361 LogTransactionOperationsForShardingHandler::commit misses transferring documents from prepared and non-prepared transactions changing a document's shard key value
SERVER-69874 Document or possibly mitigate scenario where shards end up with different prepareUnique and unique index settings
SERVER-70793 Make database metadata refresh first check new metadata under the IS lock before taking X lock
SERVER-71092 shard_id_test.cpp relies on a pure behavior of std::string::compare function
SERVER-71689 Refresh the CatalogCache before dropping the local collection
SERVER-72301 Use ordered:false when inserting chunks in optimized path of create collection
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
Internals
SERVER-60455 serverStatus metrics for external sorter
SERVER-60829 Tenant donor shouldn't use donorAbortMigration cancellation token when writing commit decision
SERVER-62300 Platform Support: Add support for Ubuntu 22.04 x86
SERVER-63104 Make it easy to run jsCore locally again in a world with tests tagged by feature flag
SERVER-65177 Elapsed initial sync time in TestRemainingInitialSyncEstimatedMillisMetric unit test can be 0 ms
SERVER-65259 Cursor leak in aggregation that requires merging on shard
SERVER-65385 Disable threshold checks for Google Microbenchmarks on DEBUG/Sanitizer variants
SERVER-66337 Ensure that check for the interrupt is done on every getNext() call in datasize_kill_op.js
SERVER-66466 Remove TransportLayerASIOTest dependence on ThreadContext
SERVER-66570 Timeseries pushes down metaField-projections that can change semantics
SERVER-66920 Crash in debug builds due to WiredTigerIndexCursorBase::seekWTCursor assertion not following search_near comparison semantics
SERVER-67290 Repair doesn't handle recordIds correctly for clustered collections
SERVER-67406 Sorting a cursor on sharded coll returns documents that are missing $-prefixed fields
SERVER-67795 Add serverstatus tracking to know how many users use updateMany and DeleteMany
SERVER-67898 BalancerCollectionStatus return wrong chunk size for session collection
SERVER-68125 Index build on multi-key fields can consume more memory than limit
SERVER-68338 sync_source_changes.js needs to wait for heartbeat
SERVER-68500 multiversion tag files are not correctly excluding tests in CI
SERVER-68576 We need to know how many sharded collections exist in a cluster
SERVER-68769 If a shard key index cannot be dropped then a user should not be able to hide that index
SERVER-68853 Remove invariant that a session stat needs to be a slow op stat
SERVER-68901 Incorrect $elemMatch query analysis in mongocryptd if document contains 2 different fields with the same name
SERVER-69160 Make ShardingTest wait for fCV initialization before running getClusterParameter tests
SERVER-69497 Have internal_sessions_reaping_basic.js oplog application use batches of size 1
SERVER-69603 Do not report drop events as part of shardCollection
SERVER-69890 Concurrent movePrimary and removeShard can move database to a no-longer existent shard
SERVER-69902 Stop bucket_unpacking_with_sort_plan_cache.js from running in parallel with fsyncLock tests
SERVER-69944 Resmoke's globstar.py does not properly parse
*
before**
SERVER-70024 ldap_provider_check.js needs to be updated for rhel9
SERVER-70100 Ensure that shardCollection emits an oplog event on commit time at least once in case of step-down
SERVER-70139 listCollection returns duplicate view names
SERVER-70158 Fix undefined argument order for $atan2 in SBE
SERVER-70237 Chunks merge commit must not create a BSON object too large
SERVER-70323 Convert invariant to tassert in collection_sharding_runtime
SERVER-70394 Fix self-swap in MultiPlanStage::removeRejectedPlans
SERVER-70553 Add module support to the mongo test runner
SERVER-70594 Add updated build variants to sys-perf
SERVER-70694 Platform Support: Add support for RHEL9 ARM64
SERVER-70720 Evergreen for WT should capture parent process id as part of top output
SERVER-70768 balancer use wrong chunk size for jumbo chunks
SERVER-70973 Balancer should stop iterating collections when there are no more available shards
SERVER-71006 Small window of inconsistency for reads after turning index to multikey
SERVER-71020 Ensure aborting time series batch eventually removes bucket from catalog
SERVER-71055 OplogOrder test can read stale all_durable timestamp after rolling back oplog entries
SERVER-71089 Run signing tasks on a single distro
SERVER-71094 Handle other transient election failures in fcbs_election_during_storage_change
SERVER-71139 Ensure indexes with simple collation are created correctly during initial sync
SERVER-71167 txn_index_catalog_changes.js session garbage collection can deadlock with fsync lock in consistency checks
SERVER-71191 Deadlock between index build setup, prepared transaction, and stepdown
SERVER-71225 Make sure collation.js does not change 'db'
SERVER-71247 DocumentSourceBackupFile should ensure backup cursor is open before returning data
SERVER-71249 Remove buildvariant task overrides for .publish tags
SERVER-71328 Ensure correct filtering metadata on donor shard after multiple failures
SERVER-71399 Jumbo chunk flag isn't automatically cleared after a chunk split
SERVER-71424 Fix failures in lint_fuzzer_sanity
SERVER-71435 Increse verbosity level for range-deleter in resmoke
SERVER-71436 Range deleter must not aggressively spam the log when shard key index not found
SERVER-71449 Fix log_successs_msg: not found in init.d on debian
SERVER-71467 Dont run feature flag specific tests for multiversion testing
SERVER-71471 Improve jstestfuzz deployment to work with new node run/install
SERVER-71473 Begin using the new test stats location
SERVER-71477 Check '_internalAllCollectionStatsSpec.getStats()' exists (boost::optional) before calling 'makeStatsForNs' in 'document_source_internal_all_collection_stats.cpp'
SERVER-71479 Merging chunks must not set validAfter to the current wall time
SERVER-71518 Use S3 test stats in mongo-task-generator
SERVER-71534 lint_fuzzer_sanity_all regression caused by running multiple instances of npm
SERVER-71568 Fix race condition related to ChangeStreamOptions access
SERVER-71597 Fix race condition on createDatabase for case sensitive dbName
SERVER-71609 splitOrMarkJumbo must not over-split chunks
SERVER-71614 Add a case to accept to hide an index if it is not compatible with shard key
SERVER-71632 Re-enable dropDatabase FSM test in stepdown suites
SERVER-71638 Don't let to hide the last shard key index using a key pattern
SERVER-71666 Reduce number of scanned index entries on chunk migration commit
SERVER-71668 Move isLastNonHiddenShardKeyIndex check after hide index on system collection and hide _id index in coll_mod.cpp
SERVER-71691 Error 5643004 when using $setWindowFields in a facet
SERVER-71726 Increase timeout of server_discovery_and_monitoring_json_test
SERVER-71756 Defragmentation policy should issue dataSize commands with estimate true
SERVER-71759 dataSize command doesn't yield
SERVER-71769 Add a new log message when a secondary node is skipping a two-phase index build
SERVER-71771 Defragmenter should cap chunk size estimation
SERVER-71787 Balancer needs to attach forceJumbo to moveRange command
SERVER-71788 Defragmentation should handle ChunkTooBig errors
SERVER-71880 _shardsvrDropCollectionParticipant with fromMigrate=true does not abort index builds
SERVER-71921 Task update_timeseries_fuzzer times out on some variants
SERVER-71924 Reduce verbosity of chunk merge change log event
SERVER-71939 Update BucketCatalogTest::Task class with failpoint
SERVER-71982 Add directConnection=True to standalone.py for multiversion testing
SERVER-72005 Enable TSBS on 2022-11 sys-perf variants
SERVER-72011 Add the ability to load js files to fsm worker threads.
SERVER-72021 Fix Enterprise SLES 12 crypt_create_lib Evergreen Failure
SERVER-72065 The logical sessions cache cannot be refreshed in secondary nodes of the CSRS
SERVER-72091 Enable auth-delay sys-perf variant
SERVER-72176 MetadataManagerTest must reset orphanCleanupDelaySecs to the default value on teardown
SERVER-72222 MapReduce with single reduce optimization fails when merging results in sharded cluster
SERVER-72276 Remove all outdated entries from backports_required_for_multiversion_tests.yml
SERVER-72288 microbenchmark tests fail after "Enable M1 Mac support for DSI"