►Nboost | Copyright (C) 2017 MongoDB Inc |
►Nmongo | Copyright (C) 2014 MongoDB Inc |
►Ndur | |
CAlready | Bitmap to remember things we have already marked for journaling |
CBufferGuard | Used inside the journal writer thread to ensure that used buffers are cleaned up properly |
CBufReaderUnitTest | |
CBufReaderY | |
CCommitJob | Tracks all write operations on the private view so they can be journaled |
CDropDbOp | Record drop of a database |
CDurableInterface | |
CDurOp | DurOp - Operations we journal that aren't just basic writes |
CFileCreatedOp | Indicates creation of a new file |
CJDbContext | Declares "the next entry(s) are for this database / file path prefix" |
CJEntry | Individual write operation within a group commit section |
CJHeader | Beginning header for a journal/j._<n> file there is nothing important int this header at this time |
►CJournal | Writeahead journal for durability |
CJFile | |
CJournalSectionIterator | Read through the memory mapped data of a journal file (journal/j._<n> file) throws |
►CJournalWriter | Manages the thread and queues used for writing the journal to disk and notify parties with are waiting on the write concern |
CBuffer | Stores the memory and the header for a complete journal buffer which is pending to be written by the journal writer thread |
CJSectFooter | Group commit section footer |
CJSectHeader | "Section" header |
CLSNFile | "last sequence number" |
CParsedJournalEntry | |
►CRecoveryJob | Call go() to execute a recovery from existing journal files |
CLast | |
►CStats | Journaling stats |
CS | |
CWriteIntent | Declaration of an intent to write to a region of a memory mapped view |
►CAlignedBuilder | Page-aligned BufBuilder |
CAllocationInfo | |
CArtificialTreeBuilder | Tool to construct custom tree shapes for tests |
CAutoAcquireFlushLockForMMAPV1Commit | This explains how the MMAP V1 durability system is implemented |
CAutoYieldFlushLockForMMAPV1Commit | At global synchronization points, such as drop database we are running under a global exclusive lock and without an active write unit of work, doing changes which require global commit |
CBalanceLeftEmpty | |
CBalanceOneLeftToRight | |
CBalanceOneRightToLeft | |
CBalanceRightEmpty | |
CBalanceSingleParentKey | |
CBalanceSingleParentKeyPackParent | |
CBalanceSplitParent | |
CBalanceThreeLeftToRight | |
CBalanceThreeRightToLeft | |
►CBSONCollectionCatalogEntry | This is a helper class for any storage engine that wants to store catalog information as BSON |
CIndexMetaData | |
CMetaData | |
CBsonRecord | |
CBtreeBucket | |
CBtreeBucketV0 | This structure represents header data for a btree bucket |
CBtreeBucketV1 | |
CBtreeLayoutV0 | |
CBtreeLayoutV1 | |
►CBtreeLogic | This is the logic for manipulating the Btree |
►CBuilder | |
CSetRightLeafLocChange | |
CFullKey | This is an in memory wrapper for the variable length data associated with a KeyHeaderType |
CBtreeLogicTestBase | This class is made friend of BtreeLogic so we can add whatever private method accesses we need to it, to be used by the tests |
CBtreeLogicTestHelper | This structure encapsulates a Btree and all the infrastructure needed by it (head manager, record store and a valid disk location to use by the tests) |
CBtreeLogicTestSuite | |
CCantMergeLeftNoMerge | |
CCantMergeRightNoMerge | |
CCappedCallback | When a capped collection is modified (delete/insert/etc) then certain notifications need to be made, which this (pure virtual) interface exposes |
CCappedInsertNotifier | Queries with the awaitData option use this notifier object to wait for more data to be inserted into the capped collection |
CCappedRecordStoreV1 | |
CCappedRecordStoreV1Iterator | This class iterates over a capped collection identified by 'ns' |
CCmpUnitTest | |
►CCollection | This is NOT safe through a yield right now |
CImpl | |
CTUHook | |
CCollectionCatalogEntry | |
CCollectionImpl | |
►CCollectionInfoCache | This is for storing things that you want to cache about a single collection life cycle is managed for you from inside Collection |
CImpl | |
CTUHook | |
CCollectionInfoCacheImpl | This is for storing things that you want to cache about a single collection life cycle is managed for you from inside Collection |
CCollectionMock | This class comprises a mock Collection for use by UUIDCatalog unit tests |
CCollectionOptions | |
CCommitNotifier | Establishes a synchronization point between threads |
CCompactDocWriter | |
CCompactOptions | |
CCompactStats | |
CCondVarLockGrantNotification | Notfication callback, which stores the last notification result and signals a condition variable, which can be waited on |
CCounterOps | Operations for manipulating the lock statistics abstracting whether they are atomic or not |
►CDatabase | Represents a logical database containing Collections |
CImpl | |
Citerator | Iterating over a Database yields Collection* pointers |
CTUHook | |
CDatabaseCatalogEntry | |
►CDatabaseHolder | Registry of opened databases |
CImpl | |
CTUHook | |
CDatabaseHolderImpl | Registry of opened databases |
CDatabaseHolderMock | Registry of opened databases |
►CDatabaseImpl | Represents a logical database containing Collections |
CAddCollectionChange | |
Citerator | Iterating over a Database yields Collection* pointers |
CRemoveCollectionChange | |
CDataFile | |
CDataFileHeader | |
CDataFileSync | Does background async flushes of mmapped files |
CDataFileVersion | |
CDataProtector | Performs an implementation specific transformation on a series of input buffers to produce a protected form of their concatenated contents |
►CDeadlockDetector | Iteratively builds the wait-for graph, starting from a given blocked Locker and stops either when all reachable nodes have been checked or if a cycle is detected |
CEdges | |
CUnprocessedNode | |
CDeferredWriter | Provides an interface for asynchronously adding to a collection |
CDelEmptyEmptyNeighbors | |
CDelEmptyNoNeighbors | |
CDeletedRecord | |
CDelInternal | |
CDelInternalPromoteKey | |
CDelInternalPromoteRightKey | |
CDelInternalReplacementNextNonNull | |
CDelInternalReplacementPrevNonNull | |
CDelInternalReplaceRight | |
CDelInternalReplaceWithUnused | |
CDelInternalSplitPromoteLeft | |
CDelInternalSplitPromoteRight | |
CDevNullKVEngine | The devnull storage engine is intended for unit and performance testing |
CDevNullRecordStore | |
CDevNullSortedDataBuilderInterface | |
CDevNullSortedDataInterface | |
CDisableDocumentValidation | Disables document validation on a single OperationContext while in scope |
CDisableDocumentValidationIfTrue | Disables document validation while in scope if the constructor is passed true |
CDiskLoc | Disk location/offset on disk in a database |
CDiskLoc56Bit | A variant of DiskLoc Used by the V1 bucket type |
CDocWriter | Allows inserting a Record "in-place" without creating a copy ahead of time |
CDontMergeSingleBucket | |
CDontReuseUnused | |
CDummyDocWriter | |
►CDummyExtentManager | |
CExtentInfo | |
CDummyRecordStoreV1MetaData | |
CDuplicateKeys | |
CDurableMappedFile | DurableMappedFile adds some layers atop memory mapped files - specifically our handling of private views & such |
►CDurRecoveryUnit | Just pass through to getDur() |
►CWrite | These are memory writes inside the mmapv1 mmap-ed files |
CcompareEnd | |
CEmptyRecordCursor | |
CEncryptionHooks | |
CEphemeralForTestEngine | |
►CEphemeralForTestRecordStore | A RecordStore that stores all data in-memory |
CCursor | |
CData | |
CEphemeralForTestRecord | |
CInsertChange | |
CRemoveChange | |
CReverseCursor | |
CTruncateChange | |
CEphemeralForTestRecoveryUnit | |
CEvenRebalanceCenter | |
CEvenRebalanceLeft | |
CEvenRebalanceLeftCusp | |
CEvenRebalanceRight | |
CEvenRebalanceRightCusp | |
CExportedMaxIndexBuildMemoryUsageParameter | |
CExtent | |
►CExtentManager | ExtentManager basics |
CCacheHint | |
CFactory | |
►CFastMapNoAlloc | NOTE: This structure should not be used for anything other than the Lock Manager |
CIteratorImpl | Forward-only iterator |
CPreallocEntry | Map entry through which we avoid releasing memory: we mark it as inUse or not |
CFileAllocator | |
CFileOp | |
CFixedWidthKey | This is the fixed width data component for storage of a key within a bucket |
CForceMergeLeft | |
CForceMergeRight | |
CForceSupportsDocLocking | |
CGlobalLockAcquisitionTracker | The GlobalLockAcquisitionTracker keeps track of if the global lock has ever been taken in X or IX mode |
CHarnessHelper | Sets up an OperationContext with a Recovery Unit |
CHeadManager | An abstraction for setting and getting data about the 'head' of an index |
CHeadManagerImpl | |
CHealthLog | The interface to the local healthlog |
►CHeapRecordStoreBtree | A RecordStore that stores all data on the heap |
CMmapV1RecordHeader | |
►CHeapRecordStoreBtreeRecoveryUnit | A RecoveryUnit for HeapRecordStoreBtree, this is for testing btree only |
CInsertEntry | |
CModEntry | |
►CIndexCatalog | How many: 1 per Collection |
CImpl | |
►CIndexIterator | |
CImpl | |
CTUHook | |
CTUHook | |
►CIndexCatalogEntry | |
CImpl | |
CTUHook | |
CIndexCatalogEntryContainer | |
►CIndexCatalogEntryImpl | |
CSetHeadChange | |
►CIndexCatalogImpl | How many: 1 per Collection |
CIndexBuildBlock | Disk creation order 1) system.indexes entry 2) collection's NamespaceDetails a) info + head b) _indexBuildsInProgress++ 3) indexes entry in .ns file 4) system.namespaces entry for index ns |
CIndexIteratorImpl | |
CIndexKillCriteria | |
CIndexConsistency | |
CIndexDetails | |
CIndexEntryComparison | Compares two different IndexKeyEntry instances |
CIndexInfo | The IndexConsistency class is used to keep track of the index consistency |
CIndexKeyEntry | Represents a single item in an index |
CIndexSeekPoint | Describes a query that can be compared against an IndexKeyEntry in a way that allows expressing exclusiveness on a prefix of the key |
CIndexUpdateTest | |
CJournalLatencyTestCmd | |
CJournalListener | This class allows for the storageEngine to alert the rest of the system about journaled write progress |
CJournalSectionCorruptException | Thrown when a journal section is corrupt |
CKeyBson | Key class for precomputing a small format index key that is denser than a traditional BSONObj |
►CKeyString | |
►CTypeBits | Encodes info needed to restore the original BSONTypes from a KeyString |
CReader | |
CKeyV1 | |
CKeyV1Owned | |
►CKVCatalog | |
CAddIdentChange | |
CEntry | |
►CFeatureTracker | Manages the contents of a document in the KVCatalog used to restrict downgrade compatibility |
CFeatureBits | |
CRemoveIdentChange | |
►CKVCollectionCatalogEntry | |
CAddIndexChange | |
CRemoveIndexChange | |
CKVDatabaseCatalogEntry | |
►CKVDatabaseCatalogEntryBase | |
CAddCollectionChange | |
CRemoveCollectionChange | |
CKVDatabaseCatalogEntryMock | |
CKVEngine | |
CKVHarnessHelper | Creates a harness for generic KVEngine testing of all KVEngine implementations |
CKVPrefix | A KVPrefix may be prepended to the keys of entries in an underlying KV store |
►CKVStorageEngine | |
CRemoveDBChange | |
CKVStorageEngineOptions | |
CKVStorageEngineTest | |
CLocAndSize | |
CLocateEmptyForward | |
CLocateEmptyReverse | |
►CLock | |
CCollectionLock | Collection lock with support for document-level locking |
CDBLock | Database lock with support for collection- and document-level locking |
CExclusiveLock | Obtains a ResourceMutex for exclusive use |
►CGlobalLock | Global lock |
CEnqueueOnly | |
CGlobalRead | Global shared lock |
CGlobalWrite | Global exclusive lock |
COplogIntentWriteLock | Like the CollectionLock, but optimized for the local oplog |
CParallelBatchWriterMode | Turn on "parallel batch writer mode" by locking the global ParallelBatchWriterMode resource in exclusive mode |
CResourceLock | General purpose RAII wrapper for a resource managed by the lock manager |
CResourceMutex | For use as general mutex or readers/writers lock, outside the general multi-granularity model |
CSharedLock | Obtains a ResourceMutex for shared/non-exclusive use |
CTempRelease | NOTE: DO NOT add any new usages of TempRelease |
►CLocker | Interface for acquiring locks |
CLockerInfo | Returns information and locking statistics for this instance of the locker |
CLockSnapshot | LockSnapshot captures the state of all resources that are locked, what modes they're locked in, and how many times they've been locked in that mode |
COneLock | Describes a single lock acquisition for reporting/serialization purposes |
CLockerForTests | |
CLockerImpl | Interface for acquiring locks |
CLockerNoop | Locker, which cannot be used to lock/unlock resources and just returns true for checks for whether a particular resource is locked |
CLockGrantNotification | Interface on which granted lock requests will be notified |
CLockHead | There is one of these objects for each resource that has a lock request |
►CLockManager | Entry point for the lock manager scheduling functionality |
CLockBucket | |
CPartition | |
CLockMongoFilesExclusive | |
CLockMongoFilesShared | |
CLockRequest | There is one of those entries per each request for a lock |
CLockRequestCombo | |
CLockRequestList | Simple intrusive list implementation for the lock's granted and conflicting lists |
CLockStatCounters | Bundle of locking statistics values |
►CLockStats | Templatized lock statistics management class, which can be specialized with atomic integers for the global stats and with regular integers for the per-locker stats |
CPerModeLockStatCounters | |
CLogFile | |
CMAdvise | |
CMemJournalServerStatusMetric | |
CMemoryMappedFile | |
CMergeBucketsDelInternal | |
CMergeBucketsDontReplaceHead | |
CMergeBucketsLeft | |
CMergeBucketsRight | |
CMergeBucketsRightNull | |
CMergeBucketsTestBase | |
CMergeLeftEmpty | |
CMergeMinLeftEmpty | |
CMergeMinRightEmpty | |
CMergeOption | |
CMergeRightEmpty | |
CMergeSizeJustRightLeft | |
CMergeSizeJustRightRight | |
CMergeSizeLeft | |
CMergeSizeLeftTooBig | |
CMergeSizeRight | |
CMergeSizeRightTooBig | |
CMergeSizeTestBase | |
CMissingLocate | |
CMissingLocateMultiBucket | |
►CMMAPV1DatabaseCatalogEntry | |
CEntry | |
CEntryInsertion | Registers the insertion of a new entry in the _collections cache with the RecoveryUnit, allowing for rollback |
CEntryRemoval | Registers the removal of an entry from the _collections cache with the RecoveryUnit, delaying actual deletion of the information until the change is commited |
CMMAPV1Engine | |
►CMmapV1ExtentManager | ExtentManager basics |
CFactory | |
CFilesArray | Simple wrapper around an array object to allow append-only modification of the array, as well as concurrent read-accesses |
CMMAPV1Options | |
CMmapV1RecordFetcher | |
►CMmapV1RecordHeader | |
CNP | |
CMobileDelayedOpQueue | This class manages a queue of operations delayed for some reason |
►CMobileIndex | |
CBulkBuilderBase | |
CBulkBuilderStandard | Bulk builds a non-unique index |
CBulkBuilderUnique | Bulk builds a unique index |
CMobileIndexStandard | |
CMobileIndexTestHarnessHelper | |
CMobileIndexUnique | |
CMobileKVEngine | |
►CMobileRecordStore | A RecordStore that stores all data in SQLite |
CCursor | |
CDataSizeChange | Keeps track of the total data size |
CNumRecsChange | Keeps track of the changes to the number of records |
CMobileRecoveryUnit | |
CMobileSession | This class manages a SQLite database connection object |
CMobileSessionPool | This class manages a pool of open sqlite3* objects |
►CMongoFile | |
CFlushable | Flushable has to fail nicely if the underlying object gets killed |
CMongoFileFinder | Look up a MMF by filename |
CMoveBelowLowWaterMarkLeft | |
CMoveBelowLowWaterMarkRight | |
►CMultiIndexBlock | Builds one or more indexes |
CImpl | |
CTUHook | |
►CMultiIndexBlockImpl | Builds one or more indexes |
CCleanupIndexesVectorOnRollback | On rollback in init(), cleans up _indexes so that ~MultiIndexBlock doesn't try to clean up _indexes manually (since the changes were already rolled back) |
CIndexToBuild | |
CSetNeedToCleanupOnRollback | On rollback sets MultiIndexBlockImpl::_needToCleanup to true |
CNamespace | This is used for storing a namespace on disk in a fixed witdh form and should only be used for that, not for passing internally |
►CNamespaceDetails | |
CExtra | |
CIndexIterator | |
CStats | |
CNamespaceDetailsCollectionCatalogEntry | |
CNamespaceDetailsRSV1MetaData | |
►CNamespaceHashTable | Simple, fixed size hash table used for namespace mapping (effectively the contents of the MMAP V1 .ns file) |
CNode | |
CNamespaceIndex | |
CNamespaceUUIDCache | |
CNoMergeBelowMarkLeft | |
CNoMergeBelowMarkRight | |
CNoMoveAtLowWaterMarkLeft | |
CNoMoveAtLowWaterMarkRight | |
CNoOpJournalListener | The NoOpJournalListener is a trivial implementation of a JournalListener, that does nothing |
COddRebalanceCenter | |
COddRebalanceLeft | |
COddRebalanceRight | |
CPackedDataSizeEmptyBucket | |
CPackEmptyBucket | |
CParentMergeNonRightToLeft | |
CParentMergeNonRightToRight | |
►CPartitioned | A templated class used to partition an associative container like a set or a map to increase scalability |
CAll | Used to protect access to all partitions of this partitioned associative structure |
CIteratorEndTag | |
COnePartition | Used to protect access to a single partition of a Partitioned |
CPartitionedLockHead | The PartitionedLockHead allows optimizing the case where requests overwhelmingly use the intent lock modes MODE_IS and MODE_IX, which are compatible with each other |
CPartitioner | The default partitioning policy: If using a numeric built-in type, will use the lower bits of a number to decide which partition to assign it to |
CPointerToDurableMappedFile | For durability support we want to be able to map pointers to specific DurableMappedFile objects |
CPosixFlushable | |
CPreferBalanceLeft | |
CPreferBalanceRight | |
CPrefixedWiredTigerRecordStore | |
CRebalancedSeparatorBase | |
CRebalanceEmptyLeft | |
CRebalanceEmptyRight | |
CRecord | The data items stored in a RecordStore |
►CRecordAccessTracker | Used to implement likelyInPhysicalMemory() for the MMAP v1 storage engine |
CEntry | |
CRolling | This contains many slices of times the idea you put mem status in the current time slice and then after a certain period of time, it rolls off so we check again |
CSlice | Simple hash map for region -> status this constitutes a single region of time it does chaining, but very short chains |
CRecordCursor | Retrieves Records from a RecordStore |
CRecordData | A replacement for the Record class |
CRecordFetcher | Used for yielding while data is fetched from disk |
CRecordStore | An abstraction used for storing documents in a collection or entries in an index |
CRecordStoreCompactAdaptor | |
CRecordStoreHarnessHelper | |
►CRecordStoreV1Base | |
CIntraExtentIterator | Iterates over all records within a single extent |
CRecordStoreV1MetaData | |
CRecordStoreV1RepairCursor | This iterator will go over the collection twice - once going forward (first extent -> last extent) and once backwards in an attempt to salvage potentially corrupted or unreachable records |
CRecordStoreValidateAdaptor | The record store validate adaptor is used to keep track of the index consistency during a validation that's running |
►CRecoveryUnit | A RecoveryUnit is responsible for ensuring that data is persisted |
CChange | A Change is an action that is registerChange()'d while a WriteUnitOfWork exists |
CRecoveryUnitHarnessHelper | |
CRecoveryUnitNoop | |
CRecursiveMerge | |
CRecursiveMergeDoubleRightBucket | |
CRecursiveMergeRightBucket | |
CRecursiveMergeThenBalance | |
CRelativePath | This is very much like a boost::path |
CRenameCollectionOptions | Renames the collection from "source" to "target" and drops the existing collection with UUID dropTargetUUID iff "dropTarget" is true |
CRepairFileDeleter | |
CResourceId | Uniquely identifies a lockable resource |
►CSavedCursorRegistry | Class that stores active cursors that have been saved (as part of yielding) to allow them to be invalidated if the thing they pointed at goes away |
CSavedCursor | The destructor ensures the cursor is unregistered when an exception is thrown |
CSeekableRecordCursor | Adds explicit seeking of records |
CSERVER983 | Validates that adding keys incrementally produces buckets, which are 90%/10% full |
CShouldNotConflictWithSecondaryBatchApplicationBlock | RAII-style class to opt out of replication's use of ParallelBatchWriterMode |
CSimpleCreate | |
CSimpleInsertDelete | |
CSimpleRecordStoreV1 | |
CSimpleRecordStoreV1Iterator | This class iterates over a non-capped collection identified by 'ns' |
CSnapshotId | |
CSnapshotManager | Manages snapshots that can be read from at a later time |
CSnapshotted | |
CSortedDataBuilderInterface | A version-hiding wrapper around the bulk builder for the Btree |
►CSortedDataInterface | This interface is a work in progress |
CCursor | Navigates over the sorted data |
CSortedDataInterfaceHarnessHelper | |
CSplitLeftHeavyBucket | |
CSplitRightHeavyBucket | |
CSplitUnevenBucketBase | |
CSqliteStatement | SqliteStatement is a wrapper around the sqlite3_stmt object |
CStandardWiredTigerRecordStore | |
CStatusWith | |
►CStorageEngine | Top level interface for creating a new storage engine |
CFactory | The interface for creating new instances of storage engines |
►CStorageEngineLockFile | |
CLockFileHandle | |
CStorageEngineMetadata | This reads and write the storage engine metadata file 'storage.bson' in the data directory (See –dbpath) |
CStorageGlobalParams | |
CTestHeadManager | Simple head manager, which performs no validity checking or persistence |
CTestStruct | |
CTrackingLockGrantNotification | |
CUninterruptibleLockGuard | This class prevents lock acquisitions from being interrupted when it is in scope |
CUpdateNotifier | |
CUUIDCatalog | |
CUUIDCatalogObserver | Class used for updating the UUID catalog on metadata operations |
CValidateAdaptor | This is so when a RecordStore is validating all records it can call back to someone to check if a record is valid |
CValidateAdaptorSpy | |
CValidateResults | |
CValidateTest | |
CWindowsFlushable | |
CWiredTigerBeginTxnBlock | When constructed, this object begins a WiredTiger transaction on the provided session |
CWiredTigerCachedCursor | |
CWiredTigerConfigParser | |
CWiredTigerConnection | |
CWiredTigerCursor | This is a smart pointer that wraps a WT_CURSOR and knows how to obtain and get from pool |
CWiredTigerCustomizationHooks | |
CWiredTigerEngineRuntimeConfigParameter | WT_CONNECTION::reconfigure get/setParameter support |
CWiredTigerExtensions | |
CWiredTigerFileVersion | |
CWiredTigerGlobalOptions | |
►CWiredTigerIndex | |
CBulkBuilder | Base class for WiredTigerIndex bulk builders |
CStandardBulkBuilder | Bulk builds a non-unique index |
CUniqueBulkBuilder | Bulk builds a unique index |
CWiredTigerIndexStandard | |
CWiredTigerIndexUnique | |
CWiredTigerItem | |
►CWiredTigerKVEngine | |
CWiredTigerCheckpointThread | |
CWiredTigerJournalFlusher | |
CWiredTigerOplogManager | |
►CWiredTigerRecordStore | |
CDataSizeChange | |
CNumRecordsChange | |
►COplogStones | |
CInsertChange | |
CStone | |
CTruncateChange | |
CParams | |
CRandomCursor | |
CWiredTigerRecordStoreCursorBase | |
CWiredTigerRecordStorePrefixedCursor | |
CWiredTigerRecordStoreStandardCursor | |
CWiredTigerRecoveryUnit | |
CWiredTigerServerStatusSection | Adds "wiredTiger" to the results of db.serverStatus() |
CWiredTigerSession | This is a structure that caches 1 cursor for each uri |
►CWiredTigerSessionCache | This cache implements a shared pool of WiredTiger sessions with the goal to amortize the cost of session creation and destruction over multiple uses |
CWiredTigerSessionDeleter | This deleter automatically releases WiredTigerSession objects when no longer needed |
►CWiredTigerSizeStorer | Serves as a write buffer to durably store size information for MongoDB collections |
CSizeInfo | SizeInfo is a thread-safe buffer for keeping track of the number of documents in a collection and their data size |
CWiredTigerSnapshotManager | |
►CWiredTigerUtil | |
CErrorAccumulator | |
CWiredTigerUtilHarnessHelper | |
CWiredTigerUtilMetadataTest | |
CWriteConflictException | This is thrown if during a write, two or more operations conflict with each other |
CWriteUnitOfWork | The WriteUnitOfWork is an RAII type that begins a storage engine write unit of work on both the Locker and the RecoveryUnit of the OperationContext |
Chash< mongo::ResourceId > | |
CKeyStringTest | |
CUUIDCatalogTest | A test fixture that creates a UUID Catalog and Collection* pointer to store in it |