libfoedus-core
FOEDUS Core Library
Class Hierarchy

Go to the graphical class hierarchy

This inheritance list is sorted roughly, but not completely, alphabetically:
[detail level 1234]
 Cfoedus::xct::AcquireAsyncRetReturn value of acquire_async_rw
 Cfoedus::snapshot::MergeSort::AdjustComparatorMasstreeUsed in batch_sort_adjust_sort if the storage is a masstree storage
 Cfoedus::memory::AlignedMemoryRepresents one memory block aligned to actual OS/hardware pages
 Cfoedus::memory::AlignedMemorySliceA slice of foedus::memory::AlignedMemory
 Cfoedus::storage::array::ArrayComposeContextArrayComposer's compose() implementation separated from the class itself
 Cfoedus::storage::array::ArrayComposerComposer for an array storage
 Cfoedus::storage::array::ArrayPageRepresents one data page in Array Storage
 Cfoedus::storage::array::ArrayPartitionerPartitioner for an array storage
 Cfoedus::storage::array::ArrayPartitionerData
 Cfoedus::storage::array::ArrayRangeRepresents an offset range in an array storage
 Cfoedus::storage::array::ArrayRootInfoPageOutput of one compose() call, which are then combined in construct_root()
 Cfoedus::storage::array::ArrayStorageControlBlockShared data of this storage type
 Cfoedus::storage::array::ArrayStoragePimplPimpl object of ArrayStorage
 Cfoedus::Attachable< CONTROL_BLOCK >Attachable Resources on Shared Memory
 Cfoedus::Attachable< ArrayStorageControlBlock >
 Cfoedus::Attachable< HashStorageControlBlock >
 Cfoedus::Attachable< LoggerControlBlock >
 Cfoedus::Attachable< LogGleanerControlBlock >
 Cfoedus::Attachable< MasstreeStorageControlBlock >
 Cfoedus::Attachable< MetaLogControlBlock >
 Cfoedus::Attachable< PartitionerMetadata >
 Cfoedus::Attachable< SequentialStorageControlBlock >
 Cfoedus::memory::AutoVolatilePageReleaseScopeAutomatically invokes a page offset acquired for volatile page
 Cfoedus::assorted::BacktraceContext
 Cfoedus::log::BaseLogTypeBase class for log type
 Cbitmask
 Cfoedus::snapshot::BlockHeaderBaseAll log blocks in mapper/reducers start with this header
 Cfoedus::storage::hash::BloomFilterFingerprintA fingerprint for bloom filter in each HashDataPage
 Cfoedus::cache::CacheBucketHash bucket in cache table
 Cfoedus::cache::CacheHashtableA NUMA-local hashtable of cached snapshot pages
 Cfoedus::cache::CacheOverflowEntryAn entry in the overflow linked list for snapshot cache
 Cfoedus::cache::CacheRefCountA loosely maintained reference count for CLOCK algorithm
 Cfoedus::soc::ChildEngineStatusCurrent status of a child SOC engine
 Cfoedus::snapshot::ReducerBufferStatus::Components
 Cfoedus::xct::McsRwSimpleBlock::Self::Components
 Cfoedus::xct::McsRwExtendedBlock::Field::Components
 Cfoedus::storage::Composer::ComposeArgumentsArguments for compose()
 Cfoedus::storage::hash::ComposedBinRepresents an output of composer on one bin
 Cfoedus::storage::hash::ComposedBinsBufferAbstracts how we batch-read several HashComposedBinsPage emit from individual composers
 Cfoedus::storage::hash::ComposedBinsMergedStreamPackages all ComposedBinsBuffer to easily extract bins of current interest
 Cfoedus::storage::ComposerRepresents a logic to compose a new version of data pages for one storage
 Cfoedus::thread::ConditionVariableAn analogue of pthread's condition variable and std::condition_variable to avoid glibc's bug in pthread_cond_broadcast/signal (thus in notify_all/one in turn)
 Cfoedus::assorted::ConstDivThe pre-calculated p-m pair for optimized integer division by constant
 Cfoedus::storage::Composer::ConstructRootArgumentsArguments for construct_root()
 Cfoedus::xct::CurrentLockListSorted list of all locks, either read-lock or write-lock, taken in the current run
 Cfoedus::xct::CurrentLockListIteratorForWriteSetAn iterator over CurrentLockList to find entries along with sorted write-set
 Cfoedus::storage::array::ArrayPage::DataData union for either leaf (dynamic size) or interior (fixed size)
 Cfoedus::storage::hash::DataPageBloomFilterTo quickly check whether a HashDataPage might contain a specific hash value, we maintain a non-counting bloom filter in each page
 Cfoedus::storage::Partitioner::DesignPartitionArgumentsArguments for design_partition()
 Cfoedus::fs::DirectIoFileRepresents an I/O stream on one file without filesystem caching
 Cfoedus::memory::DivvyupPageGrabBatchA helper class to grab a bunch of pages from multiple nodes in arbitrary fashion
 Cfoedus::storage::Composer::DropResultRetrun value of drop_volatiles()
 Cfoedus::storage::Composer::DropVolatilesArgumentsArguments for drop_volatiles()
 Cfoedus::storage::DualPagePointerRepresents a pointer to another page (usually a child page)
 Cfoedus::assorted::DumbSpinlockA simple spinlock using a boolean field
 Cfoedus::EpochRepresents a time epoch
 Cfoedus::log::EpochHistoryRepresents an event where a logger switched its epoch
 Cfoedus::ErrorStackBrings error stacktrace information as return value of functions
 Cfoedus::ErrorStackBatchBatches zero or more ErrorStack objects to represent in one ErrorStack
 Cfoedus::cache::CacheHashtable::EvictArgsParameters for evict()
 Cfoedus::externalize::ExternalizableRepresents an object that can be written to and read from files/bytes in XML format
 Cfoedus::storage::masstree::MasstreeComposeContext::FenceAndPointer
 Cfoedus::xct::McsRwExtendedBlock::Field
 Cfoedus::fs::FileStatusAnalogue of boost::filesystem::file_status
 Cfoedus::storage::masstree::MasstreeBorderPage::FindKeyForReserveResultReturn value for find_key_for_reserve()
 Cfoedus::FixedErrorStackRepresentation of ErrorStack that can be copied to other processes and even serialized to files
 Cfoedus::savepoint::FixedSavepointSavepoint that can be stored in shared memory
 Cfoedus::assorted::FixedString< MAXLEN, CHAR >An embedded string object of fixed max-length, which uses no external memory
 Cfoedus::assorted::FixedString< 124 >
 Cfoedus::assorted::FixedString< 252 >
 Cfoedus::assorted::FixedString< 508 >
 Cfoedus::assorted::FixedString< 60 >
 Cfoedus::assorted::BacktraceContext::GlibcBacktraceInfo
 Cfoedus::soc::GlobalMemoryAnchorsJust a set of pointers within global_memory_ for ease of use
 Cfoedus::memory::GlobalVolatilePageResolverResolves an offset in a volatile page pool to an actual pointer and vice versa
 Cfoedus::thread::GrabFreeVolatilePagesScopeObtains multiple free volatile pages at once and releases them automatically when this object gets out of scope
 Cfoedus::snapshot::MergeSort::GroupifyResultRepresents a group of consecutive logs in the current batch
 Cfoedus::storage::hash::HashBinRangeRepresents a range of hash bins in a hash storage, such as what an intermediate page is responsible for
 Cfoedus::storage::hash::HashComboA set of information that are used in many places, extracted from the given key
 Cfoedus::storage::hash::HashComposeContextHashComposer's compose() implementation separated from the class itself
 Cfoedus::storage::hash::HashComposedBinsPageA page to pack many ComposedBin as an output of composer
 Cfoedus::storage::hash::HashComposerComposer for a hash storage
 Cfoedus::storage::hash::HashDataPageRepresents an individual data page in Hashtable Storage
 Cfoedus::cache::HashFuncA simple hash function logic used in snasphot cache
 Cfoedus::storage::hash::HashIntermediatePageRepresents an intermediate page in Hashtable Storage
 Cfoedus::storage::hash::HashPartitionerPartitioner for a hash storage
 Cfoedus::storage::hash::HashPartitionerData
 Cfoedus::storage::hash::HashStorageControlBlockShared data of this storage type
 Cfoedus::storage::hash::HashTmpBinAn in-memory single-threaded data structure to compose tuples in a hash bin
 Cfoedus::storage::sequential::HeadPagePointerEach pointer to a snapshot head page comes with a bit more information to help reading
 Cfoedus::assorted::HexConvenient way of writing hex integers to stream
 Cfoedus::assorted::HexStringEquivalent to std::hex in case the stream doesn't support it
 Cfoedus::storage::masstree::HighFenceUsed only for debugging as this is not space efficient
 Cfoedus::thread::ImpersonateSessionA user session running on an impersonated thread
 Cfoedus::xct::InCommitEpochGuardAutomatically sets in-commit-epoch with appropriate fence during pre-commit protocol
 Cfoedus::InitializableThe pure-virtual interface to initialize/uninitialize non-trivial resources
 Cfoedus::snapshot::MergeSort::InputStatusCurrent status of each input
 Cfoedus::storage::hash::IntermediateRouteCompactly represents the route of intermediate pages to reach the given hash bin
 Cfoedus::xct::LockEntry::LessThanFor std::binary_search() etc without creating the object
 Cfoedus::xct::SysxctLockEntry::LessThanFor std::binary_search() etc without creating the object
 Cfoedus::assorted::BacktraceContext::LibBacktraceInfo
 Cfoedus::memory::LocalPageResolverResolves an offset in local (same NUMA node) page pool to a pointer and vice versa
 Cfoedus::xct::LockableXctIdTransaction ID, a 128-bit data to manage record versions and provide locking mechanism
 Cfoedus::xct::LockEntryAn entry in CLL and RLL, representing a lock that is taken or will be taken
 Cfoedus::xct::LockFreeReadXctAccessRepresents a record of special read-access during a transaction without any need for locking
 Cfoedus::xct::LockFreeWriteXctAccessRepresents a record of special write-access during a transaction without any need for locking
 Cfoedus::snapshot::LogBufferPackages handling of 4-bytes representation of position in log buffers
 Cfoedus::log::LoggerControlBlockShared data of Logger
 Cfoedus::savepoint::LoggerSavepointInfoInformation in savepoint for one logger
 Cfoedus::snapshot::LogGleanerControlBlockShared data for LogGleaner
 Cfoedus::snapshot::LogGleanerResourceLocal resource for the log gleaner, which runs only in the master node
 Cfoedus::log::LogHeaderA common header part for all log types
 Cfoedus::log::LogManagerControlBlockShared data in LogManagerPimpl
 Cfoedus::log::LogRangeContiguous range of log entries that might span multiple files
 Cfoedus::snapshot::LogReducerControlBlockShared data for LogReducer
 Cfoedus::snapshot::LogReducerRefA remote view of LogReducer from all engines
 Cfoedus::storage::array::LookupRouteCompactly represents the route to reach the given offset
 Cfoedus::storage::array::LookupRouteFinderPackages logic and required properties to calculate LookupRoute in array storage from offset
 Cfoedus::storage::masstree::MasstreeComposeContextMasstreeComposer's compose() implementation separated from the class itself
 Cfoedus::storage::masstree::MasstreeComposerComposer for an masstree storage
 Cfoedus::storage::masstree::MasstreeCursorRepresents a cursor object for Masstree storage
 Cfoedus::storage::masstree::MasstreeIntermediatePointerIteratorHandy iterator for MasstreeIntermediate
 Cfoedus::storage::masstree::MasstreePageCommon base of MasstreeIntermediatePage and MasstreeBorderPage
 Cfoedus::storage::masstree::MasstreePartitionerPartitioner for a masstree storage
 Cfoedus::storage::masstree::MasstreePartitionerDataDynamic information of one partitioner
 Cfoedus::storage::masstree::MasstreeStorageControlBlockShared data of this storage type
 Cfoedus::soc::MasterEngineStatusCurrent status of master engine
 Cfoedus::xct::McsAdaptorConcept< RW_BLOCK >Defines an adapter template interface for our MCS lock classes
 Cfoedus::xct::McsImpl< ADAPTOR, RW_BLOCK >Implements an MCS-locking Algorithm
 Cfoedus::xct::McsImpl< ADAPTOR, McsRwExtendedBlock >The Extended MCS-RW lock
 Cfoedus::xct::McsImpl< ADAPTOR, McsRwSimpleBlock >The Simple MCS-RW lock
 Cfoedus::xct::McsMockAdaptor< RW_BLOCK >Implements McsAdaptorConcept
 Cfoedus::xct::McsMockContext< RW_BLOCK >Analogous to the entire engine
 Cfoedus::xct::McsMockDataPageA dummy page layout to store RwLockableXctId
 Cfoedus::xct::McsMockNode< RW_BLOCK >Analogous to one thread-group/socket/node
 Cfoedus::xct::McsMockThread< RW_BLOCK >A dummy implementation that provides McsAdaptorConcept for testing
 Cfoedus::xct::McsOwnerlessLockScope
 Cfoedus::xct::McsRwAsyncMapping
 Cfoedus::xct::McsRwExtendedBlockPre-allocated MCS block for extended version of RW-locks
 Cfoedus::xct::McsRwLockAn MCS reader-writer lock data structure
 Cfoedus::xct::McsRwSimpleBlockReader-writer (RW) MCS lock classes
 Cfoedus::xct::McsWwBlockPre-allocated MCS block for WW-locks
 Cfoedus::xct::McsWwBlockDataExclusive-only (WW) MCS lock classes
 Cfoedus::xct::McsWwImpl< ADAPTOR >A specialized/simplified implementation of an MCS-locking Algorithm for exclusive-only (WW) locks
 Cfoedus::xct::McsWwLockAn exclusive-only (WW) MCS lock data structure
 Cfoedus::xct::McsWwOwnerlessImplA ownerless (contextless) interface for McsWwImpl
 Cfoedus::storage::MetadataMetadata of one storage
 Cfoedus::log::MetaLogControlBlockControl block for MetaLogBuffer and MetaLogger
 Cfoedus::storage::masstree::MasstreeIntermediatePage::MiniPage
 Cfoedus::EnginePimpl::ModulePtrPair of module pointer and its type
 Cnodemask_t
 Cfoedus::soc::NodeMemoryAnchorsSame as GlobalMemoryAnchors except this is for node_memories_
 Cfoedus::memory::NumaNodeMemoryRefA view of NumaNodeMemory for other SOCs and master engine
 Cfoedus::thread::NumaThreadScopePin the current thread to the given NUMA node in this object's scope
 Cfoedus::memory::PagePoolOffsetAndEpochChunk::OffsetAndEpoch
 Cfoedus::log::ThreadLogBuffer::OffsetRange
 Cfoedus::storage::masstree::OwnerSamplesNumber of vol pages in each node sampled per pointer in the root page
 Cfoedus::storage::PageJust a marker to denote that the memory region represents a data page
 Cfoedus::storage::masstree::MasstreeComposeContext::PageBoundaryInfoRepresents a minimal information to install a new snapshot page pointer
 Cfoedus::storage::masstree::MasstreeComposeContext::PageBoundarySortPoints to PageBoundaryInfo with a sorting information
 Cfoedus::xct::PageComparator
 Cfoedus::storage::PageHeaderJust a marker to denote that a memory region represents a data page
 Cfoedus::memory::PagePoolControlBlockShared data in PagePoolPimpl
 Cfoedus::memory::PagePoolOffsetAndEpochChunkUsed to store an epoch value with each entry in PagePoolOffsetChunk
 Cfoedus::memory::PagePoolOffsetChunkTo reduce the overhead of grabbing/releasing pages from pool, we pack this many pointers for each grab/release
 Cfoedus::memory::PagePoolOffsetDynamicChunkUsed to point to an already existing array
 Cfoedus::memory::PageReleaseBatchA helper class to return a bunch of pages to individual nodes
 Cfoedus::storage::PageVersionJust a synonym of XctId to be used as a page lock mechanism
 Cfoedus::xct::PageVersionAccessRepresents a record of reading a page during a transaction
 Cfoedus::storage::PageVersionStatus
 Cfoedus::debugging::DebuggingSupports::PapiCounters
 Cfoedus::storage::Partitioner::PartitionBatchArgumentsArguments for partition_batch()
 Cfoedus::storage::PartitionerMetadataTiny metadata of partitioner for every storage used while log gleaning
 Cfoedus::fs::PathAnalogue of boost::filesystem::path
 Cfoedus::storage::masstree::MasstreeComposeContext::PathLevelOne level in the path
 Cfoedus::storage::masstree::MasstreeStorage::PeekBoundariesArgumentsArguments for peek_volatile_page_boundaries()
 Cfoedus::snapshot::LogGleanerResource::PerNodeResourceThese buffers are used to read intermediate results from each reducer to compose the root page or other kinds of pages that weren't composed in each reducer (eg
 Cfoedus::xct::PointerAccessRepresents a record of following a page pointer during a transaction
 Cfoedus::storage::sequential::SequentialStoragePimpl::PointerPage
 Cfoedus::snapshot::MergeSort::PositionEntryProvides additional information for each entry we are sorting
 Cfoedus::assorted::ProbCounterImplements a probabilistic counter [Morris 1978]
 Cfoedus::proc::ProcArgumentsSet of arguments, both inputs and outputs, given to each procedure
 Cfoedus::proc::ProcManagerControlBlockThis small control block is used to synchronize the access to the array
 Cfoedus::assorted::ProtectedBoundaryA 4kb dummy data placed between separate memory regions so that we can check if/where a bogus memory access happens
 Cfoedus::debugging::RdtscWatchA RDTSC-based low-overhead stop watch
 Cfoedus::storage::hash::HashTmpBin::RecordRepresents a record with a unique key
 Cfoedus::storage::RecordRepresents one record in our key-value store
 Cfoedus::storage::masstree::MasstreeCommonLogType::RecordAddresses
 Cfoedus::storage::hash::RecordLocationReturn value of locate_record()
 Cfoedus::storage::masstree::RecordLocationReturn value of MasstreeStoragePimpl::locate_record()/reserve_record()
 Cfoedus::xct::RecordXctAccessBase of ReadXctAccess and WriteXctAccess
 Cfoedus::snapshot::ReducerBufferStatusCompactly represents important status informations of a reducer buffer
 Cfoedus::thread::RendezvousThe frequently appearing triplet of condition_varible, "signal" flag for spurious wakeup, and mutex for a one-time single-producer multiple-consumer event synchronization
 Cfoedus::restart::RestartManagerControlBlockShared data in RestartManagerPimpl
 Cfoedus::xct::RetrospectiveLockListRetrospective lock list
 Cfoedus::storage::sequential::SequentialComposer::RootInfoPageOutput of one compose() call, which are then combined in construct_root()
 Cfoedus::memory::RoundRobinPageGrabBatchA helper class to grab a bunch of pages from multiple nodes in round-robin fashion per chunk
 Cfoedus::storage::masstree::MasstreeCursor::RouteRepresents one page in the current search path from layer0-root
 Cfoedus::xct::RwLockableXctIdThe MCS reader-writer lock variant of LockableXctId
 Cfoedus::savepoint::SavepointManagerControlBlockShared data in SavepointManagerPimpl
 Cfoedus::memory::ScopedNumaPreferredAutomatically sets and resets numa_set_preferred()
 Cfoedus::xct::McsRwSimpleBlock::Self
 Cfoedus::storage::sequential::SequentialComposerComposer for an sequential storage
 Cfoedus::storage::sequential::SequentialCursorA cursor interface to read tuples from a sequential storage
 Cfoedus::storage::sequential::SequentialPageRepresents one data page in Sequential Storage
 Cfoedus::storage::sequential::SequentialPartitionerPartitioner for an sequential storage
 Cfoedus::storage::sequential::SequentialRecordBatchA chunk of records returned by SequentialCursor
 Cfoedus::storage::sequential::SequentialRecordIteratorIterator for one SequentialRecordBatch, or a page
 Cfoedus::storage::sequential::SequentialRootPageRepresents one stable root page in Sequential Storage
 Cfoedus::storage::sequential::SequentialStorageControlBlockShared data of this storage type
 Cfoedus::soc::SharedCondA conditional variable that can be placed in shared memory and used from multiple processes
 Cfoedus::proc::ProcManagerPimpl::SharedDataAll shared data in this module
 Cfoedus::memory::SharedMemoryRepresents memory shared between processes
 Cfoedus::soc::SharedMemoryRepoRepository of all shared memory in one FOEDUS instance
 Cfoedus::soc::SharedMutexA mutex that can be placed in shared memory and used from multiple processes
 Cfoedus::soc::SharedMutexScopeAuto-lock scope object for SharedMutex
 Cfoedus::soc::SharedPollingA polling-wait mechanism that can be placed in shared memory and used from multiple processes
 Cfoedus::soc::SharedRendezvousA one-time single-producer multiple-consumer event synchronization in shared memory for multiple processes
 Cfoedus::storage::hash::HashDataPage::SlotFix-sized slot for each record, which is placed at the end of data region
 Cfoedus::storage::masstree::MasstreeBorderPage::SlotFix-sized slot for each record, which is placed at the end of data region
 Cfoedus::storage::masstree::MasstreeBorderPage::SlotLengthPartA piece of Slot object that must be read/written in one-shot, meaning no one reads half-written values whether it reads old values or new values
 Cfoedus::storage::masstree::MasstreeBorderPage::SlotLengthUnion
 Cfoedus::memory::NumaCoreMemory::SmallThreadLocalMemoryPiecesPacks pointers to pieces of small_thread_local_memory_
 Cfoedus::snapshot::SnapshotRepresents one snapshot that converts all logs from base epoch to valid_until epoch into snapshot file(s)
 Cfoedus::snapshot::SnapshotManagerControlBlockShared data in SnapshotManagerPimpl
 Cfoedus::storage::Metadata::SnapshotThresholdsTuning parameters related to snapshotting
 Cfoedus::snapshot::SnapshotWriterWrites out one snapshot file for all data pages in one reducer
 Cfoedus::storage::Partitioner::SortBatchArgumentsArguments for sort_batch()
 Cfoedus::snapshot::SortedBufferRepresents one input stream of sorted log entries
 Cfoedus::storage::hash::SortEntryUsed in sort_batch()
 Cfoedus::snapshot::MergeSort::SortEntryEntries we actually sort
 Cfoedus::storage::array::SortEntryUsed in sort_batch()
 Cfoedus::storage::masstree::SortEntryUnlike array's sort entry, we don't always use this because keys are arbitrary lengthes
 Cfoedus::fs::SpaceInfoAnalogue of boost::filesystem::space_info
 Cfoedus::assorted::SpinlockStatHelper for SPINLOCK_WHILE
 Cfoedus::storage::masstree::SplitBorder::SplitStrategy
 Cfoedus::storage::masstree::SplitIntermediate::SplitStrategyConstructed by hierarchically reading all separators and pointers in old page
 Cfoedus::cache::CacheHashtable::Stat
 Cfoedus::memory::PagePool::Stat
 Cfoedus::thread::StoppableThreadThe frequently appearing quartet of std::thread, condition_varible, stop-request flag, and mutex
 Cfoedus::debugging::StopWatchA high-resolution stop watch
 Cfoedus::storage::StorageControlBlockA base layout of shared data for all storage types
 Cfoedus::storage::StorageManagerControlBlockShared data in StorageManagerPimpl
 Cfoedus::storage::sequential::StreamStatusUnlike other composers, this one doesn't need merge sort
 Cfoedus::xct::SysxctFunctorA functor representing the logic in a system transaction via virtual-function
 Cfoedus::xct::SysxctLockEntryAn entry in CLL/RLL for system transactions
 Cfoedus::xct::SysxctLockListRLL/CLL of a system transaction
 Cfoedus::xct::SysxctWorkspacePer-thread reused work memory for system transactions
 Cfoedus::thread::ThreadControlBlockShared data of ThreadPimpl
 Cfoedus::log::ThreadEpockMarkA thread-buffer's epoch marker, which indicates where a thread switched an epoch
 Cfoedus::thread::ThreadGroupRefA view of Thread group object for other SOCs and master engine
 Cfoedus::log::ThreadLogBufferMetaMetadata part of ThreadLogBuffer, without the actual buffer which is way way larger
 Cfoedus::soc::ThreadMemoryAnchorsPart of NodeMemoryAnchors for each thread
 Cfoedus::thread::ThreadPimplCllReleaseAllFunctor
 Cfoedus::thread::ThreadPimplMcsAdaptor< RW_BLOCK >Implements McsAdaptorConcept over ThreadPimpl
 Cfoedus::thread::ThreadRefA view of Thread object for other SOCs and master engine
 Cfoedus::externalize::TinyxmlGetter< T >Functor to help use tinyxml2's Element QueryXxxText()
 Cfoedus::externalize::TinyxmlGetter< assorted::FixedString< MAXLEN, CHAR > >
 Cfoedus::externalize::TinyxmlGetter< bool >
 Cfoedus::externalize::TinyxmlGetter< double >
 Cfoedus::externalize::TinyxmlGetter< float >
 Cfoedus::externalize::TinyxmlGetter< int16_t >
 Cfoedus::externalize::TinyxmlGetter< int32_t >
 Cfoedus::externalize::TinyxmlGetter< int64_t >
 Cfoedus::externalize::TinyxmlGetter< int8_t >
 Cfoedus::externalize::TinyxmlGetter< std::string >
 Cfoedus::externalize::TinyxmlGetter< uint16_t >
 Cfoedus::externalize::TinyxmlGetter< uint32_t >
 Cfoedus::externalize::TinyxmlGetter< uint64_t >
 Cfoedus::externalize::TinyxmlGetter< uint8_t >
 Cfoedus::externalize::TinyxmlSetter< T >Functor to help use tinyxml2's Element SetText()
 Cfoedus::externalize::TinyxmlSetter< assorted::FixedString< MAXLEN, CHAR > >
 Cfoedus::externalize::TinyxmlSetter< std::string >
 Cfoedus::storage::hash::TmpSnashotPage
 Cfoedus::assorted::TopWrite only first few bytes to stream
 Cfoedus::xct::TrackMovedRecordResultResult of track_moved_record()
 Cfoedus::assorted::UniformRandomA very simple and deterministic random generator that is more aligned with standard benchmark such as TPC-C
 Cfoedus::UninitializeGuardCalls Initializable::uninitialize() automatically when it gets out of scope
 Cfoedus::storage::VolatilePageInitArgumentsSet of arguments, both inputs and outputs, given to each volatile page initializer
 Cfoedus::storage::VolatilePagePointerRepresents a pointer to a volatile page with modification count for preventing ABA
 Cfoedus::xct::XctRepresents a user transaction
 Cfoedus::xct::XctIdPersistent status part of Transaction ID
 Cfoedus::xct::XctManagerControlBlockShared data in XctManagerPimpl
 Cfoedus::assorted::ZipfianRandomA simple zipfian generator based off of YCSB's Java implementation