| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.io.encoding | |
| org.apache.hadoop.hbase.io.hfile | Provides implementations of  HFileand HFileBlockCache. | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.compactions | |
| org.apache.hadoop.hbase.regionserver.querymatcher | |
| org.apache.hadoop.hbase.security.visibility | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CellComparatorImplCompare two HBase cells. | 
| static class  | CellComparatorImpl.MetaCellComparator | 
| Modifier and Type | Method and Description | 
|---|---|
| static CellComparator | CellComparator. getInstance()A comparator for ordering cells in user-space tables. | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | CellUtil. compare(CellComparator comparator,
       Cell left,
       byte[] key,
       int offset,
       int length)Deprecated. 
 As of HBase-2.0. Will be removed in HBase-3.0 | 
| static int | PrivateCellUtil. compare(CellComparator comparator,
       Cell left,
       byte[] key,
       int offset,
       int length)Used when a cell needs to be compared with a key byte[] such as cases of finding the index from
 the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in
 the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this
 method cannot be used. | 
| static int | PrivateCellUtil. compareKeyBasedOnColHint(CellComparator comparator,
                        Cell nextIndexedCell,
                        Cell currentCell,
                        int foff,
                        int flen,
                        byte[] colHint,
                        int coff,
                        int clen,
                        long ts,
                        byte type)Used to compare two cells based on the column hint provided. | 
| static int | PrivateCellUtil. compareKeyIgnoresMvcc(CellComparator comparator,
                     Cell left,
                     Cell right)Compares only the key portion of a cell. | 
| (package private) static int | PrivateCellUtil. compareWithoutRow(CellComparator comparator,
                 Cell left,
                 byte[] right,
                 int roffset,
                 int rlength,
                 short rowlength)Compare columnFamily, qualifier, timestamp, and key type (everything except the row). | 
| Modifier and Type | Field and Description | 
|---|---|
| protected CellComparator | AbstractDataBlockEncoder.AbstractEncodedSeeker. comparator | 
| Modifier and Type | Method and Description | 
|---|---|
| int | DataBlockEncoder.EncodedSeeker. compareKey(CellComparator comparator,
          Cell key)Compare the given key against the current key | 
| int | RowIndexSeekerV1. compareKey(CellComparator comparator,
          Cell key) | 
| int | BufferedDataBlockEncoder.BufferedEncodedSeeker. compareKey(CellComparator comparator,
          Cell key) | 
| DataBlockEncoder.EncodedSeeker | FastDiffDeltaEncoder. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx) | 
| DataBlockEncoder.EncodedSeeker | DataBlockEncoder. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx)Create a HFileBlock seeker which find KeyValues within a block. | 
| DataBlockEncoder.EncodedSeeker | RowIndexCodecV1. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx) | 
| DataBlockEncoder.EncodedSeeker | PrefixKeyDeltaEncoder. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx) | 
| DataBlockEncoder.EncodedSeeker | CopyKeyDataBlockEncoder. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx) | 
| DataBlockEncoder.EncodedSeeker | DiffKeyDeltaEncoder. createSeeker(CellComparator comparator,
            HFileBlockDecodingContext decodingCtx) | 
| Constructor and Description | 
|---|
| AbstractEncodedSeeker(CellComparator comparator,
                     HFileBlockDecodingContext decodingCtx) | 
| BufferedEncodedSeeker(CellComparator comparator,
                     HFileBlockDecodingContext decodingCtx) | 
| RowIndexSeekerV1(CellComparator comparator,
                HFileBlockDecodingContext decodingCtx) | 
| Modifier and Type | Field and Description | 
|---|---|
| private CellComparator | HFileBlockIndex.CellBasedKeyBlockIndexReader. comparatorNeeded doing lookup on blocks. | 
| private CellComparator | HFileReaderImpl. comparatorKey comparator | 
| protected CellComparator | HFileWriterImpl. comparatorKey comparator. | 
| protected CellComparator | CompoundBloomFilterBase. comparatorComparator used to compare Bloom filter keys | 
| protected CellComparator | HFile.WriterFactory. comparator | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) CellComparator | FixedFileTrailer. createComparator() | 
| static CellComparator | FixedFileTrailer. createComparator(String comparatorClassName) | 
| CellComparator | HFileReaderImpl. getComparator() | 
| CellComparator | HFile.Reader. getComparator() | 
| Modifier and Type | Method and Description | 
|---|---|
| private static Class<? extends CellComparator> | FixedFileTrailer. getComparatorClass(String comparatorClassName) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static int | HFileBlockIndex.BlockIndexReader. binarySearchNonRootIndex(Cell key,
                        ByteBuff nonRootIndex,
                        CellComparator comparator)Performs a binary search over a non-root level index block. | 
| int | HFileReaderImpl.HFileScannerImpl. compareKey(CellComparator comparator,
          Cell key) | 
| int | HFileReaderImpl.EncodedScanner. compareKey(CellComparator comparator,
          Cell key) | 
| static Cell | HFileWriterImpl. getMidpoint(CellComparator comparator,
           Cell left,
           Cell right)Try to return a Cell that falls between  leftandrightbut that is shorter; i.e. | 
| (package private) static int | HFileBlockIndex.BlockIndexReader. locateNonRootIndexEntry(ByteBuff nonRootBlock,
                       Cell key,
                       CellComparator comparator)Search for one key using the secondary index in a non-root block. | 
| int | HFileBlockIndex.ByteArrayKeyBlockIndexReader. rootBlockContainingKey(byte[] key,
                      int offset,
                      int length,
                      CellComparator comp) | 
| int | HFileBlockIndex.CellBasedKeyBlockIndexReader. rootBlockContainingKey(byte[] key,
                      int offset,
                      int length,
                      CellComparator comp) | 
| abstract int | HFileBlockIndex.BlockIndexReader. rootBlockContainingKey(byte[] key,
                      int offset,
                      int length,
                      CellComparator comp)Finds the root-level index block containing the given key. | 
| HFile.WriterFactory | HFile.WriterFactory. withComparator(CellComparator comparator) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FixedFileTrailer. setComparatorClass(Class<? extends CellComparator> klass) | 
| Constructor and Description | 
|---|
| CellBasedKeyBlockIndexReader(CellComparator c,
                            int treeLevel) | 
| CellBasedKeyBlockIndexReader(CellComparator c,
                            int treeLevel,
                            HFile.CachingBlockReader cachingBlockReader) | 
| CompoundBloomFilterWriter(int chunkByteSizeHint,
                         float errorRate,
                         int hashType,
                         int maxFold,
                         boolean cacheOnWrite,
                         CellComparator comparator,
                         BloomType bloomType) | 
| HFileWriterImpl(org.apache.hadoop.conf.Configuration conf,
               CacheConfig cacheConf,
               org.apache.hadoop.fs.Path path,
               org.apache.hadoop.fs.FSDataOutputStream outputStream,
               CellComparator comparator,
               HFileContext fileContext) | 
| Modifier and Type | Field and Description | 
|---|---|
| private CellComparator | DefaultStoreFileManager. cellComparator | 
| private CellComparator | StripeStoreFileManager. cellComparator | 
| private CellComparator | ScanInfo. comparator | 
| private CellComparator | HStoreFile. comparator | 
| private CellComparator | Segment. comparator | 
| protected CellComparator | HStore. comparator | 
| private CellComparator | StoreFileWriter.Builder. comparator | 
| private CellComparator | AbstractMemStore. comparator | 
| protected CellComparator | StripeMultiFileWriter. comparator | 
| private CellComparator | StoreScanner. comparator | 
| protected CellComparator | HRegion.RegionScannerImpl. comparator | 
| protected CellComparator | StripeStoreFlusher.StripeFlushRequest. comparator | 
| protected CellComparator | KeyValueHeap.KVScannerComparator. kvComparator | 
| Modifier and Type | Method and Description | 
|---|---|
| CellComparator | Region. getCellComparator()The comparator to be used with the region | 
| CellComparator | HRegion. getCellComparator() | 
| CellComparator | ScanInfo. getComparator() | 
| CellComparator | StoreFile. getComparator()Get the comparator for comparing two cells. | 
| (package private) CellComparator | StoreFileScanner. getComparator() | 
| CellComparator | HStoreFile. getComparator() | 
| protected CellComparator | Segment. getComparator()Returns the Cell comparator used by this segment | 
| CellComparator | HStore. getComparator() | 
| protected CellComparator | AbstractMemStore. getComparator() | 
| CellComparator | StoreFileReader. getComparator() | 
| CellComparator | KeyValueHeap.KVScannerComparator. getComparator() | 
| CellComparator | Store. getComparator() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | ReversedStoreScanner. checkScanOrder(Cell prevKV,
              Cell kv,
              CellComparator comparator) | 
| protected void | StoreScanner. checkScanOrder(Cell prevKV,
              Cell kv,
              CellComparator comparator)Check whether scan as expected order | 
| static StoreEngine<?,?,?,?> | StoreEngine. create(HStore store,
      org.apache.hadoop.conf.Configuration conf,
      CellComparator cellComparator)Create the StoreEngine configured for the given Store. | 
| protected void | StripeStoreEngine. createComponents(org.apache.hadoop.conf.Configuration conf,
                HStore store,
                CellComparator comparator) | 
| protected void | DefaultStoreEngine. createComponents(org.apache.hadoop.conf.Configuration conf,
                HStore store,
                CellComparator kvComparator) | 
| protected abstract void | StoreEngine. createComponents(org.apache.hadoop.conf.Configuration conf,
                HStore store,
                CellComparator cellComparator)Create the StoreEngine's components. | 
| protected void | DateTieredStoreEngine. createComponents(org.apache.hadoop.conf.Configuration conf,
                HStore store,
                CellComparator kvComparator) | 
| private void | StoreEngine. createComponentsOnce(org.apache.hadoop.conf.Configuration conf,
                    HStore store,
                    CellComparator cellComparator) | 
| CompositeImmutableSegment | SegmentFactory. createCompositeImmutableSegment(CellComparator comparator,
                               List<ImmutableSegment> segments) | 
| ImmutableSegment | SegmentFactory. createImmutableSegment(CellComparator comparator)create empty immutable segment for initializations
 This ImmutableSegment is used as a place holder for snapshot in Memstore. | 
| 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. createImmutableSegmentByMerge(org.apache.hadoop.conf.Configuration conf,
                             CellComparator comparator,
                             MemStoreSegmentsIterator iterator,
                             int numOfCells,
                             List<ImmutableSegment> segments,
                             CompactingMemStore.IndexType idxType,
                             MemStoreCompactionStrategy.Action action) | 
| MutableSegment | SegmentFactory. createMutableSegment(org.apache.hadoop.conf.Configuration conf,
                    CellComparator comparator,
                    MemStoreSizing memstoreSizing) | 
| protected StoreEngine<?,?,?,?> | HMobStore. createStoreEngine(HStore store,
                 org.apache.hadoop.conf.Configuration conf,
                 CellComparator cellComparator)Creates the mob store engine. | 
| protected StoreEngine<?,?,?,?> | HStore. createStoreEngine(HStore store,
                 org.apache.hadoop.conf.Configuration conf,
                 CellComparator kvComparator)Creates the store engine configured for the given Store. | 
| private MutableSegment | SegmentFactory. generateMutableSegment(org.apache.hadoop.conf.Configuration conf,
                      CellComparator comparator,
                      MemStoreLAB memStoreLAB,
                      MemStoreSizing memstoreSizing) | 
| (package private) static Optional<byte[]> | StoreUtils. getFileSplitPoint(HStoreFile file,
                 CellComparator comparator)Gets the approximate mid-point of the given file that is optimal for use in splitting it. | 
| (package private) static Optional<byte[]> | StoreUtils. getSplitPoint(Collection<HStoreFile> storefiles,
             CellComparator comparator)Gets the mid point of the largest file passed in as split point. | 
| protected KeyValueHeap | ReversedStoreScanner. newKVHeap(List<? extends KeyValueScanner> scanners,
         CellComparator comparator) | 
| protected KeyValueHeap | StoreScanner. newKVHeap(List<? extends KeyValueScanner> scanners,
         CellComparator comparator) | 
| protected void | StoreScanner. resetKVHeap(List<? extends KeyValueScanner> scanners,
           CellComparator comparator) | 
| private static List<Cell> | HRegion. sort(List<Cell> cells,
    CellComparator comparator) | 
| StoreFileWriter.Builder | StoreFileWriter.Builder. withComparator(CellComparator comparator) | 
| Constructor and Description | 
|---|
| AbstractMemStore(org.apache.hadoop.conf.Configuration conf,
                CellComparator c,
                RegionServicesForStores regionServices) | 
| BoundaryMultiWriter(CellComparator comparator,
                   List<byte[]> targetBoundaries,
                   byte[] majorRangeFrom,
                   byte[] majorRangeTo) | 
| BoundaryStripeFlushRequest(CellComparator comparator,
                          List<byte[]> targetBoundaries) | 
| 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. | 
| 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. | 
| CellSet(CellComparator c) | 
| CompactingMemStore(org.apache.hadoop.conf.Configuration conf,
                  CellComparator c,
                  HStore store,
                  RegionServicesForStores regionServices,
                  MemoryCompactionPolicy compactionPolicy) | 
| CompositeImmutableSegment(CellComparator comparator,
                         List<ImmutableSegment> segments) | 
| DefaultMemStore(org.apache.hadoop.conf.Configuration conf,
               CellComparator c)Constructor. | 
| DefaultMemStore(org.apache.hadoop.conf.Configuration conf,
               CellComparator c,
               RegionServicesForStores regionServices)Constructor. | 
| DefaultStoreFileManager(CellComparator cellComparator,
                       Comparator<HStoreFile> storeFileComparator,
                       org.apache.hadoop.conf.Configuration conf,
                       CompactionConfiguration comConf) | 
| ImmutableSegment(CellComparator comparator)------------------------------------------------------------------------
 Empty C-tor to be used only for CompositeImmutableSegment | 
| ImmutableSegment(CellComparator comparator,
                List<ImmutableSegment> segments) | 
| ImmutableSegment(CellSet cs,
                CellComparator comparator,
                MemStoreLAB memStoreLAB)------------------------------------------------------------------------
 C-tor to be used to build the derived classes | 
| KeyValueHeap(List<? extends KeyValueScanner> scanners,
            CellComparator comparator)Constructor. | 
| KVScannerComparator(CellComparator kvComparator)Constructor | 
| MemStoreCompactorSegmentsIterator(List<ImmutableSegment> segments,
                                 CellComparator comparator,
                                 int compactionKVMax,
                                 HStore store) | 
| MemStoreMergerSegmentsIterator(List<ImmutableSegment> segments,
                              CellComparator comparator,
                              int compactionKVMax) | 
| MutableSegment(CellSet cellSet,
              CellComparator comparator,
              MemStoreLAB memStoreLAB,
              MemStoreSizing memstoreSizing) | 
| ReversedKeyValueHeap(List<? extends KeyValueScanner> scanners,
                    CellComparator comparator) | 
| ReversedKVScannerComparator(CellComparator kvComparator)Constructor | 
| ScanInfo(byte[] family,
        int minVersions,
        int maxVersions,
        long ttl,
        KeepDeletedCells keepDeletedCells,
        long timeToPurgeDeletes,
        CellComparator comparator,
        long tableMaxRowSize,
        boolean usePread,
        long cellsPerTimeoutCheck,
        boolean parallelSeekEnabled,
        long preadMaxBytes,
        boolean newVersionBehavior) | 
| ScanInfo(org.apache.hadoop.conf.Configuration conf,
        byte[] family,
        int minVersions,
        int maxVersions,
        long ttl,
        KeepDeletedCells keepDeletedCells,
        long blockSize,
        long timeToPurgeDeletes,
        CellComparator comparator,
        boolean newVersionBehavior) | 
| ScanInfo(org.apache.hadoop.conf.Configuration conf,
        ColumnFamilyDescriptor family,
        long ttl,
        long timeToPurgeDeletes,
        CellComparator comparator) | 
| Segment(CellComparator comparator,
       List<ImmutableSegment> segments,
       TimeRangeTracker trt) | 
| Segment(CellComparator comparator,
       TimeRangeTracker trt) | 
| Segment(CellSet cellSet,
       CellComparator comparator,
       MemStoreLAB memStoreLAB,
       TimeRangeTracker trt) | 
| SizeMultiWriter(CellComparator comparator,
               int targetCount,
               long targetKvs,
               byte[] left,
               byte[] right) | 
| SizeStripeFlushRequest(CellComparator comparator,
                      int targetCount,
                      long targetKvs) | 
| StoreFileWriter(org.apache.hadoop.fs.FileSystem fs,
               org.apache.hadoop.fs.Path path,
               org.apache.hadoop.conf.Configuration conf,
               CacheConfig cacheConf,
               CellComparator comparator,
               BloomType bloomType,
               long maxKeys,
               InetSocketAddress[] favoredNodes,
               HFileContext fileContext,
               boolean shouldDropCacheBehind)Creates an HFile.Writer that also write helpful meta data. | 
| StripeFlushRequest(CellComparator comparator) | 
| StripeMultiFileWriter(CellComparator comparator) | 
| StripeStoreFileManager(CellComparator kvComparator,
                      org.apache.hadoop.conf.Configuration conf,
                      StripeStoreConfig config) | 
| Modifier and Type | Method and Description | 
|---|---|
| StripeStoreFlusher.StripeFlushRequest | StripeCompactionPolicy. selectFlush(CellComparator comparator,
           StripeCompactionPolicy.StripeInformationProvider si,
           int kvCount) | 
| Modifier and Type | Field and Description | 
|---|---|
| private CellComparator | NewVersionBehaviorTracker. comparator | 
| protected CellComparator | ScanDeleteTracker. comparator | 
| private CellComparator | ScanWildcardColumnTracker. comparator | 
| protected CellComparator | ScanQueryMatcher. rowComparatorRow comparator for the region this query is for | 
| Modifier and Type | Method and Description | 
|---|---|
| CellComparator | NewVersionBehaviorTracker. getCellComparator() | 
| CellComparator | ScanDeleteTracker. getCellComparator() | 
| CellComparator | DeleteTracker. getCellComparator()Return the comparator passed to this delete tracker | 
| Constructor and Description | 
|---|
| NewVersionBehaviorTracker(NavigableSet<byte[]> columns,
                         CellComparator comparartor,
                         int minVersion,
                         int maxVersion,
                         int resultMaxVersions,
                         long oldestUnexpiredTS)Note maxVersion and minVersion must set according to cf's conf, not user's scan parameter. | 
| ScanDeleteTracker(CellComparator comparator) | 
| ScanWildcardColumnTracker(int minVersion,
                         int maxVersion,
                         long oldestUnexpiredTS,
                         CellComparator comparator)Return maxVersions of every row. | 
| Constructor and Description | 
|---|
| VisibilityNewVersionBehaivorTracker(NavigableSet<byte[]> columns,
                                   CellComparator cellComparator,
                                   int minVersion,
                                   int maxVersion,
                                   int resultMaxVersions,
                                   long oldestUnexpiredTS) | 
| VisibilityScanDeleteTracker(CellComparator comparator) | 
| Modifier and Type | Field and Description | 
|---|---|
| (package private) CellComparator | CollectionBackedScanner. comparator | 
| protected CellComparator | BloomContext. comparator | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | Bytes. binarySearch(Cell[] arr,
            Cell key,
            CellComparator comparator)Binary search for keys in indexes. | 
| Constructor and Description | 
|---|
| BloomContext(BloomFilterWriter bloomFilterWriter,
            CellComparator comparator) | 
| CollectionBackedScanner(CellComparator comparator,
                       Cell... array) | 
| CollectionBackedScanner(List<Cell> list,
                       CellComparator comparator) | 
| CollectionBackedScanner(SortedSet<Cell> set,
                       CellComparator comparator) | 
| RowBloomContext(BloomFilterWriter bloomFilterWriter,
               CellComparator comparator) | 
| RowColBloomContext(BloomFilterWriter generalBloomFilterWriter,
                  CellComparator comparator) | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.