Uses of Interface
org.apache.hadoop.hbase.regionserver.MemStoreSizing
Packages that use MemStoreSizing
-
Uses of MemStoreSizing in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement MemStoreSizingModifier and TypeClassDescriptionclassCellArrayImmutableSegment extends the API supported by aSegment, andImmutableSegment.classCellChunkImmutableSegment extends the API supported by aSegment, andImmutableSegment.classThe CompositeImmutableSegments is created as a collection of ImmutableSegments and supports the interface of a single ImmutableSegments.classCSLMImmutableSegment is an abstract class that extends the API supported by aSegment, andImmutableSegment.classImmutableSegment is an abstract class that extends the API supported by aSegment, and is not needed for aMutableSegment.classA mutable segment in memstore, specifically the active segment.(package private) classAccounting of current heap and data sizes.classThis is an abstraction of a segment maintained in a memstore, e.g., the active cell set or its snapshot.(package private) classAccounting of current heap and data sizes.Fields in org.apache.hadoop.hbase.regionserver declared as MemStoreSizingModifier and TypeFieldDescriptionstatic final MemStoreSizingMemStoreSizing.DUDprivate final MemStoreSizingHRegion.memStoreSizingprotected final MemStoreSizingSegment.memStoreSizing(package private) final MemStoreSizingHRegion.PrepareFlushResult.totalFlushableSizeMethods in org.apache.hadoop.hbase.regionserver with parameters of type MemStoreSizingModifier and TypeMethodDescriptionvoidAbstractMemStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) voidAbstractMemStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) voidHStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoidHStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) Adds a value to the memstorevoidMemStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Write the updatesvoidMemStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) Write an updatevoidMutableSegment.add(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentprotected voidHRegion.BatchOperation.applyFamilyMapToMemStore(Map<byte[], List<ExtendedCell>> familyMap, MemStoreSizing memstoreAccounting) Atomically apply the given map of family->edits to the memstore.private voidHRegion.applyToMemStore(HStore store, List<ExtendedCell> cells, boolean delta, MemStoreSizing memstoreAccounting) protected booleanCompactingMemStore.checkAndAddToActiveSize(MutableSegment currActive, Cell cellToAdd, MemStoreSizing memstoreSizing) Check whether anything need to be done based on the current active set size.private ExtendedCellCellChunkImmutableSegment.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 voidAbstractMemStore.doAdd(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private voidAbstractMemStore.doAddOrUpsert(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing, boolean doAdd) private voidAbstractMemStore.doUpsert(MutableSegment currentActive, ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) private MutableSegmentSegmentFactory.generateMutableSegment(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) private voidAbstractMemStore.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 voidCompositeImmutableSegment.internalAdd(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.internalAdd(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected abstract booleanAbstractMemStore.preUpdate(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected booleanCompactingMemStore.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 booleanDefaultMemStore.preUpdate(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private voidCellChunkImmutableSegment.reinitializeCellSet(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) protected voidHRegion.restoreEdit(HStore s, ExtendedCell cell, MemStoreSizing memstoreAccounting) Used by testsprotected voidCompositeImmutableSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, MemStoreSizing memstoreSizing) voidAbstractMemStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) private voidAbstractMemStore.upsert(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) voidHStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.voidMemStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Update or insert the specified cells.voidMutableSegment.upsert(ExtendedCell cell, long readpoint, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type MemStoreSizingModifierConstructorDescriptionprotectedCellArrayImmutableSegment(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.protectedCellChunkImmutableSegment(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.protectedCSLMImmutableSegment(Segment segment, MemStoreSizing memstoreSizing) ------------------------------------------------------------------------ Copy C-tor to be used when new CSLMImmutableSegment is being built from a Mutable one.protectedMutableSegment(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 resultprivatePrepareFlushResult(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)