| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.regionserver | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CellArrayImmutableSegmentCellArrayImmutableSegment extends the API supported by a  Segment,
 andImmutableSegment. | 
| class  | CellChunkImmutableSegmentCellChunkImmutableSegment extends the API supported by a  Segment,
 andImmutableSegment. | 
| class  | CompositeImmutableSegmentThe CompositeImmutableSegments is created as a collection of ImmutableSegments and supports
 the interface of a single ImmutableSegments. | 
| class  | CSLMImmutableSegmentCSLMImmutableSegment is an abstract class that extends the API supported by a  Segment,
 andImmutableSegment. | 
| class  | ImmutableSegmentImmutableSegment is an abstract class that extends the API supported by a  Segment,
 and is not needed for aMutableSegment. | 
| class  | MutableSegmentA mutable segment in memstore, specifically the active segment. | 
| (package private) class  | NonThreadSafeMemStoreSizingAccounting of current heap and data sizes. | 
| class  | SegmentThis is an abstraction of a segment maintained in a memstore, e.g., the active
 cell set or its snapshot. | 
| (package private) class  | ThreadSafeMemStoreSizingAccounting of current heap and data sizes. | 
| Modifier and Type | Field and Description | 
|---|---|
| static MemStoreSizing | MemStoreSizing. DUD | 
| protected MemStoreSizing | Segment. memStoreSizing | 
| private MemStoreSizing | HRegion. memStoreSizing | 
| (package private) MemStoreSizing | HRegion.PrepareFlushResult. totalFlushableSize | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MutableSegment. add(Cell cell,
   boolean mslabUsed,
   MemStoreSizing memStoreSizing,
   boolean sizeAddedPreOperation)Adds the given cell into the segment | 
| void | HStore. add(Cell cell,
   MemStoreSizing memstoreSizing)Adds a value to the memstore | 
| void | AbstractMemStore. add(Cell cell,
   MemStoreSizing memstoreSizing) | 
| void | MemStore. add(Cell cell,
   MemStoreSizing memstoreSizing)Write an update | 
| void | HStore. add(Iterable<Cell> cells,
   MemStoreSizing memstoreSizing)Adds the specified value to the memstore | 
| void | AbstractMemStore. add(Iterable<Cell> cells,
   MemStoreSizing memstoreSizing) | 
| void | MemStore. add(Iterable<Cell> cells,
   MemStoreSizing memstoreSizing)Write the updates | 
| protected void | HRegion.BatchOperation. applyFamilyMapToMemStore(Map<byte[],List<Cell>> familyMap,
                        MemStoreSizing memstoreAccounting)Atomically apply the given map of family->edits to the memstore. | 
| private void | HRegion. applyToMemStore(HStore store,
               Cell cell,
               MemStoreSizing memstoreAccounting) | 
| private void | HRegion. applyToMemStore(HStore store,
               List<Cell> cells,
               boolean delta,
               MemStoreSizing memstoreAccounting) | 
| private boolean | CompactingMemStore. checkAndAddToActiveSize(MutableSegment currActive,
                       Cell cellToAdd,
                       MemStoreSizing memstoreSizing)Check whether anything need to be done based on the current active set size. | 
| private Cell | CellChunkImmutableSegment. copyCellIntoMSLAB(Cell cell,
                 MemStoreSizing memstoreSizing) | 
| ImmutableSegment | SegmentFactory. createImmutableSegment(MutableSegment segment,
                      MemStoreSizing memstoreSizing) | 
| ImmutableSegment | SegmentFactory. createImmutableSegmentByFlattening(CSLMImmutableSegment segment,
                                  CompactingMemStore.IndexType idxType,
                                  MemStoreSizing memstoreSizing,
                                  MemStoreCompactionStrategy.Action action) | 
| MutableSegment | SegmentFactory. createMutableSegment(org.apache.hadoop.conf.Configuration conf,
                    CellComparator comparator,
                    MemStoreSizing memstoreSizing) | 
| private void | AbstractMemStore. doAdd(MutableSegment currentActive,
     Cell cell,
     MemStoreSizing memstoreSizing) | 
| private void | AbstractMemStore. doAddOrUpsert(Cell cell,
             long readpoint,
             MemStoreSizing memstoreSizing,
             boolean doAdd) | 
| private void | AbstractMemStore. doUpsert(MutableSegment currentActive,
        Cell cell,
        long readpoint,
        MemStoreSizing memstoreSizing) | 
| private MutableSegment | SegmentFactory. generateMutableSegment(org.apache.hadoop.conf.Configuration conf,
                      CellComparator comparator,
                      MemStoreLAB memStoreLAB,
                      MemStoreSizing memstoreSizing) | 
| protected void | Segment. internalAdd(Cell cell,
           boolean mslabUsed,
           MemStoreSizing memstoreSizing,
           boolean sizeAddedPreOperation) | 
| protected void | CompositeImmutableSegment. internalAdd(Cell cell,
           boolean mslabUsed,
           MemStoreSizing memstoreSizing,
           boolean sizeAddedPreOperation) | 
| private void | AbstractMemStore. internalAdd(MutableSegment currentActive,
           Cell toAdd,
           boolean mslabUsed,
           MemStoreSizing memstoreSizing) | 
| protected boolean | CompactingMemStore. preUpdate(MutableSegment currentActive,
         Cell 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
 overflow | 
| protected boolean | DefaultMemStore. preUpdate(MutableSegment currentActive,
         Cell cell,
         MemStoreSizing memstoreSizing) | 
| protected abstract boolean | AbstractMemStore. preUpdate(MutableSegment currentActive,
         Cell cell,
         MemStoreSizing memstoreSizing)Issue any synchronization and test needed before applying the update | 
| private void | CellChunkImmutableSegment. reinitializeCellSet(int numOfCells,
                   KeyValueScanner segmentScanner,
                   CellSet oldCellSet,
                   MemStoreSizing memstoreSizing,
                   MemStoreCompactionStrategy.Action action) | 
| protected void | HRegion. restoreEdit(HStore s,
           Cell cell,
           MemStoreSizing memstoreAccounting)Used by tests | 
| protected boolean | CompactingMemStore. shouldFlushInMemory(MutableSegment currActive,
                   Cell cellToAdd,
                   MemStoreSizing memstoreSizing) | 
| protected void | Segment. updateMetaInfo(Cell cellToAdd,
              boolean succ,
              boolean mslabUsed,
              MemStoreSizing memstoreSizing,
              boolean sizeAddedPreOperation) | 
| protected void | CompositeImmutableSegment. updateMetaInfo(Cell cellToAdd,
              boolean succ,
              boolean mslabUsed,
              MemStoreSizing memstoreSizing,
              boolean sizeAddedPreOperation) | 
| protected void | Segment. updateMetaInfo(Cell cellToAdd,
              boolean succ,
              MemStoreSizing memstoreSizing) | 
| private void | AbstractMemStore. upsert(Cell cell,
      long readpoint,
      MemStoreSizing memstoreSizing) | 
| void | MutableSegment. upsert(Cell cell,
      long readpoint,
      MemStoreSizing memStoreSizing,
      boolean sizeAddedPreOperation) | 
| void | HStore. upsert(Iterable<Cell> cells,
      long readpoint,
      MemStoreSizing memstoreSizing)Adds or replaces the specified KeyValues. | 
| void | AbstractMemStore. upsert(Iterable<Cell> cells,
      long readpoint,
      MemStoreSizing memstoreSizing) | 
| void | MemStore. upsert(Iterable<Cell> cells,
      long readpoint,
      MemStoreSizing memstoreSizing)Update or insert the specified cells. | 
| Constructor and Description | 
|---|
| 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. | 
| 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. | 
| CSLMImmutableSegment(Segment segment,
                    MemStoreSizing memstoreSizing)------------------------------------------------------------------------
 Copy C-tor to be used when new CSLMImmutableSegment is being built from a Mutable one. | 
| MutableSegment(CellSet cellSet,
              CellComparator comparator,
              MemStoreLAB memStoreLAB,
              MemStoreSizing memstoreSizing) | 
| 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) | 
| 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 result | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.