Uses of Interface
org.apache.hadoop.hbase.CellComparator
Packages that use CellComparator
- 
Uses of CellComparator in org.apache.hadoop.hbaseClasses in org.apache.hadoop.hbase that implement CellComparatorModifier and TypeClassDescriptionclassCompare two HBase cells.classCompare two HBase cells inner store, skip compare family for better performance.classMethods in org.apache.hadoop.hbase that return CellComparatorModifier and TypeMethodDescriptionstatic CellComparatorCellComparatorImpl.getCellComparator(byte[] tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparatorCellComparatorImpl.getCellComparator(TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparatorInnerStoreCellComparator.getInnerStoreCellComparator(byte[] tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparatorInnerStoreCellComparator.getInnerStoreCellComparator(TableName tableName) Utility method that makes a guess at comparator to use based off passed tableName.static CellComparatorCellComparator.getInstance()A comparator for ordering cells in user-space tables.Methods in org.apache.hadoop.hbase with parameters of type CellComparatorModifier and TypeMethodDescriptionstatic final intPrivateCellUtil.compare(CellComparator comparator, ExtendedCell 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 final intPrivateCellUtil.compareKeyBasedOnColHint(CellComparator comparator, ExtendedCell nextIndexedCell, ExtendedCell 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 final intPrivateCellUtil.compareKeyIgnoresMvcc(CellComparator comparator, Cell left, Cell right) Compares only the key portion of a cell.(package private) static final intPrivateCellUtil.compareWithoutRow(CellComparator comparator, ExtendedCell left, byte[] right, int roffset, int rlength, short rowlength) Compare columnFamily, qualifier, timestamp, and key type (everything except the row).
- 
Uses of CellComparator in org.apache.hadoop.hbase.io.encodingFields in org.apache.hadoop.hbase.io.encoding declared as CellComparatorMethods in org.apache.hadoop.hbase.io.encoding with parameters of type CellComparatorModifier and TypeMethodDescriptionintBufferedDataBlockEncoder.BufferedEncodedSeeker.compareKey(CellComparator comparator, ExtendedCell key) intDataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator, ExtendedCell key) Compare the given key against the current keyintRowIndexSeekerV1.compareKey(CellComparator comparator, ExtendedCell key) 
- 
Uses of CellComparator in org.apache.hadoop.hbase.io.hfileFields in org.apache.hadoop.hbase.io.hfile declared as CellComparatorModifier and TypeFieldDescriptionprivate CellComparatorHFileContext.cellComparatorprivate CellComparatorHFileContextBuilder.cellComparatorprotected CellComparatorCompoundBloomFilterBase.comparatorComparator used to compare Bloom filter keysprotected CellComparatorHFileBlockIndex.CellBasedKeyBlockIndexReader.comparatorNeeded doing lookup on blocks.private CellComparatorNoOpIndexBlockEncoder.NoOpEncodedSeeker.comparatorMethods in org.apache.hadoop.hbase.io.hfile that return CellComparatorModifier and TypeMethodDescriptionFixedFileTrailer.createComparator()(package private) static CellComparatorFixedFileTrailer.createComparator(String comparatorClassName) HFileContext.getCellComparator()HFile.Reader.getComparator()HFileReaderImpl.getComparator()Returns comparatorMethods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type CellComparatorModifier and TypeMethodDescriptionprivate static Class<? extends CellComparator>FixedFileTrailer.getComparatorClass(String comparatorClassName) Methods in org.apache.hadoop.hbase.io.hfile with parameters of type CellComparatorModifier and TypeMethodDescription(package private) static intHFileBlockIndex.BlockIndexReader.binarySearchNonRootIndex(Cell key, ByteBuff nonRootIndex, CellComparator comparator) Performs a binary search over a non-root level index block.intHFileReaderImpl.EncodedScanner.compareKey(CellComparator comparator, ExtendedCell key) intHFileReaderImpl.HFileScannerImpl.compareKey(CellComparator comparator, ExtendedCell key) static ExtendedCellHFileWriterImpl.getMidpoint(CellComparator comparator, ExtendedCell left, ExtendedCell right) Try to return a Cell that falls betweenleftandrightbut that is shorter; i.e.voidHFileIndexBlockEncoder.EncodedSeeker.initRootIndex(HFileBlock blk, int numEntries, CellComparator comparator, int treeLevel) voidNoOpIndexBlockEncoder.NoOpEncodedSeeker.initRootIndex(HFileBlock blk, int numEntries, CellComparator comparator, int treeLevel) static intHFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(ByteBuff nonRootBlock, Cell key, CellComparator comparator) Search for one key using the secondary index in a non-root block.abstract intHFileBlockIndex.BlockIndexReader.rootBlockContainingKey(byte[] key, int offset, int length, CellComparator comp) Finds the root-level index block containing the given key.intHFileBlockIndex.ByteArrayKeyBlockIndexReader.rootBlockContainingKey(byte[] key, int offset, int length, CellComparator comp) intHFileBlockIndex.CellBasedKeyBlockIndexReader.rootBlockContainingKey(byte[] key, int offset, int length, CellComparator comp) HFileContextBuilder.withCellComparator(CellComparator cellComparator) Method parameters in org.apache.hadoop.hbase.io.hfile with type arguments of type CellComparatorModifier and TypeMethodDescriptionvoidFixedFileTrailer.setComparatorClass(Class<? extends CellComparator> klass) Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type CellComparatorModifierConstructorDescriptionCellBasedKeyBlockIndexReader(CellComparator c, int treeLevel) CellBasedKeyBlockIndexReaderV2(CellComparator c, int treeLevel) CellBasedKeyBlockIndexReaderV2(CellComparator c, int treeLevel, HFileIndexBlockEncoder indexBlockEncoder) CompoundBloomFilterWriter(int chunkByteSizeHint, float errorRate, int hashType, int maxFold, boolean cacheOnWrite, CellComparator comparator, BloomType bloomType) each chunk's size in bytes.(package private)HFileContext(boolean useHBaseChecksum, boolean includesMvcc, boolean includesTags, Compression.Algorithm compressAlgo, Compression.HFileDecompressionContext decompressionContext, boolean compressTags, ChecksumType checksumType, int bytesPerChecksum, int blockSize, DataBlockEncoding encoding, Encryption.Context cryptoContext, long fileCreateTime, String hfileName, byte[] columnFamily, byte[] tableName, CellComparator cellComparator, IndexBlockEncoding indexBlockEncoding) 
- 
Uses of CellComparator in org.apache.hadoop.hbase.regionserverFields in org.apache.hadoop.hbase.regionserver declared as CellComparatorModifier and TypeFieldDescriptionprivate final CellComparatorDefaultStoreFileManager.cellComparatorprivate final CellComparatorHRegion.cellComparatorprivate final CellComparatorStripeStoreFileManager.cellComparatorprivate final CellComparatorAbstractMemStore.comparatorprivate CellComparatorHStoreFile.comparatorprotected final CellComparatorRegionScannerImpl.comparatorprivate CellComparatorScanInfo.comparatorprivate final CellComparatorSegment.comparatorprivate CellComparatorStoreContext.Builder.comparatorprivate final CellComparatorStoreContext.comparatorprivate CellComparatorStoreFileWriter.Builder.comparatorprivate final CellComparatorStoreFileWriter.comparatorprivate final CellComparatorStoreScanner.comparatorprotected final CellComparatorStripeMultiFileWriter.comparatorprotected final CellComparatorStripeStoreFlusher.StripeFlushRequest.comparatorprotected CellComparatorKeyValueHeap.KVScannerComparator.kvComparatorMethods in org.apache.hadoop.hbase.regionserver that return CellComparatorModifier and TypeMethodDescriptionHRegion.getCellComparator()Region.getCellComparator()The comparator to be used with the regionprotected CellComparatorAbstractMemStore.getComparator()HStore.getComparator()HStoreFile.getComparator()KeyValueHeap.KVScannerComparator.getComparator()ScanInfo.getComparator()protected CellComparatorSegment.getComparator()Returns the Cell comparator used by this segmentStore.getComparator()StoreContext.getComparator()StoreFile.getComparator()Get the comparator for comparing two cells.StoreFileReader.getComparator()(package private) CellComparatorStoreFileScanner.getComparator()Methods in org.apache.hadoop.hbase.regionserver with parameters of type CellComparatorModifier and TypeMethodDescriptionprotected voidReversedStoreScanner.checkScanOrder(Cell prevKV, Cell kv, CellComparator comparator) protected voidStoreScanner.checkScanOrder(Cell prevKV, Cell kv, CellComparator comparator) Check whether scan as expected orderstatic StoreEngine<?,?, ?, ?> StoreEngine.create(HStore store, org.apache.hadoop.conf.Configuration conf, CellComparator cellComparator) Create the StoreEngine configured for the given Store.protected voidCustomTieredStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected voidDateTieredStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected voidDefaultStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator kvComparator) protected abstract voidStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) Create the StoreEngine's components.protected voidStripeStoreEngine.createComponents(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator comparator) protected final voidStoreEngine.createComponentsOnce(org.apache.hadoop.conf.Configuration conf, HStore store, CellComparator cellComparator) SegmentFactory.createCompositeImmutableSegment(CellComparator comparator, List<ImmutableSegment> segments) private ImmutableSegmentSegmentFactory.createImmutableSegment(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreSegmentsIterator iterator, MemStoreLAB memStoreLAB, int numOfCells, MemStoreCompactionStrategy.Action action, CompactingMemStore.IndexType idxType) SegmentFactory.createImmutableSegment(CellComparator comparator) create empty immutable segment for initializations This ImmutableSegment is used as a place holder for snapshot in Memstore.SegmentFactory.createImmutableSegmentByCompaction(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreSegmentsIterator iterator, int numOfCells, CompactingMemStore.IndexType idxType, MemStoreCompactionStrategy.Action action) SegmentFactory.createImmutableSegmentByMerge(org.apache.hadoop.conf.Configuration conf, CellComparator comparator, MemStoreSegmentsIterator iterator, int numOfCells, List<ImmutableSegment> segments, CompactingMemStore.IndexType idxType, MemStoreCompactionStrategy.Action action) 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 MutableSegmentSegmentFactory.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 KeyValueHeapReversedStoreScanner.newKVHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) protected KeyValueHeapStoreScanner.newKVHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) protected voidStoreScanner.resetKVHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) StoreContext.Builder.withCellComparator(CellComparator comparator) StoreFileWriter.Builder.withCellComparator(CellComparator comparator) Constructors in org.apache.hadoop.hbase.regionserver with parameters of type CellComparatorModifierConstructorDescriptionprotectedAbstractMemStore(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) protectedCellArrayImmutableSegment(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.protectedCellChunkImmutableSegment(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.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) protectedImmutableSegment(CellComparator comparator) ------------------------------------------------------------------------ Empty C-tor to be used only for CompositeImmutableSegmentprotectedImmutableSegment(CellComparator comparator, List<ImmutableSegment> segments) protectedImmutableSegment(CellSet cs, CellComparator comparator, MemStoreLAB memStoreLAB) ------------------------------------------------------------------------ C-tor to be used to build the derived classesKeyValueHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) Constructor.KVScannerComparator(CellComparator kvComparator) ConstructorMemStoreCompactorSegmentsIterator(List<ImmutableSegment> segments, CellComparator comparator, int compactionKVMax, HStore store) MemStoreMergerSegmentsIterator(List<ImmutableSegment> segments, CellComparator comparator, int compactionKVMax) protectedMutableSegment(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) ReversedKeyValueHeap(List<? extends KeyValueScanner> scanners, CellComparator comparator) ReversedKVScannerComparator(CellComparator kvComparator) ConstructorprivateScanInfo(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) protectedSegment(CellComparator comparator, List<ImmutableSegment> segments, TimeRangeTracker trt) protectedSegment(CellComparator comparator, TimeRangeTracker trt) protectedSegment(CellSet<ExtendedCell> 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) privateStoreFileWriter(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path liveFilePath, org.apache.hadoop.fs.Path historicalFilePath, org.apache.hadoop.conf.Configuration conf, CacheConfig cacheConf, BloomType bloomType, long maxKeys, InetSocketAddress[] favoredNodes, HFileContext fileContext, boolean shouldDropCacheBehind, Supplier<Collection<HStoreFile>> compactedFilesSupplier, CellComparator comparator, int maxVersions, boolean newVersionBehavior) 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) 
- 
Uses of CellComparator in org.apache.hadoop.hbase.regionserver.compactionsMethods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type CellComparatorModifier and TypeMethodDescriptionStripeCompactionPolicy.selectFlush(CellComparator comparator, StripeCompactionPolicy.StripeInformationProvider si, int kvCount) 
- 
Uses of CellComparator in org.apache.hadoop.hbase.regionserver.querymatcherFields in org.apache.hadoop.hbase.regionserver.querymatcher declared as CellComparatorModifier and TypeFieldDescriptionprivate CellComparatorNewVersionBehaviorTracker.comparatorprotected final CellComparatorScanDeleteTracker.comparatorprivate final CellComparatorScanWildcardColumnTracker.comparatorprotected final CellComparatorScanQueryMatcher.rowComparatorRow comparator for the region this query is forMethods in org.apache.hadoop.hbase.regionserver.querymatcher that return CellComparatorModifier and TypeMethodDescriptionDeleteTracker.getCellComparator()Return the comparator passed to this delete trackerNewVersionBehaviorTracker.getCellComparator()ScanDeleteTracker.getCellComparator()Constructors in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type CellComparatorModifierConstructorDescriptionNewVersionBehaviorTracker(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.
- 
Uses of CellComparator in org.apache.hadoop.hbase.security.visibilityConstructors in org.apache.hadoop.hbase.security.visibility with parameters of type CellComparatorModifierConstructorDescriptionVisibilityNewVersionBehaivorTracker(NavigableSet<byte[]> columns, CellComparator cellComparator, int minVersion, int maxVersion, int resultMaxVersions, long oldestUnexpiredTS) VisibilityScanDeleteTracker(CellComparator comparator) 
- 
Uses of CellComparator in org.apache.hadoop.hbase.utilFields in org.apache.hadoop.hbase.util declared as CellComparatorModifier and TypeFieldDescriptionprotected CellComparatorBloomContext.comparator(package private) final CellComparatorCollectionBackedScanner.comparatorMethods in org.apache.hadoop.hbase.util with parameters of type CellComparatorModifier and TypeMethodDescriptionstatic intBytes.binarySearch(Cell[] arr, Cell key, CellComparator comparator) Binary search for keys in indexes.Constructors in org.apache.hadoop.hbase.util with parameters of type CellComparatorModifierConstructorDescriptionBloomContext(BloomFilterWriter bloomFilterWriter, CellComparator comparator) CollectionBackedScanner(List<ExtendedCell> list, CellComparator comparator) CollectionBackedScanner(SortedSet<ExtendedCell> set, CellComparator comparator) CollectionBackedScanner(CellComparator comparator, ExtendedCell... array) RowBloomContext(BloomFilterWriter bloomFilterWriter, CellComparator comparator) RowColBloomContext(BloomFilterWriter generalBloomFilterWriter, CellComparator comparator) RowPrefixFixedLengthBloomContext(BloomFilterWriter bloomFilterWriter, CellComparator comparator, int prefixLength)