SERVER-62202 Log ID 5936504 should contain observer type as string
SERVER-62203 change the thread name "Health checks progress monitor" to "FaultManagerProgressMonitor"
SERVER-62204 do not schedule health check if observer is not enabled
SERVER-62226 Disable dbcheck_no_history_on_secondary.js on EFT
SERVER-62280 Premature transition to ok during initial checks in fault_state_machine_test.cpp
SERVER-62291 Find replacement for skipValidatingExitCode in the 4.4 backport of the health monitor
SERVER-62312 Enable feature flag in 4.4 backport and other housekeeping
SERVER-62371 Syntax error on rare code path in ldap_mongos_health_checking.js
SERVER-62373 LDAP health check integration test should assert stats
SERVER-62555 Ldap integration test should crash the server
4.4.11 Changelog
Sharding
SERVER-45149 replSetStepDown command in txn_two_phase_commit_failover.js should not timeout
SERVER-51329 Unexpected non-retryable error when shutting down a mongos server
SERVER-53335 Queries, updates, and deletes with non-"simple" collations may miss documents when using hashed sharding
SERVER-54623 Decrease number of jobs in causal consistency passthrough suites
SERVER-55382 Ignore error from retryable write being converted to transaction and that transaction failing in random_moveChunk_update_shard_key.js
SERVER-55392 Add a timestamp field to config.rangeDeletions
SERVER-55412 Mirrored reads should propagate the shard version field
SERVER-56226 [v4.4] Introduce 'permitMigrations' field on config.collections entry to prevent chunk migrations from committing
SERVER-56227 Add user-facing command to set allowMigrations to false for a sharded collection
SERVER-59890 Exclude migration_coordinator_shutdown_in_critical_section.js test from the config stepdown suite
SERVER-60552 Separate test for non-existing collection in metadata_manager_test
SERVER-60652 Backport the autoSplitVector logic to v4.4
SERVER-60682 TransactionCoordinator may block acquiring WiredTiger write ticket to persist its decision, prolonging transactions being in the prepared state
SERVER-60738 Update metadata manager tests for non-existing collections
SERVER-60804 Remove shard version checks from cursor_valid_after_shard_stepdown
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-61689 ActiveMigrationsRegistry::lock method doesn't properly handle its exceptions
SERVER-61816 cancel_coordinate_txn_commit_with_tickets_exhausted.js can hang forever due to race condition between transaction reaper and transaction coordinator
Replication
SERVER-54909 In replSetGetStatus, report last durable and last applied operation wall times for all members
SERVER-55376 Reconfig can roll back committed writes in PSA sets
SERVER-60946 Race condition in replsetprio1.js when initiating replset with nodes having different priorities
Query
SERVER-57588 Inconsistent query results when an array position is indexed whose value is an array
SERVER-60586 out_max_time_ms.js does not correctly enable "maxTimeNeverTimeOut" failpoint leading to spurious test failure
Aggregation
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-30846 Run dbCheck as background workload in FSM tests
SERVER-45953 Exempt oplog readers from acquiring read tickets
SERVER-48293 remove inactive index builds from config.system.indexBuilds
Operations
SERVER-28953 Capture df (disk full) statistics in FTDC
Internals
SERVER-34597 shardedcluster.py does not wait correctly on shards initialization
SERVER-46871 liblzma presence apparently not checked by configure
SERVER-48691 Fix Ninja builds on Windows Enterprise Server
SERVER-50568 Platform Support: Remove Ubuntu18.04 zSeries from 5.0
SERVER-53054 The ninja builder fails to link on Windows with LNK1561: entry point must be defined
SERVER-53952 Building with ninja + ASan poisons the build/install/ directory
SERVER-55460 Fix RPM packaging and testing for SLES 12
Internals
SERVER-37125 Powercycle should ignore a process reference if it no longer exists
SERVER-40820 Jstestfuzz suite to introduce spurious write conflicts
SERVER-47720 Clarify "RecordId(...) not found in the index for key" log message
SERVER-48890 allow $addFields with empty document and have it be a no-op
SERVER-49336 Set client metadata if it is missing during failCommand
SERVER-49930 Log collection name in createCollectionForApplyOps() invariant that collections are not renamed out of the way in steady state replication
SERVER-50549 Transform connection-related error codes in proxied commands
SERVER-50576 mongokerberos utility is missing in the MSI installer
SERVER-50662 Support large doubles and other double values in FTDC
SERVER-51172 resmoke sometimes throws TypeError when calculating elapsed time for test
SERVER-52657 index_commands_shard_targeting.js relies on too short MaxTimeMs
SERVER-56372 Add retryableFindAndModifyStorageLocation server parameter
SERVER-56373 [RRFaM] When writing FaM images to txn table, write oplog entries with needsRetryImage
SERVER-56374 [RRFaM] Have update path write to config.image_collection
SERVER-56375 [RRFaM] Have delete path write to config.transactions
SERVER-56376 [RRFaM] Add jstest that exercises both retryable FaM behaviors
SERVER-56377 [RRFaM] Add FSM test to perform retryable FaM while flipping server parameter
SERVER-56452 Self anchor in PooledLDAPConnection::setup's callback
SERVER-56468 Incorrect plan cache entry for {$ne: null} predicate, leads to missing query results
SERVER-56501 Add op counters for legacy op codes (OP_QUERY, OP_INSERT, etc.)
SERVER-56509 Wrap unique index insertion _keyExists call in a WT cursor reconfigure.
SERVER-56516 Fix undefined behaviour in parsing code for $slice projectional operator
SERVER-56563 [RRFaM] Forge noop image oplog entries for chunk migration
SERVER-56630 Unittest OpObserverImpl::onDelete/onUpdate paths for retryable findAndModify
SERVER-56713 [RRFaM] Avoid creating images while in initial sync
SERVER-56751 Check for todo comments as part of running patch build
SERVER-56772 Validator BSON is lost if write conflict occurs during collMod
SERVER-56819 $indexOfCP returns incorrect result when searching for empty string inside empty string with non-zero start index (classic execution engine only)
SERVER-56839 Index seeks concurrent with recently-committed prepared transactions can return wrong results
SERVER-56929 Improve error message for improper downgrades resulting in invalid collection options
SERVER-56952 [4.4] Add new build variant with storeFindAndModifyImagesInSideCollection=true
SERVER-56961 [v4.4] Ensure cluster is in FCV 4.4 while running FuzzerRestoreClusterSettings hook
SERVER-56976 'setIndexCommitQuorum' command has no effect while the index build is waiting for the commit quorum to be satisfied
SERVER-57015 [RRFaM] Writing to the image collection must be in an UnreplicatedWriteBlock
SERVER-53827 range_deleter_server_status.js should use assert.soon to check the number of range deletion tasks
SERVER-54014 Define a reasonable maxTimeMsOverride for the checkOID requests
SERVER-54585 Unable to run findAndModify against the Config server collections
SERVER-54701 shardCollection might successfully write to the config server but end up with missing indexes on the primary Shard
Replication
SERVER-48179 Removing rollback node will crash the node on transition out of rollback
SERVER-49294 waitInIsMaster_failpoint.js should ensure the shell is connected before enabling failpoint
SERVER-50412 Change “not master” error messages to “not primary”
SERVER-50414 Change “not master or secondary; cannot currently read from this replSet member” to “not primary or secondary; cannot currently read from this replSet member”
SERVER-53248 call awaitLastOpCommitted before committing transaction in retryable_prepared_commit_transaction_after_failover.js
SERVER-53666 curSecondary in rollback test fixture not guaranteed to be in SECONDARY state after restart
SERVER-54147 initial_sync_nodes_contribute_to_liveness_majorities.js should verify that the term increases instead of comparing to a specific number
SERVER-54180 ReplSetTest's stepUp function only waits 6 seconds for nodes to agree on primary
SERVER-54339 Prevent spontaneous elections in rollback_crud_op_sequences.js
SERVER-54528 Race between shutting down replica set and initial sync failing in initial_sync_fails_when_source_removed.js
SERVER-54540 Allow for network errors when restarting heartbeats to induce rollback in rollback test fixture
SERVER-54648 Add correct log verbosity to disallow_adding_initialized_node2.js
SERVER-54938 Only flush journal once per batch on secondary oplog application
Query
SERVER-48963 Make max_time_ms_sharded.js more robust
SERVER-54710 Large number of $or clauses can create profiling entry exceeding max BSON size, causing the query to fail when it should not
Aggregation
SERVER-54296 Invariant failure | aborting after invariant
Storage
SERVER-45847 Pull the JournalFlusher out of the storage engine layer and place it above the storage engine
SERVER-46826 Instantiate the JournalFlusher thread for ephemeral engines and when non-durable (nojournal=true)
SERVER-48149 Move callers of waitUntilDurable onto JournalFlusher::waitForJournalFlush
SERVER-49191 Cache the oplogTruncateAfterPoint in memory and only update it when it changes
SERVER-53875 Stop the JournalFlusher thread from running at all unless requested in unit tests so that it does not access infrastructure still being initialized
Operations
SERVER-50396 Align mongosymb_multithread to current SIGUSR2 stack dump format
SERVER-47509 resmoke accepts multiple "mongodSetParameters" options but only uses the last one
SERVER-48650 Unit tests' ServiceContext's NetworkInterfaceMockClockSource cannot continue to depend upon the lifetime of the ReplicationCoordinator to remain valid
SERVER-49695 Clarify and correct synchronization of isOplogTruncateAfterPointBeingUsedForPrimary
SERVER-50426 Add a delimiter indicating the end of a death test run
SERVER-47869 Add diagnostic logging to ClusterCursorManager
SERVER-50769 server restarted after expr:{"expr":"_currentApplyOps.getArrayLength() > 0","file":"src/mongo/db/pipeline/document_source_change_stream_transform.cpp","line":535}}
SERVER-53176 Return an error when commitQuorum includes voting buildIndexes:false members
SERVER-50475 mr_noscripting.js can fail spuriously on new mapReduce implementation
SERVER-51337 use-after-move in NetworkInterfaceMock
SERVER-52585 idl_tool.py not setting up buildscript/idl/* dependencies
SERVER-52787 Adjust ocsp_sharding_basic test response validity period
SERVER-52867 Make sure secondary has finished closing connections after being removed before sending new commands in awaitable_hello_on_nodes_with_invalid_configs.js
SERVER-52879 Periodic operation latency spikes every 5 minutes due to closing idle cached WT sessions
SERVER-52919 Wire compression not enabled for initial sync
SERVER-52983 Assertions in initial_sync_replSetGetStatus.js have to account for batch sizes smaller than collectionClonerBatchSize
SERVER-53234 jstests/core/profile2.js fails when background operations are run against test database
SERVER-53323 Run concurrency_simultaneous_replication on large distro on Enterprise Windows (inMemory) buildvariant
SERVER-53376 [4.4] dbHash can live lock an aborting index build
SERVER-53422 [v4.4] Move create_collection.js from noPassthroughWithMongod to noPassthrough
SERVER-53440 [v4.4] plan_cache_drop_database.js assertion too strict
SERVER-53445 [4.4] impose lock acquisition timeout for background validation
SERVER-53559 Stop the background workload in the backup/restore test before adding the node from the backed up data to the replica set
SERVER-53565 Update TPC-C version in sys-perf.yml and perf.yml modules
SERVER-53694 CleanEveryN timing information needs to accounts for hard-coded N
SERVER-53717 Dynamically split large concurrency tasks
SERVER-50291 Add query knob to enumerate $or children in a different order
SERVER-51120 Find queries with SORT_MERGE incorrectly sort the results when the collation is specified
SERVER-51853 Always initialize the numInserted out-parameter in AbstractIndexAccessMethod::insertKeys
Write Operations
SERVER-44586 add metrics to serverStatus to track type of update command
SERVER-49154 Add a regression test to ensure setting FCV to 4.2 disables collection/index creation
Aggregation
SERVER-30405 add expression to generate a random number
SERVER-40317 $facet execution has no limit on how much memory it can consume
SERVER-48390 group with $accumulator complains memory exceeds 100MBs on smaller than 96MBs collection
SERVER-48523 Unconditionally check the first entry in the oplog when attempting to resume a change stream
SERVER-49469 explain executionStats for $unionWith incorrectly shows COLLSCAN for inner pipeline
Catalog
SERVER-50030 Coverity analysis defect 115212: Wrong operator used
Storage
SERVER-43664 Speedup WiredTiger storage engine startup for many tables by optimizing WiredTigerUtil::setTableLogging()
SERVER-47681 Background validation uses the kNoOverlap read source instead of kAllDurableSnapshot to prevent us from having to take the PBWM lock on secondaries
SERVER-47803 Move the database level profile setting from Database into CollectionCatalog
SERVER-47812 Secondaries persist wildcard multikeypaths out of order
SERVER-47959 Retry JournalFlusher oplog reads on WriteConflictExceptions caused by concurrent {full:true} validate command on the oplog collection
SERVER-48021 Add WT debug table logging mode to *kill_(primary|secondary)* tests
SERVER-48154 ident dropper should periodically yield Global IS lock
SERVER-48245 index drop allowed on drop-pending collection
SERVER-49776 Forward port MDB <-> WT versioning table from 4.2 to 4.4 and master, please
SERVER-50045 JournalFlusher can interrupt write concern with ShutdownInProgress during rollback
SERVER-50586 Collection validation should append the collection's namespace to the output before any exceptions can be thrown
SERVER-51302 Override read timestamp check for refreshTransaction
Operations
SERVER-26726 Check number of arguments for createIndex() and throw error if more than two arguments
SERVER-46189 shell hang with message "Missing ssl modes with a single replica set is disallowed
SERVER-48244 Shell should not hard-code the allowed explain levels and let the server reject it instead
SERVER-49320 No error message produced if log file can't be created
SERVER-50270 shell should require a password for AWS auth
SERVER-50491 Frequent schema changes due to freeStorageSize limit FTDC retention
Build and Packaging
SERVER-23668 scons abbreviated options do not work properly
SERVER-43903 All compile tasks should upload the config log and the cache log
SERVER-47355 Hardcoded path of dist-test/bin must not be included in aws_e2e_ecs.js
SERVER-47943 Explicitly error if ICECC or CCACHE are specified but fail to load
SERVER-48282 Platform Support: Add Community & Enterprise RHEL 8 ARM
SERVER-50016 Fail on missing variable customization files
SERVER-50091 Enable SCons cache for ARM64 builders
SERVER-50125 UBSAN with ccache doesn't always respect -fsanitize-blacklist options
SERVER-48705 resmoke.py sending SIGABRT to take core dumps on fixture teardown may overwrite core files from hang analyzer
SERVER-48742 Log whenever profiler settings are changed via setProfilingLevel
SERVER-48884 Test Proctor Initializer has incorrect prereqs
SERVER-48946 Remove the Biggie evergreen variant in the v4.4 branch
SERVER-48949 missed logv2 cleanup in snapshot_window_util.cpp in 4.4
SERVER-49102 Accept a filter expression as an alternative to slowMS/sampleRate
SERVER-49165 endSessions command in Client.Disconnect causes an authorization failure for an unauthed connection on a host that requires authentication
SERVER-49396 Only activate skipWriteConflictRetries failpoint for user connections
SERVER-49402 Misleading error message when connecting to Data Lake
SERVER-49507 Reduce memory consumption in startup repair when rebuilding unique indexes with a large number of duplicate records
SERVER-49766 Indexed and non-indexed collections return different results for null query
SERVER-49857 ASAN Ubuntu 18.04 build variant did not symbolize its output
SERVER-49926 [4.4] collMod should not accept "recordPreImages: false" option in FCV 4.2
SERVER-49957 Read out of bounds in getPrevAndNextUUIDs
SERVER-50010 Mongodb build should have specific ninja REGENERATE rule
SERVER-50051 Make jstests/multiversion/hashed_index_bad_keys_cleanup.js more robust
SERVER-50072 Check _isWindows() when initializing MongoRunner.EXIT_ABORT
SERVER-50123 Record number of physical cores on all platforms
SERVER-50134 Run microbenchmarks tests through DSI
SERVER-50148 Fix use-after-move in MultiIndexBlock
SERVER-50242 slow query message seen in mongos for ismaster
SERVER-50246 $unionWith explain loses information from any stages in sub-pipeline which get absorbed into cursor stage
SERVER-50249 Upgrade via package manager from 4.2.8 to 4.4.0
SERVER-50326 Restrict sharding in agg_out.js workload to a single thread
SERVER-50365 Stuck with long-running transactions that can't be timed out
SERVER-50376 Ninja next does not see compiler changes
SERVER-50379 Reduce frequency of ! and * builders on 4.4
SERVER-50394 mongod audit log attributes DDL operations to the __system user in a sharded environment
WT-6822 Use the correct python for all tests and set up env for the split stress test
WT-6827 Run scons check examples in sequence not parallel
4.4.1 Changelog
Security
SERVER-47733 SymmetricEncryptorWindows shouldn't pad when update is called
SERVER-49339 Rename ocspValidationRefreshPeriodSecs to ocspStaplingRefreshPeriodSecs
SERVER-49383 Assert that Host header is present in OCSP responder
Sharding
SERVER-43938 Make auth_sharding_cmd_metadata.js start shards as replica sets
SERVER-46811 multi=true updates can modify the shard key of orphan documents and cause them to become owned
SERVER-47753 Enable random_moveChunk_index_operations.js in stepdown concurrency suites
SERVER-47900 Disable checkOrphansDeleted helper in 4.4 multiversion testing
SERVER-48066 Don't allow update shard key concurrency test to update shard key to same value
SERVER-48096 PeriodicShardedIndexConsistencyChecker thread on jstests can cause unintended shard refreshes
SERVER-48229 Shutdown PeriodicShardedIndexConsistencyChecker after ReplicationCoordinator so no thread will try to pause the job after it has stopped
SERVER-48341 Remove requires_fcv_46 from tests blacklisted under SERVER-48307 after backporting SERVER-48307 to 4.4.
SERVER-48365 Migration manager recovery should handle a refined shard key
SERVER-48531 3 way deadlock can happen between chunk splitter, prepared transactions and stepdown thread.
SERVER-48556 random_moveChunk_broadcast_delete_transaction.js should treat an stepdown error while waiting for a range deletion task to complete as an acceptable moveChunk error
SERVER-48601 ChunkSplitter should use the same chunk bounds for splitVector and splitChunk
SERVER-48641 Deadlock due to the MigrationDestinationManager waiting for write concern with the session checked-out
SERVER-48679 flushRoutingTableCacheUpdates should block on critical section with kWrite, not kRead
SERVER-48689 MigrationDestinationManager waits for thread to join with session checked out
SERVER-48699 MaxTimeMS may expire in range_deleter_interacts_correctly_with_refine_shard_key.js test before _configsvrMoveChunk command started
SERVER-48929 The moveChunk helper needs to ignore LockTimeout errors
SERVER-49044 Make AsyncRequestSender not retry remote command requests with startTransaction=true