libfoedus-core
FOEDUS Core Library
|
Cfoedus::xct::AcquireAsyncRet | Return value of acquire_async_rw |
Cfoedus::snapshot::MergeSort::AdjustComparatorMasstree | Used in batch_sort_adjust_sort if the storage is a masstree storage |
Cfoedus::memory::AlignedMemory | Represents one memory block aligned to actual OS/hardware pages |
Cfoedus::memory::AlignedMemorySlice | A slice of foedus::memory::AlignedMemory |
Cfoedus::storage::array::ArrayComposeContext | ArrayComposer's compose() implementation separated from the class itself |
Cfoedus::storage::array::ArrayComposer | Composer for an array storage |
Cfoedus::storage::array::ArrayPage | Represents one data page in Array Storage |
Cfoedus::storage::array::ArrayPartitioner | Partitioner for an array storage |
Cfoedus::storage::array::ArrayPartitionerData | |
Cfoedus::storage::array::ArrayRange | Represents an offset range in an array storage |
Cfoedus::storage::array::ArrayRootInfoPage | Output of one compose() call, which are then combined in construct_root() |
Cfoedus::storage::array::ArrayStorageControlBlock | Shared data of this storage type |
Cfoedus::storage::array::ArrayStoragePimpl | Pimpl 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::AutoVolatilePageReleaseScope | Automatically invokes a page offset acquired for volatile page |
Cfoedus::assorted::BacktraceContext | |
►Cfoedus::log::BaseLogType | Base class for log type |
Cbitmask | |
►Cfoedus::snapshot::BlockHeaderBase | All log blocks in mapper/reducers start with this header |
Cfoedus::storage::hash::BloomFilterFingerprint | A fingerprint for bloom filter in each HashDataPage |
Cfoedus::cache::CacheBucket | Hash bucket in cache table |
Cfoedus::cache::CacheHashtable | A NUMA-local hashtable of cached snapshot pages |
Cfoedus::cache::CacheOverflowEntry | An entry in the overflow linked list for snapshot cache |
Cfoedus::cache::CacheRefCount | A loosely maintained reference count for CLOCK algorithm |
Cfoedus::soc::ChildEngineStatus | Current status of a child SOC engine |
Cfoedus::snapshot::ReducerBufferStatus::Components | |
Cfoedus::xct::McsRwSimpleBlock::Self::Components | |
Cfoedus::xct::McsRwExtendedBlock::Field::Components | |
Cfoedus::storage::Composer::ComposeArguments | Arguments for compose() |
Cfoedus::storage::hash::ComposedBin | Represents an output of composer on one bin |
Cfoedus::storage::hash::ComposedBinsBuffer | Abstracts how we batch-read several HashComposedBinsPage emit from individual composers |
Cfoedus::storage::hash::ComposedBinsMergedStream | Packages all ComposedBinsBuffer to easily extract bins of current interest |
Cfoedus::storage::Composer | Represents a logic to compose a new version of data pages for one storage |
Cfoedus::thread::ConditionVariable | An 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::ConstDiv | The pre-calculated p-m pair for optimized integer division by constant |
Cfoedus::storage::Composer::ConstructRootArguments | Arguments for construct_root() |
Cfoedus::xct::CurrentLockList | Sorted list of all locks, either read-lock or write-lock, taken in the current run |
Cfoedus::xct::CurrentLockListIteratorForWriteSet | An iterator over CurrentLockList to find entries along with sorted write-set |
Cfoedus::storage::array::ArrayPage::Data | Data union for either leaf (dynamic size) or interior (fixed size) |
Cfoedus::storage::hash::DataPageBloomFilter | To quickly check whether a HashDataPage might contain a specific hash value, we maintain a non-counting bloom filter in each page |
Cfoedus::storage::Partitioner::DesignPartitionArguments | Arguments for design_partition() |
Cfoedus::fs::DirectIoFile | Represents an I/O stream on one file without filesystem caching |
Cfoedus::memory::DivvyupPageGrabBatch | A helper class to grab a bunch of pages from multiple nodes in arbitrary fashion |
Cfoedus::storage::Composer::DropResult | Retrun value of drop_volatiles() |
Cfoedus::storage::Composer::DropVolatilesArguments | Arguments for drop_volatiles() |
Cfoedus::storage::DualPagePointer | Represents a pointer to another page (usually a child page) |
Cfoedus::assorted::DumbSpinlock | A simple spinlock using a boolean field |
Cfoedus::Epoch | Represents a time epoch |
Cfoedus::log::EpochHistory | Represents an event where a logger switched its epoch |
Cfoedus::ErrorStack | Brings error stacktrace information as return value of functions |
Cfoedus::ErrorStackBatch | Batches zero or more ErrorStack objects to represent in one ErrorStack |
Cfoedus::cache::CacheHashtable::EvictArgs | Parameters for evict() |
►Cfoedus::externalize::Externalizable | Represents 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::FileStatus | Analogue of boost::filesystem::file_status |
Cfoedus::storage::masstree::MasstreeBorderPage::FindKeyForReserveResult | Return value for find_key_for_reserve() |
Cfoedus::FixedErrorStack | Representation of ErrorStack that can be copied to other processes and even serialized to files |
Cfoedus::savepoint::FixedSavepoint | Savepoint 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::GlobalMemoryAnchors | Just a set of pointers within global_memory_ for ease of use |
Cfoedus::memory::GlobalVolatilePageResolver | Resolves an offset in a volatile page pool to an actual pointer and vice versa |
Cfoedus::thread::GrabFreeVolatilePagesScope | Obtains multiple free volatile pages at once and releases them automatically when this object gets out of scope |
Cfoedus::snapshot::MergeSort::GroupifyResult | Represents a group of consecutive logs in the current batch |
Cfoedus::storage::hash::HashBinRange | Represents a range of hash bins in a hash storage, such as what an intermediate page is responsible for |
Cfoedus::storage::hash::HashCombo | A set of information that are used in many places, extracted from the given key |
Cfoedus::storage::hash::HashComposeContext | HashComposer's compose() implementation separated from the class itself |
Cfoedus::storage::hash::HashComposedBinsPage | A page to pack many ComposedBin as an output of composer |
Cfoedus::storage::hash::HashComposer | Composer for a hash storage |
Cfoedus::storage::hash::HashDataPage | Represents an individual data page in Hashtable Storage |
Cfoedus::cache::HashFunc | A simple hash function logic used in snasphot cache |
Cfoedus::storage::hash::HashIntermediatePage | Represents an intermediate page in Hashtable Storage |
Cfoedus::storage::hash::HashPartitioner | Partitioner for a hash storage |
Cfoedus::storage::hash::HashPartitionerData | |
Cfoedus::storage::hash::HashStorageControlBlock | Shared data of this storage type |
Cfoedus::storage::hash::HashTmpBin | An in-memory single-threaded data structure to compose tuples in a hash bin |
Cfoedus::storage::sequential::HeadPagePointer | Each pointer to a snapshot head page comes with a bit more information to help reading |
Cfoedus::assorted::Hex | Convenient way of writing hex integers to stream |
Cfoedus::assorted::HexString | Equivalent to std::hex in case the stream doesn't support it |
Cfoedus::storage::masstree::HighFence | Used only for debugging as this is not space efficient |
Cfoedus::thread::ImpersonateSession | A user session running on an impersonated thread |
Cfoedus::xct::InCommitEpochGuard | Automatically sets in-commit-epoch with appropriate fence during pre-commit protocol |
►Cfoedus::Initializable | The pure-virtual interface to initialize/uninitialize non-trivial resources |
Cfoedus::snapshot::MergeSort::InputStatus | Current status of each input |
Cfoedus::storage::hash::IntermediateRoute | Compactly represents the route of intermediate pages to reach the given hash bin |
Cfoedus::xct::LockEntry::LessThan | For std::binary_search() etc without creating the object |
Cfoedus::xct::SysxctLockEntry::LessThan | For std::binary_search() etc without creating the object |
Cfoedus::assorted::BacktraceContext::LibBacktraceInfo | |
Cfoedus::memory::LocalPageResolver | Resolves an offset in local (same NUMA node) page pool to a pointer and vice versa |
Cfoedus::xct::LockableXctId | Transaction ID, a 128-bit data to manage record versions and provide locking mechanism |
Cfoedus::xct::LockEntry | An entry in CLL and RLL, representing a lock that is taken or will be taken |
Cfoedus::xct::LockFreeReadXctAccess | Represents a record of special read-access during a transaction without any need for locking |
Cfoedus::xct::LockFreeWriteXctAccess | Represents a record of special write-access during a transaction without any need for locking |
Cfoedus::snapshot::LogBuffer | Packages handling of 4-bytes representation of position in log buffers |
Cfoedus::log::LoggerControlBlock | Shared data of Logger |
Cfoedus::savepoint::LoggerSavepointInfo | Information in savepoint for one logger |
Cfoedus::snapshot::LogGleanerControlBlock | Shared data for LogGleaner |
Cfoedus::snapshot::LogGleanerResource | Local resource for the log gleaner, which runs only in the master node |
Cfoedus::log::LogHeader | A common header part for all log types |
Cfoedus::log::LogManagerControlBlock | Shared data in LogManagerPimpl |
Cfoedus::log::LogRange | Contiguous range of log entries that might span multiple files |
Cfoedus::snapshot::LogReducerControlBlock | Shared data for LogReducer |
Cfoedus::snapshot::LogReducerRef | A remote view of LogReducer from all engines |
Cfoedus::storage::array::LookupRoute | Compactly represents the route to reach the given offset |
Cfoedus::storage::array::LookupRouteFinder | Packages logic and required properties to calculate LookupRoute in array storage from offset |
Cfoedus::storage::masstree::MasstreeComposeContext | MasstreeComposer's compose() implementation separated from the class itself |
Cfoedus::storage::masstree::MasstreeComposer | Composer for an masstree storage |
Cfoedus::storage::masstree::MasstreeCursor | Represents a cursor object for Masstree storage |
Cfoedus::storage::masstree::MasstreeIntermediatePointerIterator | Handy iterator for MasstreeIntermediate |
►Cfoedus::storage::masstree::MasstreePage | Common base of MasstreeIntermediatePage and MasstreeBorderPage |
Cfoedus::storage::masstree::MasstreePartitioner | Partitioner for a masstree storage |
Cfoedus::storage::masstree::MasstreePartitionerData | Dynamic information of one partitioner |
Cfoedus::storage::masstree::MasstreeStorageControlBlock | Shared data of this storage type |
Cfoedus::soc::MasterEngineStatus | Current 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::McsMockDataPage | A 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::McsRwExtendedBlock | Pre-allocated MCS block for extended version of RW-locks |
Cfoedus::xct::McsRwLock | An MCS reader-writer lock data structure |
Cfoedus::xct::McsRwSimpleBlock | Reader-writer (RW) MCS lock classes |
Cfoedus::xct::McsWwBlock | Pre-allocated MCS block for WW-locks |
Cfoedus::xct::McsWwBlockData | Exclusive-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::McsWwLock | An exclusive-only (WW) MCS lock data structure |
Cfoedus::xct::McsWwOwnerlessImpl | A ownerless (contextless) interface for McsWwImpl |
►Cfoedus::storage::Metadata | Metadata of one storage |
Cfoedus::log::MetaLogControlBlock | Control block for MetaLogBuffer and MetaLogger |
Cfoedus::storage::masstree::MasstreeIntermediatePage::MiniPage | |
Cfoedus::EnginePimpl::ModulePtr | Pair of module pointer and its type |
Cnodemask_t | |
Cfoedus::soc::NodeMemoryAnchors | Same as GlobalMemoryAnchors except this is for node_memories_ |
Cfoedus::memory::NumaNodeMemoryRef | A view of NumaNodeMemory for other SOCs and master engine |
Cfoedus::thread::NumaThreadScope | Pin the current thread to the given NUMA node in this object's scope |
Cfoedus::memory::PagePoolOffsetAndEpochChunk::OffsetAndEpoch | |
Cfoedus::log::ThreadLogBuffer::OffsetRange | |
Cfoedus::storage::masstree::OwnerSamples | Number of vol pages in each node sampled per pointer in the root page |
Cfoedus::storage::Page | Just a marker to denote that the memory region represents a data page |
Cfoedus::storage::masstree::MasstreeComposeContext::PageBoundaryInfo | Represents a minimal information to install a new snapshot page pointer |
Cfoedus::storage::masstree::MasstreeComposeContext::PageBoundarySort | Points to PageBoundaryInfo with a sorting information |
Cfoedus::xct::PageComparator | |
Cfoedus::storage::PageHeader | Just a marker to denote that a memory region represents a data page |
Cfoedus::memory::PagePoolControlBlock | Shared data in PagePoolPimpl |
Cfoedus::memory::PagePoolOffsetAndEpochChunk | Used to store an epoch value with each entry in PagePoolOffsetChunk |
Cfoedus::memory::PagePoolOffsetChunk | To reduce the overhead of grabbing/releasing pages from pool, we pack this many pointers for each grab/release |
Cfoedus::memory::PagePoolOffsetDynamicChunk | Used to point to an already existing array |
Cfoedus::memory::PageReleaseBatch | A helper class to return a bunch of pages to individual nodes |
Cfoedus::storage::PageVersion | Just a synonym of XctId to be used as a page lock mechanism |
Cfoedus::xct::PageVersionAccess | Represents a record of reading a page during a transaction |
Cfoedus::storage::PageVersionStatus | |
Cfoedus::debugging::DebuggingSupports::PapiCounters | |
Cfoedus::storage::Partitioner::PartitionBatchArguments | Arguments for partition_batch() |
Cfoedus::storage::PartitionerMetadata | Tiny metadata of partitioner for every storage used while log gleaning |
Cfoedus::fs::Path | Analogue of boost::filesystem::path |
Cfoedus::storage::masstree::MasstreeComposeContext::PathLevel | One level in the path |
Cfoedus::storage::masstree::MasstreeStorage::PeekBoundariesArguments | Arguments for peek_volatile_page_boundaries() |
Cfoedus::snapshot::LogGleanerResource::PerNodeResource | These 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::PointerAccess | Represents a record of following a page pointer during a transaction |
Cfoedus::storage::sequential::SequentialStoragePimpl::PointerPage | |
Cfoedus::snapshot::MergeSort::PositionEntry | Provides additional information for each entry we are sorting |
Cfoedus::assorted::ProbCounter | Implements a probabilistic counter [Morris 1978] |
Cfoedus::proc::ProcArguments | Set of arguments, both inputs and outputs, given to each procedure |
Cfoedus::proc::ProcManagerControlBlock | This small control block is used to synchronize the access to the array |
Cfoedus::assorted::ProtectedBoundary | A 4kb dummy data placed between separate memory regions so that we can check if/where a bogus memory access happens |
Cfoedus::debugging::RdtscWatch | A RDTSC-based low-overhead stop watch |
Cfoedus::storage::hash::HashTmpBin::Record | Represents a record with a unique key |
Cfoedus::storage::Record | Represents one record in our key-value store |
Cfoedus::storage::masstree::MasstreeCommonLogType::RecordAddresses | |
Cfoedus::storage::hash::RecordLocation | Return value of locate_record() |
Cfoedus::storage::masstree::RecordLocation | Return value of MasstreeStoragePimpl::locate_record()/reserve_record() |
►Cfoedus::xct::RecordXctAccess | Base of ReadXctAccess and WriteXctAccess |
Cfoedus::snapshot::ReducerBufferStatus | Compactly represents important status informations of a reducer buffer |
Cfoedus::thread::Rendezvous | The 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::RestartManagerControlBlock | Shared data in RestartManagerPimpl |
Cfoedus::xct::RetrospectiveLockList | Retrospective lock list |
Cfoedus::storage::sequential::SequentialComposer::RootInfoPage | Output of one compose() call, which are then combined in construct_root() |
Cfoedus::memory::RoundRobinPageGrabBatch | A helper class to grab a bunch of pages from multiple nodes in round-robin fashion per chunk |
Cfoedus::storage::masstree::MasstreeCursor::Route | Represents one page in the current search path from layer0-root |
Cfoedus::xct::RwLockableXctId | The MCS reader-writer lock variant of LockableXctId |
Cfoedus::savepoint::SavepointManagerControlBlock | Shared data in SavepointManagerPimpl |
Cfoedus::memory::ScopedNumaPreferred | Automatically sets and resets numa_set_preferred() |
Cfoedus::xct::McsRwSimpleBlock::Self | |
Cfoedus::storage::sequential::SequentialComposer | Composer for an sequential storage |
Cfoedus::storage::sequential::SequentialCursor | A cursor interface to read tuples from a sequential storage |
Cfoedus::storage::sequential::SequentialPage | Represents one data page in Sequential Storage |
Cfoedus::storage::sequential::SequentialPartitioner | Partitioner for an sequential storage |
Cfoedus::storage::sequential::SequentialRecordBatch | A chunk of records returned by SequentialCursor |
Cfoedus::storage::sequential::SequentialRecordIterator | Iterator for one SequentialRecordBatch, or a page |
Cfoedus::storage::sequential::SequentialRootPage | Represents one stable root page in Sequential Storage |
Cfoedus::storage::sequential::SequentialStorageControlBlock | Shared data of this storage type |
Cfoedus::soc::SharedCond | A conditional variable that can be placed in shared memory and used from multiple processes |
Cfoedus::proc::ProcManagerPimpl::SharedData | All shared data in this module |
Cfoedus::memory::SharedMemory | Represents memory shared between processes |
Cfoedus::soc::SharedMemoryRepo | Repository of all shared memory in one FOEDUS instance |
Cfoedus::soc::SharedMutex | A mutex that can be placed in shared memory and used from multiple processes |
Cfoedus::soc::SharedMutexScope | Auto-lock scope object for SharedMutex |
Cfoedus::soc::SharedPolling | A polling-wait mechanism that can be placed in shared memory and used from multiple processes |
Cfoedus::soc::SharedRendezvous | A one-time single-producer multiple-consumer event synchronization in shared memory for multiple processes |
Cfoedus::storage::hash::HashDataPage::Slot | Fix-sized slot for each record, which is placed at the end of data region |
Cfoedus::storage::masstree::MasstreeBorderPage::Slot | Fix-sized slot for each record, which is placed at the end of data region |
Cfoedus::storage::masstree::MasstreeBorderPage::SlotLengthPart | A 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::SmallThreadLocalMemoryPieces | Packs pointers to pieces of small_thread_local_memory_ |
Cfoedus::snapshot::Snapshot | Represents one snapshot that converts all logs from base epoch to valid_until epoch into snapshot file(s) |
Cfoedus::snapshot::SnapshotManagerControlBlock | Shared data in SnapshotManagerPimpl |
Cfoedus::storage::Metadata::SnapshotThresholds | Tuning parameters related to snapshotting |
Cfoedus::snapshot::SnapshotWriter | Writes out one snapshot file for all data pages in one reducer |
Cfoedus::storage::Partitioner::SortBatchArguments | Arguments for sort_batch() |
►Cfoedus::snapshot::SortedBuffer | Represents one input stream of sorted log entries |
Cfoedus::storage::hash::SortEntry | Used in sort_batch() |
Cfoedus::snapshot::MergeSort::SortEntry | Entries we actually sort |
Cfoedus::storage::array::SortEntry | Used in sort_batch() |
Cfoedus::storage::masstree::SortEntry | Unlike array's sort entry, we don't always use this because keys are arbitrary lengthes |
Cfoedus::fs::SpaceInfo | Analogue of boost::filesystem::space_info |
Cfoedus::assorted::SpinlockStat | Helper for SPINLOCK_WHILE |
Cfoedus::storage::masstree::SplitBorder::SplitStrategy | |
Cfoedus::storage::masstree::SplitIntermediate::SplitStrategy | Constructed by hierarchically reading all separators and pointers in old page |
Cfoedus::cache::CacheHashtable::Stat | |
Cfoedus::memory::PagePool::Stat | |
Cfoedus::thread::StoppableThread | The frequently appearing quartet of std::thread, condition_varible, stop-request flag, and mutex |
Cfoedus::debugging::StopWatch | A high-resolution stop watch |
Cfoedus::storage::StorageControlBlock | A base layout of shared data for all storage types |
Cfoedus::storage::StorageManagerControlBlock | Shared data in StorageManagerPimpl |
Cfoedus::storage::sequential::StreamStatus | Unlike other composers, this one doesn't need merge sort |
►Cfoedus::xct::SysxctFunctor | A functor representing the logic in a system transaction via virtual-function |
Cfoedus::xct::SysxctLockEntry | An entry in CLL/RLL for system transactions |
Cfoedus::xct::SysxctLockList | RLL/CLL of a system transaction |
Cfoedus::xct::SysxctWorkspace | Per-thread reused work memory for system transactions |
Cfoedus::thread::ThreadControlBlock | Shared data of ThreadPimpl |
Cfoedus::log::ThreadEpockMark | A thread-buffer's epoch marker, which indicates where a thread switched an epoch |
Cfoedus::thread::ThreadGroupRef | A view of Thread group object for other SOCs and master engine |
Cfoedus::log::ThreadLogBufferMeta | Metadata part of ThreadLogBuffer, without the actual buffer which is way way larger |
Cfoedus::soc::ThreadMemoryAnchors | Part of NodeMemoryAnchors for each thread |
Cfoedus::thread::ThreadPimplCllReleaseAllFunctor | |
Cfoedus::thread::ThreadPimplMcsAdaptor< RW_BLOCK > | Implements McsAdaptorConcept over ThreadPimpl |
Cfoedus::thread::ThreadRef | A 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::Top | Write only first few bytes to stream |
Cfoedus::xct::TrackMovedRecordResult | Result of track_moved_record() |
Cfoedus::assorted::UniformRandom | A very simple and deterministic random generator that is more aligned with standard benchmark such as TPC-C |
Cfoedus::UninitializeGuard | Calls Initializable::uninitialize() automatically when it gets out of scope |
Cfoedus::storage::VolatilePageInitArguments | Set of arguments, both inputs and outputs, given to each volatile page initializer |
Cfoedus::storage::VolatilePagePointer | Represents a pointer to a volatile page with modification count for preventing ABA |
Cfoedus::xct::Xct | Represents a user transaction |
Cfoedus::xct::XctId | Persistent status part of Transaction ID |
Cfoedus::xct::XctManagerControlBlock | Shared data in XctManagerPimpl |
Cfoedus::assorted::ZipfianRandom | A simple zipfian generator based off of YCSB's Java implementation |