Class CellChunkImmutableSegment
java.lang.Object
org.apache.hadoop.hbase.regionserver.Segment
org.apache.hadoop.hbase.regionserver.ImmutableSegment
org.apache.hadoop.hbase.regionserver.CellChunkImmutableSegment
- All Implemented Interfaces:
MemStoreSizing
CellChunkImmutableSegment extends the API supported by a
Segment, and
ImmutableSegment. This immutable segment is working with CellSet with CellChunkMap
delegatee.-
Field Summary
FieldsModifier and TypeFieldDescriptionstatic final longstatic final floatFields inherited from class org.apache.hadoop.hbase.regionserver.ImmutableSegment
DEEP_OVERHEADFields inherited from class org.apache.hadoop.hbase.regionserver.Segment
FIXED_OVERHEAD, memStoreSizing, minSequenceId, tagsPresent, timeRangeTrackerFields inherited from interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
DUD -
Constructor Summary
ConstructorsModifierConstructorDescriptionprotectedCellChunkImmutableSegment(CellComparator comparator, MemStoreSegmentsIterator iterator, MemStoreLAB memStoreLAB, int numOfCells, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of compaction/merge of a list of older ImmutableSegments.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. -
Method Summary
Modifier and TypeMethodDescriptionprivate Chunk[]allocIndexChunks(int numOfCells) private intcalcNumOfCellsInChunk(int chunkSize) private intcalculateNumberOfChunks(int numOfCells, int chunkSize) protected booleanprivate ExtendedCellcopyCellIntoMSLAB(ExtendedCell cell, MemStoreSizing memstoreSizing) private intcreateCellReference(ByteBufferKeyValue cell, ByteBuffer idxBuffer, int idxOffset) protected longindexEntryOffHeapSize(boolean offHeap) protected longindexEntryOnHeapSize(boolean onHeap) protected longprivate voidinitializeCellSet(int numOfCells, MemStoreSegmentsIterator iterator, MemStoreCompactionStrategy.Action action) private voidreinitializeCellSet(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) private ChunkCreator.ChunkTypeuseIndexChunks(int numOfCells) Methods inherited from class org.apache.hadoop.hbase.regionserver.ImmutableSegment
getAllSegments, getNumOfSegments, getNumUniqueKeys, getSnapshotScanners, toStringMethods inherited from class org.apache.hadoop.hbase.regionserver.Segment
close, compare, compareAndSetDataSize, compareRows, decScannerCount, dump, getCellLength, getCellsCount, getCellSet, getComparator, getDataSize, getHeapSize, getMemStoreLAB, getMemStoreSize, getMinSequenceId, getOffHeapSize, getScanner, getScanners, getTimeRangeTracker, headSet, heapSizeChange, incMemStoreSize, incScannerCount, internalAdd, isEmpty, isTagsPresent, iterator, last, maybeCloneWithAllocator, offHeapSizeChange, setCellSet, sharedLock, sharedUnlock, shouldSeek, tailSet, updateMetaInfo, updateMetaInfo, waitForUpdatesMethods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, waitMethods inherited from interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
decMemStoreSize, decMemStoreSize, incMemStoreSize
-
Field Details
-
DEEP_OVERHEAD_CCM
-
INDEX_CHUNK_UNUSED_SPACE_PRECENTAGE
- See Also:
-
-
Constructor Details
-
CellChunkImmutableSegment
protected CellChunkImmutableSegment(CellComparator comparator, MemStoreSegmentsIterator iterator, MemStoreLAB memStoreLAB, int numOfCells, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellChunkImmutableSegment is built as a result of compaction/merge of a list of older ImmutableSegments. The given iterator returns the Cells that "survived" the compaction. -
CellChunkImmutableSegment
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.
-
-
Method Details
-
indexEntryOnHeapSize
- Overrides:
indexEntryOnHeapSizein classSegment
-
indexEntryOffHeapSize
- Overrides:
indexEntryOffHeapSizein classSegment
-
indexEntrySize
- Specified by:
indexEntrySizein classSegment
-
canBeFlattened
- Specified by:
canBeFlattenedin classImmutableSegment
-
initializeCellSet
private void initializeCellSet(int numOfCells, MemStoreSegmentsIterator iterator, MemStoreCompactionStrategy.Action action) -
reinitializeCellSet
private void reinitializeCellSet(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) -
createCellReference
-
calculateNumberOfChunks
-
useIndexChunks
-
calcNumOfCellsInChunk
-
allocIndexChunks
-
copyCellIntoMSLAB
-