| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.regionserver | 
| Modifier and Type | Method and Description | 
|---|---|
protected MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.compact(VersionedSegmentsList versionedList,
       String strategyInfo)  | 
abstract MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.getAction(VersionedSegmentsList versionedList)  | 
MemStoreCompactionStrategy.Action | 
EagerMemStoreCompactionStrategy.getAction(VersionedSegmentsList versionedList)  | 
MemStoreCompactionStrategy.Action | 
AdaptiveMemStoreCompactionStrategy.getAction(VersionedSegmentsList versionedList)  | 
MemStoreCompactionStrategy.Action | 
BasicMemStoreCompactionStrategy.getAction(VersionedSegmentsList versionedList)  | 
protected MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.getFlattenAction()  | 
protected MemStoreCompactionStrategy.Action | 
AdaptiveMemStoreCompactionStrategy.getFlattenAction()  | 
protected MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.getMergingAction()  | 
protected MemStoreCompactionStrategy.Action | 
AdaptiveMemStoreCompactionStrategy.getMergingAction()  | 
protected MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.simpleMergeOrFlatten(VersionedSegmentsList versionedList,
                    String strategy)  | 
static MemStoreCompactionStrategy.Action | 
MemStoreCompactionStrategy.Action.valueOf(String name)
Returns the enum constant of this type with the specified name. 
 | 
static MemStoreCompactionStrategy.Action[] | 
MemStoreCompactionStrategy.Action.values()
Returns an array containing the constants of this enum type, in
the order they are declared. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
private ImmutableSegment | 
SegmentFactory.createImmutableSegment(org.apache.hadoop.conf.Configuration conf,
                      CellComparator comparator,
                      MemStoreSegmentsIterator iterator,
                      MemStoreLAB memStoreLAB,
                      int numOfCells,
                      MemStoreCompactionStrategy.Action action,
                      CompactingMemStore.IndexType idxType)  | 
ImmutableSegment | 
SegmentFactory.createImmutableSegmentByCompaction(org.apache.hadoop.conf.Configuration conf,
                                  CellComparator comparator,
                                  MemStoreSegmentsIterator iterator,
                                  int numOfCells,
                                  CompactingMemStore.IndexType idxType,
                                  MemStoreCompactionStrategy.Action action)  | 
ImmutableSegment | 
SegmentFactory.createImmutableSegmentByFlattening(CSLMImmutableSegment segment,
                                  CompactingMemStore.IndexType idxType,
                                  MemStoreSizing memstoreSizing,
                                  MemStoreCompactionStrategy.Action action)  | 
ImmutableSegment | 
SegmentFactory.createImmutableSegmentByMerge(org.apache.hadoop.conf.Configuration conf,
                             CellComparator comparator,
                             MemStoreSegmentsIterator iterator,
                             int numOfCells,
                             List<ImmutableSegment> segments,
                             CompactingMemStore.IndexType idxType,
                             MemStoreCompactionStrategy.Action action)  | 
private ImmutableSegment | 
MemStoreCompactor.createSubstitution(MemStoreCompactionStrategy.Action action)
----------------------------------------------------------------------
 Creation of the ImmutableSegment either by merge or copy-compact of the segments of the
 pipeline, based on the Compactor Iterator. 
 | 
boolean | 
CompactionPipeline.flattenOneSegment(long requesterVersion,
                 CompactingMemStore.IndexType idxType,
                 MemStoreCompactionStrategy.Action action)
If the caller holds the current version, go over the the pipeline and try to flatten each
 segment. 
 | 
void | 
CompactingMemStore.flattenOneSegment(long requesterVersion,
                 MemStoreCompactionStrategy.Action action)  | 
private void | 
CellArrayImmutableSegment.initializeCellSet(int numOfCells,
                 MemStoreSegmentsIterator iterator,
                 MemStoreCompactionStrategy.Action action)  | 
private void | 
CellChunkImmutableSegment.initializeCellSet(int numOfCells,
                 MemStoreSegmentsIterator iterator,
                 MemStoreCompactionStrategy.Action action)  | 
private void | 
CellArrayImmutableSegment.reinitializeCellSet(int numOfCells,
                   KeyValueScanner segmentScanner,
                   CellSet oldCellSet,
                   MemStoreCompactionStrategy.Action action)  | 
private void | 
CellChunkImmutableSegment.reinitializeCellSet(int numOfCells,
                   KeyValueScanner segmentScanner,
                   CellSet oldCellSet,
                   MemStoreCompactionStrategy.Action action)  | 
| Constructor and Description | 
|---|
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. 
 | 
CellArrayImmutableSegment(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. 
 | 
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. 
 | 
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. 
 | 
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.