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
Modifier and TypeFieldDescriptionstatic final long
static final float
Fields inherited from class org.apache.hadoop.hbase.regionserver.ImmutableSegment
DEEP_OVERHEAD
Fields inherited from class org.apache.hadoop.hbase.regionserver.Segment
FIXED_OVERHEAD, memStoreSizing, minSequenceId, tagsPresent, timeRangeTracker
Fields inherited from interface org.apache.hadoop.hbase.regionserver.MemStoreSizing
DUD
-
Constructor Summary
ModifierConstructorDescriptionprotected
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.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 Summary
Modifier and TypeMethodDescriptionprivate Chunk[]
allocIndexChunks
(int numOfCells) private int
calcNumOfCellsInChunk
(int chunkSize) private int
calculateNumberOfChunks
(int numOfCells, int chunkSize) protected boolean
private ExtendedCell
copyCellIntoMSLAB
(ExtendedCell cell, MemStoreSizing memstoreSizing) private int
createCellReference
(ByteBufferKeyValue cell, ByteBuffer idxBuffer, int idxOffset) protected long
indexEntryOffHeapSize
(boolean offHeap) protected long
indexEntryOnHeapSize
(boolean onHeap) protected long
private void
initializeCellSet
(int numOfCells, MemStoreSegmentsIterator iterator, MemStoreCompactionStrategy.Action action) private void
reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) private ChunkCreator.ChunkType
useIndexChunks
(int numOfCells) Methods inherited from class org.apache.hadoop.hbase.regionserver.ImmutableSegment
getAllSegments, getNumOfSegments, getNumUniqueKeys, getSnapshotScanners, toString
Methods 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, waitForUpdates
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
Methods 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:
indexEntryOnHeapSize
in classSegment
-
indexEntryOffHeapSize
- Overrides:
indexEntryOffHeapSize
in classSegment
-
indexEntrySize
- Specified by:
indexEntrySize
in classSegment
-
canBeFlattened
- Specified by:
canBeFlattened
in 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
-