Uses of Interface
org.apache.hadoop.hbase.regionserver.MemStoreSizing
-
Uses of MemStoreSizing in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
CellArrayImmutableSegment extends the API supported by aSegment
, andImmutableSegment
.class
CellChunkImmutableSegment extends the API supported by aSegment
, andImmutableSegment
.class
The CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.class
CSLMImmutableSegment is an abstract class that extends the API supported by aSegment
, andImmutableSegment
.class
ImmutableSegment is an abstract class that extends the API supported by aSegment
, and is not needed for aMutableSegment
.class
A mutable segment in memstore, specifically the active segment.(package private) class
Accounting of current heap and data sizes.class
This is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.(package private) class
Accounting of current heap and data sizes.Modifier and TypeFieldDescriptionstatic final MemStoreSizing
MemStoreSizing.DUD
private final MemStoreSizing
HRegion.memStoreSizing
protected final MemStoreSizing
Segment.memStoreSizing
(package private) final MemStoreSizing
HRegion.PrepareFlushResult.totalFlushableSize
Modifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) void
AbstractMemStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) void
HStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoid
HStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) Adds a value to the memstorevoid
MemStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Write the updatesvoid
MemStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) Write an updatevoid
MutableSegment.add
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentprotected void
HRegion.BatchOperation.applyFamilyMapToMemStore
(Map<byte[], List<ExtendedCell>> familyMap, MemStoreSizing memstoreAccounting) Atomically apply the given map of family->edits to the memstore.private void
HRegion.applyToMemStore
(HStore store, List<ExtendedCell> cells, boolean delta, MemStoreSizing memstoreAccounting) protected boolean
CompactingMemStore.checkAndAddToActiveSize
(MutableSegment currActive, Cell cellToAdd, MemStoreSizing memstoreSizing) Check whether anything need to be done based on the current active set size.private ExtendedCell
CellChunkImmutableSegment.copyCellIntoMSLAB
(ExtendedCell cell, MemStoreSizing memstoreSizing) SegmentFactory.createImmutableSegment
(MutableSegment segment, MemStoreSizing memstoreSizing) SegmentFactory.createImmutableSegmentByFlattening
(CSLMImmutableSegment segment, CompactingMemStore.IndexType idxType, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) SegmentFactory.createMutableSegment
(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreSizing memstoreSizing) protected void
AbstractMemStore.doAdd
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private void
AbstractMemStore.doAddOrUpsert
(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing, boolean doAdd) private void
AbstractMemStore.doUpsert
(MutableSegment currentActive, ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) private MutableSegment
SegmentFactory.generateMutableSegment
(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) private void
AbstractMemStore.internalAdd
(MutableSegment currentActive, ExtendedCell toAdd, boolean mslabUsed, MemStoreSizing memstoreSizing) Internal version of add() that doesn't clone Cells with the allocator, and doesn't take the lock.protected void
CompositeImmutableSegment.internalAdd
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.internalAdd
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected abstract boolean
AbstractMemStore.preUpdate
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected boolean
CompactingMemStore.preUpdate
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the update For compacting memstore this means checking the update can increase the size without overflowprotected boolean
DefaultMemStore.preUpdate
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private void
CellChunkImmutableSegment.reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) protected void
HRegion.restoreEdit
(HStore s, ExtendedCell cell, MemStoreSizing memstoreAccounting) Used by testsprotected void
CompositeImmutableSegment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, MemStoreSizing memstoreSizing) void
AbstractMemStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) private void
AbstractMemStore.upsert
(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) void
HStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.void
MemStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Update or insert the specified cells.void
MutableSegment.upsert
(ExtendedCell cell, long readpoint, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) ModifierConstructorDescriptionprotected
CellArrayImmutableSegment
(CSLMImmutableSegment segment, MemStoreSizing mss, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The given iterator returns the Cells that "survived" the compaction.protected
CellChunkImmutableSegment
(CSLMImmutableSegment segment, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of flattening of CSLMImmutableSegment The given iterator returns the Cells that "survived" the compaction.protected
CSLMImmutableSegment
(Segment segment, MemStoreSizing memstoreSizing) ------------------------------------------------------------------------ Copy C-tor to be used when new CSLMImmutableSegment is being built from a Mutable one.protected
MutableSegment
(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) (package private)
PrepareFlushResult
(TreeMap<byte[], StoreFlushContext> storeFlushCtxs, TreeMap<byte[], List<org.apache.hadoop.fs.Path>> committedFiles, TreeMap<byte[], MemStoreSize> storeFlushableSize, long startTime, long flushSeqId, long flushedSeqId, MemStoreSizing totalFlushableSize) Constructs a successful prepare flush resultprivate
PrepareFlushResult
(HRegion.FlushResultImpl result, TreeMap<byte[], StoreFlushContext> storeFlushCtxs, TreeMap<byte[], List<org.apache.hadoop.fs.Path>> committedFiles, TreeMap<byte[], MemStoreSize> storeFlushableSize, long startTime, long flushSeqId, long flushedSeqId, MemStoreSizing totalFlushableSize)