Class CellArrayImmutableSegment
java.lang.Object
org.apache.hadoop.hbase.regionserver.Segment
org.apache.hadoop.hbase.regionserver.ImmutableSegment
org.apache.hadoop.hbase.regionserver.CellArrayImmutableSegment
- All Implemented Interfaces:
MemStoreSizing
CellArrayImmutableSegment extends the API supported by a
Segment
, and
ImmutableSegment
. This immutable segment is working with CellSet with CellArrayMap
delegatee.-
Field Summary
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
CellArrayImmutableSegment
(CellComparator comparator, MemStoreSegmentsIterator iterator, MemStoreLAB memStoreLAB, int numOfCells, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellArrayImmutableSegment is a result of compaction of a list of older ImmutableSegments.protected
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. -
Method Summary
Modifier and TypeMethodDescriptionprotected boolean
protected long
private void
initializeCellSet
(int numOfCells, MemStoreSegmentsIterator iterator, MemStoreCompactionStrategy.Action action) private void
reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreCompactionStrategy.Action action) 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, indexEntryOffHeapSize, indexEntryOnHeapSize, 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_CAM
-
-
Constructor Details
-
CellArrayImmutableSegment
protected CellArrayImmutableSegment(CellComparator comparator, MemStoreSegmentsIterator iterator, MemStoreLAB memStoreLAB, int numOfCells, MemStoreCompactionStrategy.Action action) ------------------------------------------------------------------------ C-tor to be used when new CellArrayImmutableSegment is a result of compaction of a list of older ImmutableSegments. The given iterator returns the Cells that "survived" the compaction. -
CellArrayImmutableSegment
protected 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.
-
-
Method Details
-
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, MemStoreCompactionStrategy.Action action)
-