Uses of Interface
org.apache.hadoop.hbase.ExtendedCell
Packages that use ExtendedCell
Package
Description
Provides HBase Client
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next().Provides implementations of
HFile and HFile
BlockCache.Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
Provides an HBase Thrift
service.
-
Uses of ExtendedCell in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement ExtendedCellModifier and TypeClassDescriptionclassThis class is a server side extension to theCellinterface.classThis is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).classThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassclassAn HBase Key/Value.static classA simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.classAn extension of the ByteBufferKeyValue where the tags length is always 0classAn extension of the KeyValue where the tags length is always 0private static classThese cells are used in reseeks/seeks to improve the read performance.private static classThese cells are used in reseeks/seeks to improve the read performance.private static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static classprivate static class(package private) static class(package private) static classThis can be used when a Cell has to change with addition/removal of one or more tags.(package private) static class(package private) static classclassThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassThis class is an extension to KeyValue where rowLen and keyLen are cached.classThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Fields in org.apache.hadoop.hbase declared as ExtendedCellMethods in org.apache.hadoop.hbase that return ExtendedCellModifier and TypeMethodDescriptionExtendedCellBuilder.build()ExtendedCellBuilderImpl.build()(package private) static ExtendedCellHFilePerformanceEvaluation.createCell(byte[] keyRow) (package private) static ExtendedCellHFilePerformanceEvaluation.createCell(byte[] keyRow, byte[] value) (package private) static ExtendedCellHFilePerformanceEvaluation.createCell(int i) (package private) static ExtendedCellHFilePerformanceEvaluation.createCell(int i, byte[] value) HFile is Cell-based.static ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, byte[] value, byte[] tags) static ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCellPrivateCellUtil.createFirstDeleteFamilyCellOnRow(byte[] row, byte[] fam) Create a Delete Family Cell for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.static ExtendedCellPrivateCellUtil.createFirstOnNextRow(Cell cell) static ExtendedCellPrivateCellUtil.createFirstOnRow(byte[] row) static ExtendedCellPrivateCellUtil.createFirstOnRow(byte[] row, byte[] family, byte[] col) static ExtendedCellPrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength) static ExtendedCellPrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength) static ExtendedCellPrivateCellUtil.createFirstOnRow(Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static ExtendedCellPrivateCellUtil.createFirstOnRowCol(Cell cell) static ExtendedCellPrivateCellUtil.createFirstOnRowCol(Cell cell, byte[] qArray, int qoffest, int qlength) Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.static ExtendedCellPrivateCellUtil.createFirstOnRowColTS(Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static ExtendedCellPrivateCellUtil.createFirstOnRowFamily(Cell cell, byte[] fArray, int foff, int flen) static ExtendedCellPrivateCellUtil.createLastOnRow(byte[] row) static ExtendedCellPrivateCellUtil.createLastOnRow(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static ExtendedCellPrivateCellUtil.createLastOnRowCol(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static ExtendedCellPrivateCellUtil.createNextOnRowCol(ExtendedCell cell) Return a new cell is located following input cell.(package private) static ExtendedCellPrivateCellUtil.createNextOnRowCol(ExtendedCell cell, long ts, byte type) ExtendedCellScanner.current()ByteBufferKeyValue.deepClone()default ExtendedCellExtendedCell.deepClone()Does a deep copy of the contents to a new memory area and returns it as a new cell.KeyValue.deepClone()NoTagsByteBufferKeyValue.deepClone()NoTagsKeyValue.deepClone()PrivateCellUtil.TagRewriteByteBufferExtendedCell.deepClone()PrivateCellUtil.TagRewriteCell.deepClone()PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell.deepClone()PrivateCellUtil.ValueAndTagRewriteCell.deepClone()static ExtendedCellPrivateCellUtil.ensureExtendedCell(Cell cell) In fact, in HBase, allCells areExtendedCells.protected abstract ExtendedCellExtendedCellBuilderImpl.innerBuild()IndividualBytesFieldCellBuilder.innerBuild()protected ExtendedCellKeyValueBuilder.innerBuild()Methods in org.apache.hadoop.hbase with parameters of type ExtendedCellModifier and TypeMethodDescriptionstatic intKeyValueUtil.appendKeyTo(ExtendedCell cell, byte[] output, int offset) static intKeyValueUtil.appendKeyTo(ExtendedCell cell, ByteBuffer buf, int offset) static intKeyValueUtil.appendTo(ExtendedCell cell, ByteBuffer buf, int offset, boolean withTags) Copy the Cell content into the passed buf in KeyValue serialization format.static intKeyValueUtil.appendToByteArray(ExtendedCell cell, byte[] output, int offset, boolean withTags) copy key and valueprivate intKeyValue.calculateHashForKey(ExtendedCell cell) TagUtil.carryForwardTags(List<Tag> tagsOrNull, ExtendedCell cell) Add totagsOrNullany Tagscellis carrying or null if none.TagUtil.carryForwardTags(ExtendedCell cell) Returns A List<Tag> of any Tags found incellelse null.static byte[]PrivateCellUtil.cloneTags(ExtendedCell cell) static 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.(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).static voidPrivateCellUtil.compressTags(OutputStream out, ExtendedCell cell, TagCompressionContext tagCompressionContext) Compresses the tags to the given outputstream using the TagcompressionContextstatic byte[]TagUtil.concatTags(byte[] tags, ExtendedCell cell) static ByteBufferKeyValueUtil.copyKeyToNewByteBuffer(ExtendedCell cell) The position will be set to the beginning of the new ByteBufferstatic intPrivateCellUtil.copyTagsTo(ExtendedCell cell, byte[] destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic intPrivateCellUtil.copyTagsTo(ExtendedCell cell, ByteBuffer destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic byte[]KeyValueUtil.copyToNewByteArray(ExtendedCell cell) static KeyValueKeyValueUtil.copyToNewKeyValue(ExtendedCell cell) copy the cell to create a new keyvaluestatic ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, byte[] value, byte[] tags) static ExtendedCellPrivateCellUtil.createCell(ExtendedCell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(ExtendedCell[] cellArray) Returns CellScanner interface overcellArraystatic ExtendedCellPrivateCellUtil.createNextOnRowCol(ExtendedCell cell) Return a new cell is located following input cell.(package private) static ExtendedCellPrivateCellUtil.createNextOnRowCol(ExtendedCell cell, long ts, byte type) static KeyValueKeyValueUtil.ensureKeyValue(ExtendedCell cell) Deprecated.without any replacement.static booleanPrivateCellUtil.equals(ExtendedCell a, ExtendedCell b) static booleanPrivateCellUtil.equalsIgnoreMvccVersion(ExtendedCell a, ExtendedCell b) special case for Cell.equalsstatic ByteRangePrivateCellUtil.fillTagRange(ExtendedCell cell, ByteRange range) static intPrivateCellUtil.findCommonPrefixInFlatKey(ExtendedCell c1, ExtendedCell c2, boolean bypassFamilyCheck, boolean withTsType) Find length of common prefix in keys of the cells, considering key as byte[] if serialized inKeyValue.static byte[]PrivateCellUtil.getCellKeySerializedAsKeyValueKey(ExtendedCell cell) This method exists just to encapsulate how we serialize keys.PrivateCellUtil.getTag(ExtendedCell cell, byte type) Retrieve Cell's first tag, matching the passed in typePrivateCellUtil.getTags(ExtendedCell cell) Return tags in the given Cell as a Liststatic booleanPrivateCellUtil.isDeleteColumnOrFamily(ExtendedCell cell) Returns True if this cell is a delete family or column type.static booleanPrivateCellUtil.isDeleteColumns(ExtendedCell cell) static booleanPrivateCellUtil.isDeleteColumnVersion(ExtendedCell cell) static booleanPrivateCellUtil.isDeleteFamily(ExtendedCell cell) static booleanPrivateCellUtil.isDeleteFamilyVersion(ExtendedCell cell) static booleanPrivateCellUtil.isDeleteType(ExtendedCell cell) Returns True if this cell is aKeyValue.Type.Deletetype.static booleanPrivateCellUtil.matchingTags(ExtendedCell left, ExtendedCell right) static booleanPrivateCellUtil.matchingTags(ExtendedCell left, ExtendedCell right, int llength, int rlength) static booleanPrivateCellUtil.matchingType(ExtendedCell a, ExtendedCell b) PrivateCellUtil.tagsIterator(ExtendedCell cell) Utility method to iterate through the tags in the given cell.static KeyValueKeyValueUtil.toNewKeyCell(ExtendedCell cell) Copies the key to a new KeyValuestatic booleanPrivateCellUtil.updateLatestStamp(ExtendedCell cell, long ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP.(package private) static intPrivateCellUtil.ValueAndTagRewriteCell.write(OutputStream out, boolean withTags, ExtendedCell cell, byte[] value, byte[] tags) Made into a static method so as to reuse the logic within ValueAndTagRewriteByteBufferExtendedCell(package private) static voidPrivateCellUtil.ValueAndTagRewriteCell.write(ByteBuffer buf, int offset, ExtendedCell cell, byte[] value, byte[] tags) Made into a static method so as to reuse the logic within ValueAndTagRewriteByteBufferExtendedCellstatic voidPrivateCellUtil.writeFlatKey(ExtendedCell cell, DataOutput out) Writes the Cell's key part as it would have serialized in a KeyValue.static intPrivateCellUtil.writeFlatKey(ExtendedCell cell, OutputStream out) static voidPrivateCellUtil.writeTags(OutputStream out, ExtendedCell cell, int tagsLength) Writes the tag from the given cell to the output streamstatic voidPrivateCellUtil.writeValue(OutputStream out, ExtendedCell cell, int vlength) Writes the value from the given cell to the output streamMethod parameters in org.apache.hadoop.hbase with type arguments of type ExtendedCellModifier and TypeMethodDescriptionstatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterable<ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterablestatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(Iterator<ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterableor null ifcellsis nullstatic ExtendedCellScannerPrivateCellUtil.createExtendedCellScanner(NavigableMap<byte[], List<ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerKeyValueUtil.ensureKeyValues(List<ExtendedCell> cells) Deprecated.Constructors in org.apache.hadoop.hbase with parameters of type ExtendedCellModifierConstructorDescriptionTagRewriteCell(ExtendedCell cell, byte[] tags) Construct a TagRewriteCellValueAndTagRewriteCell(ExtendedCell cell, byte[] value, byte[] tags) -
Uses of ExtendedCell in org.apache.hadoop.hbase.backup.mapreduce
Methods in org.apache.hadoop.hbase.backup.mapreduce with parameters of type ExtendedCellModifier and TypeMethodDescriptionprivate org.apache.hadoop.io.WritableComparable<?>MapReduceHFileSplitterJob.HFileCellMapper.wrap(ExtendedCell cell) -
Uses of ExtendedCell in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCell[]Result.cellsprivate ExtendedCellAllowPartialScanResultCache.lastCellprivate ExtendedCellBatchScanResultCache.lastCellFields in org.apache.hadoop.hbase.client with type parameters of type ExtendedCellModifier and TypeFieldDescriptionprotected final NavigableMap<byte[],List<ExtendedCell>> Mutation.familyMapMethods in org.apache.hadoop.hbase.client that return ExtendedCellModifier and TypeMethodDescriptionResult.current()For client users: You should only use the return value as aCell,ExtendedCellis marked as IA.Private which means there is no guarantee about its API stability.static ExtendedCell[]ClientInternalHelper.getExtendedRawCells(Result result) (package private) ExtendedCell[]Result.rawExtendedCells()Methods in org.apache.hadoop.hbase.client that return types with arguments of type ExtendedCellModifier and TypeMethodDescription(package private) List<ExtendedCell>Mutation.getCellList(byte[] family) Creates an empty list if one doesn't exist for the given column family or else it returns the associated list of Cell objects.static NavigableMap<byte[],List<ExtendedCell>> ClientInternalHelper.getExtendedFamilyCellMap(Mutation m) Methods in org.apache.hadoop.hbase.client with parameters of type ExtendedCellModifier and TypeMethodDescriptionMutation.cellToStringMap(ExtendedCell c) (package private) static ResultResult.create(ExtendedCell[] cells) (package private) static ResultResult.create(ExtendedCell[] cells, Boolean exists, boolean stale) (package private) static ResultResult.create(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) static ResultClientInternalHelper.createResult(ExtendedCell[] cells) static ResultClientInternalHelper.createResult(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) (package private) static ResultConnectionUtils.filterCells(Result result, ExtendedCell keepCellsAfter) Constructors in org.apache.hadoop.hbase.client with parameters of type ExtendedCellModifierConstructorDescriptionprivateResult(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Private ctor. -
Uses of ExtendedCell in org.apache.hadoop.hbase.codec
Fields in org.apache.hadoop.hbase.codec declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCellBaseDecoder.currentprotected ExtendedCellKeyValueCodec.ByteBuffKeyValueDecoder.currentMethods in org.apache.hadoop.hbase.codec that return ExtendedCellModifier and TypeMethodDescriptionprotected ExtendedCellKeyValueCodec.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len) protected ExtendedCellKeyValueCodec.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len) protected ExtendedCellKeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len) protected ExtendedCellKeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len) BaseDecoder.current()KeyValueCodec.ByteBuffKeyValueDecoder.current()protected abstract ExtendedCellBaseDecoder.parseCell()Extract a Cell.protected ExtendedCellCellCodec.CellDecoder.parseCell()protected ExtendedCellCellCodecWithTags.CellDecoder.parseCell()protected ExtendedCellKeyValueCodec.KeyValueDecoder.parseCell()protected ExtendedCellKeyValueCodecWithTags.KeyValueDecoder.parseCell()protected ExtendedCellMessageCodec.MessageDecoder.parseCell()Methods in org.apache.hadoop.hbase.codec with parameters of type ExtendedCellModifier and TypeMethodDescriptionabstract voidBaseEncoder.write(ExtendedCell cell) voidCellCodec.CellEncoder.write(ExtendedCell cell) voidCellCodecWithTags.CellEncoder.write(ExtendedCell cell) voidKeyValueCodec.KeyValueEncoder.write(ExtendedCell cell) voidKeyValueCodecWithTags.KeyValueEncoder.write(ExtendedCell cell) voidMessageCodec.MessageEncoder.write(ExtendedCell cell) -
Uses of ExtendedCell in org.apache.hadoop.hbase.coprocessor.example
Method parameters in org.apache.hadoop.hbase.coprocessor.example with type arguments of type ExtendedCellModifier and TypeMethodDescriptionbooleanDelegatingInternalScanner.next(List<? super ExtendedCell> result, ScannerContext scannerContext) -
Uses of ExtendedCell in org.apache.hadoop.hbase.coprocessor.example.row.stats
Method parameters in org.apache.hadoop.hbase.coprocessor.example.row.stats with type arguments of type ExtendedCellModifier and TypeMethodDescriptionprivate voidRowStatisticsCompactionObserver.RowStatisticsScanner.consumeCells(List<? super ExtendedCell> result) booleanRowStatisticsCompactionObserver.RowStatisticsScanner.next(List<? super ExtendedCell> result) booleanRowStatisticsCompactionObserver.RowStatisticsScanner.next(List<? super ExtendedCell> result, ScannerContext scannerContext) -
Uses of ExtendedCell in org.apache.hadoop.hbase.filter
Classes in org.apache.hadoop.hbase.filter that implement ExtendedCellModifier and TypeClassDescription(package private) static class(package private) static classFields in org.apache.hadoop.hbase.filter declared as ExtendedCellMethods in org.apache.hadoop.hbase.filter with parameters of type ExtendedCellConstructors in org.apache.hadoop.hbase.filter with parameters of type ExtendedCell -
Uses of ExtendedCell in org.apache.hadoop.hbase.io
Fields in org.apache.hadoop.hbase.io declared as ExtendedCellFields in org.apache.hadoop.hbase.io with type parameters of type ExtendedCellMethods in org.apache.hadoop.hbase.io that return types with arguments of type ExtendedCellModifier and TypeMethodDescriptionHalfStoreFileReader.getFirstKey()HalfStoreFileReader.getLastKey()HalfStoreFileReader.midKey()Methods in org.apache.hadoop.hbase.io with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidCellOutputStream.write(ExtendedCell cell) Implementation must copy the entire state of the Cell. -
Uses of ExtendedCell in org.apache.hadoop.hbase.io.encoding
Classes in org.apache.hadoop.hbase.io.encoding that implement ExtendedCellModifier and TypeClassDescriptionprotected static classprotected static classCopies only the key part of the keybuffer by doing a deep copy and passes the seeker state members for taking a clone.Fields in org.apache.hadoop.hbase.io.encoding declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCellRowIndexEncoderV1.lastCellThe Cell previously appended.protected ExtendedCellEncodingState.prevCellThe previous Cell the encoder encoded.Methods in org.apache.hadoop.hbase.io.encoding that return ExtendedCellModifier and TypeMethodDescriptionprotected ExtendedCellAbstractDataBlockEncoder.createFirstKeyCell(ByteBuffer key, int keyLength) BufferedDataBlockEncoder.OffheapDecodedExtendedCell.deepClone()BufferedDataBlockEncoder.OnheapDecodedCell.deepClone()BufferedDataBlockEncoder.BufferedEncodedSeeker.getCell()DataBlockEncoder.EncodedSeeker.getCell()Returns the Cell at the current position.RowIndexSeekerV1.getCell()CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) DataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) Return first key in block as a cell.DiffKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) FastDiffDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) RowIndexCodecV1.getFirstKeyCellInBlock(ByteBuff block) BufferedDataBlockEncoder.BufferedEncodedSeeker.getKey()DataBlockEncoder.EncodedSeeker.getKey()From the current position creates a cell using the key part of the current bufferRowIndexSeekerV1.getKey()BufferedDataBlockEncoder.SeekerState.toCell()RowIndexSeekerV1.SeekerState.toCell()private ExtendedCellBufferedDataBlockEncoder.SeekerState.toOffheapCell(ByteBuffer valAndTagsBuffer, int vOffset, int tagsLenSerializationSize) private ExtendedCellBufferedDataBlockEncoder.SeekerState.toOnheapCell(ByteBuffer valAndTagsBuffer, int vOffset, int tagsLenSerializationSize) Methods in org.apache.hadoop.hbase.io.encoding that return types with arguments of type ExtendedCellModifier and TypeMethodDescriptionEncodedDataBlock.getIterator(int headerSize) Provides access to compressed value.Methods in org.apache.hadoop.hbase.io.encoding with parameters of type ExtendedCellModifier and TypeMethodDescriptionprotected final intBufferedDataBlockEncoder.afterEncodingKeyValue(ExtendedCell cell, DataOutputStream out, HFileBlockDefaultEncodingContext encodingCtx) Returns unencoded size addedprotected booleanRowIndexEncoderV1.checkRow(ExtendedCell cell) intBufferedDataBlockEncoder.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) private intBufferedDataBlockEncoder.BufferedEncodedSeeker.compareTypeBytes(ExtendedCell key, ExtendedCell right) private intDiffKeyDeltaEncoder.compressSingleKeyValue(DataOutputStream out, ExtendedCell cell, ExtendedCell prevCell) private intFastDiffDeltaEncoder.compressSingleKeyValue(DataOutputStream out, ExtendedCell cell, ExtendedCell prevCell) voidBufferedDataBlockEncoder.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) voidDataBlockEncoder.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.voidRowIndexCodecV1.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) abstract intBufferedDataBlockEncoder.internalEncode(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingCtx, DataOutputStream out) intCopyKeyDataBlockEncoder.internalEncode(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intDiffKeyDeltaEncoder.internalEncode(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intFastDiffDeltaEncoder.internalEncode(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intPrefixKeyDeltaEncoder.internalEncode(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intBufferedDataBlockEncoder.BufferedEncodedSeeker.seekToKeyInBlock(ExtendedCell seekCell, boolean seekBefore) intDataBlockEncoder.EncodedSeeker.seekToKeyInBlock(ExtendedCell key, boolean seekBefore) Moves the seeker position within the current block to: the last key that that is less than or equal to the given key ifseekBeforeis false the last key that is strictly less than the given key ifseekBeforeis true.intRowIndexSeekerV1.seekToKeyInBlock(ExtendedCell seekCell, boolean seekBefore) intNoneEncoder.write(ExtendedCell cell) voidRowIndexEncoderV1.write(ExtendedCell cell) private voidPrefixKeyDeltaEncoder.writeKeyExcludingCommon(ExtendedCell cell, int commonPrefix, DataOutputStream out) -
Uses of ExtendedCell in org.apache.hadoop.hbase.io.hfile
Fields in org.apache.hadoop.hbase.io.hfile declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCell[]HFileBlockIndex.CellBasedKeyBlockIndexReader.blockKeysprivate ExtendedCell[]NoOpIndexBlockEncoder.NoOpEncodedSeeker.blockKeysprotected ExtendedCellHFileWriterImpl.firstCellInBlockFirst cell in a block.protected ExtendedCellHFileWriterImpl.lastCellThe Cell previously appended.private ExtendedCellHFileWriterImpl.lastCellOfPreviousBlockThe last(stop) Cell of the previous data block.private ExtendedCellHFileInfo.lastKeyCellLast key in the file.private final ExtendedCellBlockWithScanInfo.nextIndexedKeyThe first key in the next block following this one in the HFile.protected ExtendedCellHFileReaderImpl.HFileScannerImpl.nextIndexedKeyThe next indexed key is to keep track of the indexed key of the next data block.private ExtendedCellCompoundBloomFilterWriter.prevCellThe prev Cell that was processedFields in org.apache.hadoop.hbase.io.hfile with type parameters of type ExtendedCellModifier and TypeFieldDescriptionprivate AtomicReference<ExtendedCell>HFileBlockIndex.CellBasedKeyBlockIndexReader.midKeyPre-computed mid-keyprivate AtomicReference<ExtendedCell>NoOpIndexBlockEncoder.NoOpEncodedSeeker.midKeyPre-computed mid-keyMethods in org.apache.hadoop.hbase.io.hfile that return ExtendedCellModifier and TypeMethodDescriptionHFileReaderImpl.EncodedScanner.getCell()HFileReaderImpl.HFileScannerImpl.getCell()HFileScanner.getCell()Returns Instance ofExtendedCell.protected ExtendedCellHFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(HFileBlock curBlock) protected ExtendedCellHFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(HFileBlock curBlock) HFileReaderImpl.EncodedScanner.getKey()HFileReaderImpl.HFileScannerImpl.getKey()HFileScanner.getKey()Gets the current key in the form of a cell.HFileInfo.getLastKeyCell()static ExtendedCellHFileWriterImpl.getMidpoint(CellComparator comparator, ExtendedCell left, ExtendedCell right) Try to return a Cell that falls betweenleftandrightbut that is shorter; i.e.BlockWithScanInfo.getNextIndexedKey()HFileReaderImpl.HFileScannerImpl.getNextIndexedKey()HFileScanner.getNextIndexedKey()Returns the next key in the index (the key to seek to the next block)HFileBlockIndex.CellBasedKeyBlockIndexReader.getRootBlockKey(int i) from 0 to- 1HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.getRootBlockKey(int i) from 0 to- 1HFileIndexBlockEncoder.EncodedSeeker.getRootBlockKey(int i) NoOpIndexBlockEncoder.NoOpEncodedSeeker.getRootBlockKey(int i) HFileBlockIndex.CellBasedKeyBlockIndexReader.midkey(HFile.CachingBlockReader cachingBlockReader) HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.midkey(HFile.CachingBlockReader cachingBlockReader) HFileIndexBlockEncoder.EncodedSeeker.midkey(HFile.CachingBlockReader cachingBlockReader) NoOpIndexBlockEncoder.NoOpEncodedSeeker.midkey(HFile.CachingBlockReader cachingBlockReader) Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type ExtendedCellModifier and TypeMethodDescriptionHFile.Reader.getFirstKey()HFileReaderImpl.getFirstKey()HFile.Reader.getLastKey()HFileReaderImpl.getLastKey()HFile.Reader.midKey()HFileReaderImpl.midKey()Methods in org.apache.hadoop.hbase.io.hfile with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidCompoundBloomFilterWriter.append(ExtendedCell cell) voidHFileWriterImpl.append(ExtendedCell cell) Add key/value to file.intHFileReaderImpl.EncodedScanner.compareKey(CellComparator comparator, ExtendedCell key) intHFileReaderImpl.HFileScannerImpl.compareKey(CellComparator comparator, ExtendedCell key) voidHFileDataBlockEncoder.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.voidHFileDataBlockEncoderImpl.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) voidNoOpDataBlockEncoder.encode(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) static ExtendedCellHFileWriterImpl.getMidpoint(CellComparator comparator, ExtendedCell left, ExtendedCell right) Try to return a Cell that falls betweenleftandrightbut that is shorter; i.e.protected intHFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey(HFileBlock seekToBlock, ExtendedCell nextIndexedKey, boolean rewind, ExtendedCell key, boolean seekBefore) protected intHFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey(HFileBlock seekToBlock, ExtendedCell nextIndexedKey, boolean rewind, ExtendedCell key, boolean seekBefore) abstract BlockWithScanInfoHFileBlockIndex.BlockIndexReader.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) Return the BlockWithScanInfo, a data structure which contains the Data HFileBlock with other scan info such as the key that starts the next HFileBlock.HFileBlockIndex.ByteArrayKeyBlockIndexReader.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileBlockIndex.CellBasedKeyBlockIndexReader.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) NoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) intHFileReaderImpl.HFileScannerImpl.reseekTo(ExtendedCell key) intHFileScanner.reseekTo(ExtendedCell cell) Reseek to or just before the passedcell.booleanHFileReaderImpl.HFileScannerImpl.seekBefore(ExtendedCell key) booleanHFileScanner.seekBefore(ExtendedCell cell) Consider the cell stream of all the cells in the file,c[0] ..intHFileReaderImpl.HFileScannerImpl.seekTo(ExtendedCell key) intHFileReaderImpl.HFileScannerImpl.seekTo(ExtendedCell key, boolean rewind) An internal API function.intHFileScanner.seekTo(ExtendedCell cell) SeekTo or just before the passedcell.HFileBlockIndex.BlockIndexReader.seekToDataBlock(ExtendedCell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) Return the data block which contains this key.private voidHFileWriterImpl.trackTimestamps(ExtendedCell cell) Record the earliest Put timestamp.(package private) voidHFileBlock.Writer.write(ExtendedCell cell) Writes the Cell to this blockConstructors in org.apache.hadoop.hbase.io.hfile with parameters of type ExtendedCellModifierConstructorDescriptionBlockWithScanInfo(HFileBlock hFileBlock, ExtendedCell nextIndexedKey) -
Uses of ExtendedCell in org.apache.hadoop.hbase.mapreduce
Fields in org.apache.hadoop.hbase.mapreduce declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCellKeyOnlyCellComparable.cellprivate ExtendedCellImport.CellWritableComparable.kvMethods in org.apache.hadoop.hbase.mapreduce that return ExtendedCellModifier and TypeMethodDescriptionprivate static ExtendedCellImport.convertKv(ExtendedCell kv, Map<byte[], byte[]> cfRenameMap) static ExtendedCellImport.filterKv(Filter filter, ExtendedCell c) Attempt to filter out the keyvalueKeyOnlyCellComparable.getCell()Methods in org.apache.hadoop.hbase.mapreduce with parameters of type ExtendedCellModifier and TypeMethodDescriptionprivate static ExtendedCellImport.convertKv(ExtendedCell kv, Map<byte[], byte[]> cfRenameMap) ExtendedCellSerialization.ExtendedCellDeserializer.deserialize(ExtendedCell ignore) static ExtendedCellImport.filterKv(Filter filter, ExtendedCell c) Attempt to filter out the keyvaluevoidExtendedCellSerialization.ExtendedCellSerializer.serialize(ExtendedCell kv) private org.apache.hadoop.io.WritableComparable<?>WALPlayer.WALKeyValueMapper.wrapKey(byte[] key, ExtendedCell cell) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type ExtendedCellModifier and TypeMethodDescriptionExtendedCellSerialization.getDeserializer(Class<ExtendedCell> t) ExtendedCellSerialization.getSerializer(Class<ExtendedCell> c) Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type ExtendedCell -
Uses of ExtendedCell in org.apache.hadoop.hbase.mob
Fields in org.apache.hadoop.hbase.mob declared as ExtendedCellMethods in org.apache.hadoop.hbase.mob that return ExtendedCellModifier and TypeMethodDescriptionstatic ExtendedCellMobUtils.createMobRefCell(ExtendedCell cell, byte[] fileName, byte[] refCellTags) static ExtendedCellMobUtils.createMobRefCell(ExtendedCell cell, byte[] fileName, Tag tableNameTag) Creates a mob reference KeyValue.MobCell.getCell()Methods in org.apache.hadoop.hbase.mob with parameters of type ExtendedCellModifier and TypeMethodDescriptionstatic ExtendedCellMobUtils.createMobRefCell(ExtendedCell cell, byte[] fileName, byte[] refCellTags) static ExtendedCellMobUtils.createMobRefCell(ExtendedCell cell, byte[] fileName, Tag tableNameTag) Creates a mob reference KeyValue.MobUtils.getTableName(ExtendedCell cell) Get the table name from when this cell was written into a mob hfile as a TableName.MobUtils.getTableNameString(ExtendedCell cell) Gets the table name from when this cell was written into a mob hfile as a string.MobUtils.getTableNameTag(ExtendedCell cell) Gets the table name tag.static booleanMobUtils.isMobReferenceCell(ExtendedCell cell) Whether the current cell is a mob reference cell.MobFile.readCell(ExtendedCell search, boolean cacheMobBlocks) Reads a cell from the mob file.MobFile.readCell(ExtendedCell search, boolean cacheMobBlocks, long readPt) Reads a cell from the mob file.Constructors in org.apache.hadoop.hbase.mob with parameters of type ExtendedCellModifierConstructorDescriptionMobCell(ExtendedCell cell) MobCell(ExtendedCell cell, StoreFileScanner sfScanner) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement ExtendedCellModifier and TypeClassDescriptionclassByteBuffer based cell which has the chunkid at the 0th offsetclassByteBuffer based cell which has the chunkid at the 0th offset and with no tagsFields in org.apache.hadoop.hbase.regionserver declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCellStoreFileScanner.curprotected ExtendedCellSegmentScanner.currentprivate ExtendedCellSnapshotSegmentScanner.currentprivate ExtendedCellStoreFileScanner.delayedSeekKVprivate ExtendedCellStoreFileWriter.deleteColumnprivate ExtendedCellStoreFileWriter.deleteFamilyprotected ExtendedCellRegionScannerImpl.joinedContinuationRowIf the joined heap data gathering is interrupted due to scan limits, this will contain the row for which we are populating the values.private ExtendedCellSegmentScanner.lastprivate ExtendedCellStoreFileWriter.lastCellstatic final ExtendedCellKeyValueScanner.NO_NEXT_INDEXED_KEYThe byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.private ExtendedCellStoreScanner.prevCellprivate ExtendedCellStoreFileScanner.previousRowprivate ExtendedCellSegmentScanner.stopSkippingKVsRowFields in org.apache.hadoop.hbase.regionserver with type parameters of type ExtendedCellModifier and TypeFieldDescriptionprivate AtomicReference<CellSet<ExtendedCell>>Segment.cellSetprivate List<ExtendedCell>StoreFileWriter.deleteColumnVersionListprivate List<ExtendedCell>StoreFileWriter.deleteFamilyVersionListprivate Optional<ExtendedCell>HStoreFile.firstKeyprotected Iterator<ExtendedCell>SegmentScanner.iterprivate Iterator<ExtendedCell>SnapshotSegmentScanner.iterprivate final List<ExtendedCell>MemStoreCompactorSegmentsIterator.kvsprivate Iterator<ExtendedCell>MemStoreCompactorSegmentsIterator.kvsIteratorprivate Optional<ExtendedCell>HStoreFile.lastKeyprotected Function<ExtendedCell,Long> DateTieredMultiFileWriter.tieringFunctionMethods in org.apache.hadoop.hbase.regionserver that return ExtendedCellModifier and TypeMethodDescriptionprivate ExtendedCellMemStoreLABImpl.copyBBECellInto(ByteBufferExtendedCell cell, int maxAlloc) Mostly a duplicate of#copyCellInto(Cell, int)} done for perf sake.private static ExtendedCellMemStoreLABImpl.copyBBECToChunkCell(ByteBufferExtendedCell cell, ByteBuffer buf, int offset, int len) Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid out of itImmutableMemStoreLAB.copyCellInto(ExtendedCell cell) MemStoreLAB.copyCellInto(ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.copyCellInto(ExtendedCell cell) private ExtendedCellMemStoreLABImpl.copyCellInto(ExtendedCell cell, int maxAlloc) private ExtendedCellCellChunkImmutableSegment.copyCellIntoMSLAB(ExtendedCell cell, MemStoreSizing memstoreSizing) private static ExtendedCellMemStoreLABImpl.copyToChunkCell(ExtendedCell cell, ByteBuffer buf, int offset, int len) Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid out of itprivate static ExtendedCellMemStoreLABImpl.createChunkCell(ByteBuffer buf, int offset, int len, int tagsLen, long sequenceId) private static ExtendedCellAbstractMemStore.deepCopyIfNeeded(ExtendedCell cell) (package private) ExtendedCellMutableSegment.first()Returns the first cell in the segmentImmutableMemStoreLAB.forceCopyOfBigCellInto(ExtendedCell cell) The process of merging assumes all cells are allocated on mslab.MemStoreLAB.forceCopyOfBigCellInto(ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.forceCopyOfBigCellInto(ExtendedCell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.private ExtendedCellSegmentScanner.getHighest(ExtendedCell first, ExtendedCell second) Private internal method that returns the higher of the two key values, or null if they are both nullprotected ExtendedCellAbstractMemStore.getLowest(ExtendedCell a, ExtendedCell b) Returns Return lowest of a or b or null if both a and b are nullKeyValueHeap.getNextIndexedKey()KeyValueScanner.getNextIndexedKey()NonLazyKeyValueScanner.getNextIndexedKey()SegmentScanner.getNextIndexedKey()StoreFileScanner.getNextIndexedKey()StoreScanner.getNextIndexedKey()protected ExtendedCellAbstractMemStore.getNextRow(ExtendedCell key, NavigableSet<ExtendedCell> set) (package private) ExtendedCellCompactingMemStore.getNextRow(ExtendedCell cell) (package private) ExtendedCellDefaultMemStore.getNextRow(ExtendedCell cell) CompositeImmutableSegment.last()Segment.last()private ExtendedCellAbstractMemStore.maybeCloneWithAllocator(MutableSegment currentActive, ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; Otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.CompositeImmutableSegment.maybeCloneWithAllocator(ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returnedSegment.maybeCloneWithAllocator(ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.KeyValueHeap.next()KeyValueScanner.next()Return the next Cell in this scanner, iterating the scannerMemStoreCompactorSegmentsIterator.next()MemStoreMergerSegmentsIterator.next()ReversedKeyValueHeap.next()SegmentScanner.next()Return the next Cell in this scanner, iterating the scannerSnapshotSegmentScanner.next()StoreFileScanner.next()KeyValueHeap.peek()KeyValueScanner.peek()Look at the next Cell in this scanner, but do not iterate scanner.SegmentScanner.peek()Look at the next Cell in this scanner, but do not iterate the scannerSnapshotSegmentScanner.peek()StoreFileScanner.peek()StoreScanner.peek()private static ExtendedCellHRegion.MutationBatchOperation.reckonDelta(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type ExtendedCellModifier and TypeMethodDescriptionprivate static Iterator<ExtendedCell>SnapshotSegmentScanner.createIterator(Segment segment) protected CellSet<ExtendedCell>CompositeImmutableSegment.getCellSet()Returns a set of all cells in the segmentprotected CellSet<ExtendedCell>Segment.getCellSet()Returns a set of all cells in the segmentHStoreFile.getFirstKey()StoreFile.getFirstKey()Get the first key in this store file.StoreFileReader.getFirstKey()protected Iterator<ExtendedCell>SegmentScanner.getIterator(ExtendedCell cell) HStoreFile.getLastKey()StoreFile.getLastKey()Get the last key in this store file.StoreFileReader.getLastKey()CompositeImmutableSegment.headSet(ExtendedCell firstKeyOnRow) Segment.headSet(ExtendedCell firstKeyOnRow) CompositeImmutableSegment.iterator()Segment.iterator()StoreFileReader.midKey()private Map<byte[],List<ExtendedCell>> HRegion.MutationBatchOperation.reckonDeltas(Mutation mutation, List<ExtendedCell> results, long now) private List<ExtendedCell>HRegion.MutationBatchOperation.reckonDeltasByStore(HStore store, Mutation mutation, long now, List<ExtendedCell> deltas, List<ExtendedCell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.protected SortedSet<ExtendedCell>CompositeImmutableSegment.tailSet(ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<ExtendedCell>Segment.tailSet(ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellMethods in org.apache.hadoop.hbase.regionserver with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidAbstractMemStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) voidHStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) Adds a value to the memstorevoidMemStore.add(ExtendedCell cell, MemStoreSizing memstoreSizing) Write an updatevoidMutableSegment.add(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentvoidCellSink.append(ExtendedCell cell) Append the given cellvoidCustomTieringMultiFileWriter.append(ExtendedCell cell) voidDateTieredMultiFileWriter.append(ExtendedCell cell) voidStoreFileWriter.append(ExtendedCell cell) private voidStoreFileWriter.SingleStoreFileWriter.append(ExtendedCell cell) voidStripeMultiFileWriter.BoundaryMultiWriter.append(ExtendedCell cell) voidStripeMultiFileWriter.SizeMultiWriter.append(ExtendedCell cell) private voidStoreFileWriter.appendCell(ExtendedCell cell) private voidStoreFileWriter.SingleStoreFileWriter.appendDeleteFamilyBloomFilter(ExtendedCell cell) private voidStoreFileWriter.SingleStoreFileWriter.appendGeneralBloomfilter(ExtendedCell cell) booleanKeyValueScanner.backwardSeek(ExtendedCell key) Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValuebooleanNonReversedNonLazyKeyValueScanner.backwardSeek(ExtendedCell key) booleanReversedKeyValueHeap.backwardSeek(ExtendedCell seekKey) booleanReversedStoreScanner.backwardSeek(ExtendedCell key) booleanSegmentScanner.backwardSeek(ExtendedCell key) Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValuebooleanStoreFileScanner.backwardSeek(ExtendedCell key) ImmutableMemStoreLAB.copyCellInto(ExtendedCell cell) MemStoreLAB.copyCellInto(ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.copyCellInto(ExtendedCell cell) private ExtendedCellMemStoreLABImpl.copyCellInto(ExtendedCell cell, int maxAlloc) private ExtendedCellCellChunkImmutableSegment.copyCellIntoMSLAB(ExtendedCell cell, MemStoreSizing memstoreSizing) private static ExtendedCellMemStoreLABImpl.copyToChunkCell(ExtendedCell cell, ByteBuffer buf, int offset, int len) Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid out of itprivate static ExtendedCellAbstractMemStore.deepCopyIfNeeded(ExtendedCell cell) protected voidAbstractMemStore.doAdd(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private voidAbstractMemStore.doAddOrUpsert(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing, boolean doAdd) static booleanNonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner, ExtendedCell kv, boolean forward) private voidAbstractMemStore.doUpsert(MutableSegment currentActive, ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) ImmutableMemStoreLAB.forceCopyOfBigCellInto(ExtendedCell cell) The process of merging assumes all cells are allocated on mslab.MemStoreLAB.forceCopyOfBigCellInto(ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.forceCopyOfBigCellInto(ExtendedCell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.private booleanKeyValueHeap.generalizedSeek(boolean isLazy, ExtendedCell seekKey, boolean forward, boolean useBloom) private ExtendedCellSegmentScanner.getHighest(ExtendedCell first, ExtendedCell second) Private internal method that returns the higher of the two key values, or null if they are both nullprotected Iterator<ExtendedCell>SegmentScanner.getIterator(ExtendedCell cell) protected ExtendedCellAbstractMemStore.getLowest(ExtendedCell a, ExtendedCell b) Returns Return lowest of a or b or null if both a and b are nullprotected ExtendedCellAbstractMemStore.getNextRow(ExtendedCell key, NavigableSet<ExtendedCell> set) (package private) ExtendedCellCompactingMemStore.getNextRow(ExtendedCell cell) (package private) ExtendedCellDefaultMemStore.getNextRow(ExtendedCell cell) CompositeImmutableSegment.headSet(ExtendedCell firstKeyOnRow) Segment.headSet(ExtendedCell firstKeyOnRow) voidTimeRangeTracker.includeTimestamp(ExtendedCell cell) Update the current TimestampRange to include the timestamp fromcell.private voidAbstractMemStore.internalAdd(MutableSegment currentActive, ExtendedCell toAdd, boolean mslabUsed, MemStoreSizing memstoreSizing) Internal version of add() that doesn't clone Cells with the allocator, and doesn't take the lock.protected voidCompositeImmutableSegment.internalAdd(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.internalAdd(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) private booleanStoreFileWriter.isDeleted(ExtendedCell cell) private booleanStoreFileWriter.isDeletedByDeleteColumn(ExtendedCell cell) private booleanStoreFileWriter.isDeletedByDeleteColumnVersion(ExtendedCell cell) private booleanStoreFileWriter.isDeletedByDeleteFamily(ExtendedCell cell) private booleanStoreFileWriter.isDeletedByDeleteFamilyVersion(ExtendedCell cell) private booleanRegionScannerImpl.joinedHeapMayHaveData(ExtendedCell currentRowCell) Returns true when the joined heap may have data for the current rowprivate ExtendedCellAbstractMemStore.maybeCloneWithAllocator(MutableSegment currentActive, ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; Otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.CompositeImmutableSegment.maybeCloneWithAllocator(ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returnedSegment.maybeCloneWithAllocator(ExtendedCell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.private voidStoreScanner.parallelSeek(List<? extends KeyValueScanner> scanners, ExtendedCell kv) Seek storefiles in parallel to optimize IO latency as much as possiblebooleanStoreFileReader.passesGeneralRowColBloomFilter(ExtendedCell cell) A method for checking Bloom filters.private booleanRegionScannerImpl.populateResult(List<? super ExtendedCell> results, KeyValueHeap heap, ScannerContext scannerContext, ExtendedCell currentRowCell) Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is reached, or remainingResultSize (if not -1) is reacedprotected abstract booleanAbstractMemStore.preUpdate(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected booleanCompactingMemStore.preUpdate(MutableSegment currentActive, ExtendedCell 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 overflowprotected booleanDefaultMemStore.preUpdate(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private MobCellHMobStore.readCell(List<org.apache.hadoop.fs.Path> locations, String fileName, ExtendedCell search, boolean cacheMobBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from a mob file.private static ExtendedCellHRegion.MutationBatchOperation.reckonDelta(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) booleanKeyValueHeap.requestSeek(ExtendedCell key, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.ExtendedCell)(orKeyValueScanner.reseek(org.apache.hadoop.hbase.ExtendedCell)if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.booleanKeyValueScanner.requestSeek(ExtendedCell kv, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.ExtendedCell)(orKeyValueScanner.reseek(org.apache.hadoop.hbase.ExtendedCell)if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.booleanNonLazyKeyValueScanner.requestSeek(ExtendedCell kv, boolean forward, boolean useBloom) booleanReversedKeyValueHeap.requestSeek(ExtendedCell key, boolean forward, boolean useBloom) booleanSegmentScanner.requestSeek(ExtendedCell c, boolean forward, boolean useBloom) booleanStoreFileScanner.requestSeek(ExtendedCell kv, boolean forward, boolean useBloom) Pretend we have done a seek but don't do it yet, if possible.booleanKeyValueHeap.reseek(ExtendedCell seekKey) This function is identical to theKeyValueHeap.seek(ExtendedCell)function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).booleanKeyValueScanner.reseek(ExtendedCell key) Reseek the scanner at or after the specified KeyValue.booleanReversedKeyValueHeap.reseek(ExtendedCell seekKey) booleanReversedStoreScanner.reseek(ExtendedCell kv) booleanSegmentScanner.reseek(ExtendedCell cell) Reseek the scanner at or after the specified KeyValue.booleanSnapshotSegmentScanner.reseek(ExtendedCell seekCell) booleanStoreFileScanner.reseek(ExtendedCell key) booleanStoreScanner.reseek(ExtendedCell kv) private booleanStoreFileScanner.reseekAtOrAfter(ExtendedCell seekKey) (package private) static booleanStoreFileScanner.reseekAtOrAfter(HFileScanner s, ExtendedCell k) private voidStoreScanner.resetQueryMatcher(ExtendedCell lastTopKey) HMobStore.resolve(ExtendedCell reference, boolean cacheBlocks) Reads the cell from the mob file, and the read point does not count.HMobStore.resolve(ExtendedCell reference, boolean cacheBlocks, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file with readEmptyValueOnMobCellMissHMobStore.resolve(ExtendedCell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file.protected voidHRegion.restoreEdit(HStore s, ExtendedCell cell, MemStoreSizing memstoreAccounting) Used by testsbooleanKeyValueHeap.seek(ExtendedCell seekKey) Seeks all scanners at or below the specified seek key.booleanKeyValueScanner.seek(ExtendedCell key) Seek the scanner at or after the specified KeyValue.booleanReversedKeyValueHeap.seek(ExtendedCell seekKey) booleanReversedStoreScanner.seek(ExtendedCell key) booleanSegmentScanner.seek(ExtendedCell cell) Seek the scanner at or after the specified Cell.booleanSnapshotSegmentScanner.seek(ExtendedCell seekCell) booleanStoreFileScanner.seek(ExtendedCell key) booleanStoreScanner.seek(ExtendedCell key) protected booleanReversedStoreScanner.seekAsDirection(ExtendedCell kv) Do a backwardSeek in a reversed StoreScanner(scan backward)protected booleanStoreScanner.seekAsDirection(ExtendedCell kv) Do a reseek in a normal StoreScanner(scan forward)private booleanStoreFileScanner.seekAtOrAfter(ExtendedCell seekKey) static booleanStoreFileScanner.seekAtOrAfter(HFileScanner s, ExtendedCell k) Returns false if not found or if k is after the end.private booleanStoreFileScanner.seekBefore(ExtendedCell seekKey) private voidStoreFileScanner.seekBeforeAndSaveKeyToPreviousRow(ExtendedCell seekKey) Seeks before the seek target cell and saves the location toStoreFileScanner.previousRow.private voidStoreScanner.seekOrSkipToNextColumn(ExtendedCell cell) private voidStoreScanner.seekOrSkipToNextRow(ExtendedCell cell) protected voidReversedStoreScanner.seekScanners(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) protected voidStoreScanner.seekScanners(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected booleanReversedStoreScanner.seekToNextRow(ExtendedCell kv) protected booleanStoreScanner.seekToNextRow(ExtendedCell c) booleanKeyValueScanner.seekToPreviousRow(ExtendedCell key) Seek the scanner at the first Cell of the row which is the previous row of specified keybooleanNonReversedNonLazyKeyValueScanner.seekToPreviousRow(ExtendedCell key) booleanReversedKeyValueHeap.seekToPreviousRow(ExtendedCell seekKey) booleanReversedStoreScanner.seekToPreviousRow(ExtendedCell key) booleanSegmentScanner.seekToPreviousRow(ExtendedCell cell) Seek the scanner at the first Cell of the row which is the previous row of specified keybooleanStoreFileScanner.seekToPreviousRow(ExtendedCell originalKey) private booleanStoreFileScanner.seekToPreviousRowStateless(ExtendedCell originalKey) This variant of theStoreFileScanner.seekToPreviousRow(ExtendedCell)method requires two seeks.private booleanStoreFileScanner.seekToPreviousRowWithoutHint(ExtendedCell originalKey) This variant of theStoreFileScanner.seekToPreviousRow(ExtendedCell)method requires two seeks and one reseek.protected voidStoreFileScanner.setCurrentCell(ExtendedCell newVal) protected SortedSet<ExtendedCell>CompositeImmutableSegment.tailSet(ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<ExtendedCell>Segment.tailSet(ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected booleanStoreScanner.trySkipToNextColumn(ExtendedCell cell) protected booleanStoreScanner.trySkipToNextRow(ExtendedCell cell) See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).protected voidCompositeImmutableSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(ExtendedCell cellToAdd, boolean succ, MemStoreSizing memstoreSizing) private voidAbstractMemStore.upsert(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) voidMutableSegment.upsert(ExtendedCell cell, long readpoint, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type ExtendedCellModifier and TypeMethodDescriptionvoidAbstractMemStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) voidHStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoidMemStore.add(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Write the updatesprotected voidHRegion.BatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.BatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) default voidCellSink.appendAll(List<ExtendedCell> cellList) Append the given (possibly partial) list of cells of a rowvoidStoreFileWriter.appendAll(List<ExtendedCell> cellList) protected voidHRegion.BatchOperation.applyFamilyMapToMemStore(Map<byte[], List<ExtendedCell>> familyMap, MemStoreSizing memstoreAccounting) Atomically apply the given map of family->edits to the memstore.private voidHRegion.applyToMemStore(HStore store, List<ExtendedCell> cells, boolean delta, MemStoreSizing memstoreAccounting) protected abstract voidHRegion.BatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected voidHRegion.MutationBatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> nonceKeyAndWALEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Here is for HBASE-26993,in order to make the new framework for region replication could work for SKIP_WAL, we save theMutationwhichMutation.getDurability()isDurability.SKIP_WALin miniBatchOp.protected voidHRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.protected static voidHRegion.BatchOperation.doAddCellsToWALEdit(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected static voidHRegion.BatchOperation.doAddCellsToWALEdit(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected ExtendedCellAbstractMemStore.getNextRow(ExtendedCell key, NavigableSet<ExtendedCell> set) private voidHRegion.MutationBatchOperation.mergeFamilyMaps(Map<byte[], List<ExtendedCell>> familyMap, Map<byte[], List<ExtendedCell>> toBeMerged) default booleanInternalScanner.next(List<? super ExtendedCell> result) Grab the next row's worth of values.booleanInternalScanner.next(List<? super ExtendedCell> result, ScannerContext scannerContext) Grab the next row's worth of values.booleanKeyValueHeap.next(List<? super ExtendedCell> result, ScannerContext scannerContext) Gets the next row of keys from the top-most scanner.booleanMobStoreScanner.next(List<? super ExtendedCell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.booleanRegionScannerImpl.next(List<? super ExtendedCell> outResults) booleanRegionScannerImpl.next(List<? super ExtendedCell> outResults, ScannerContext scannerContext) booleanReversedMobStoreScanner.next(List<? super ExtendedCell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.booleanStoreScanner.next(List<? super ExtendedCell> outResult, ScannerContext scannerContext) Get the next row of values from this Store.private booleanRegionScannerImpl.nextInternal(List<? super ExtendedCell> results, ScannerContext scannerContext) booleanRegionScanner.nextRaw(List<? super ExtendedCell> result) Grab the next row's worth of values.booleanRegionScanner.nextRaw(List<? super ExtendedCell> result, ScannerContext scannerContext) Grab the next row's worth of values.booleanRegionScannerImpl.nextRaw(List<? super ExtendedCell> outResults) booleanRegionScannerImpl.nextRaw(List<? super ExtendedCell> outResults, ScannerContext scannerContext) private booleanRegionScannerImpl.populateFromJoinedHeap(List<? super ExtendedCell> results, ScannerContext scannerContext) Returns true if more cells exist after this batch, false if scanner is doneprivate booleanRegionScannerImpl.populateResult(List<? super ExtendedCell> results, KeyValueHeap heap, ScannerContext scannerContext, ExtendedCell currentRowCell) Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is reached, or remainingResultSize (if not -1) is reacedprivate voidHRegion.prepareDeleteTimestamps(Mutation mutation, Map<byte[], List<ExtendedCell>> familyMap, byte[] byteNow) Set up correct timestamps in the KVs in Delete object.private static ExtendedCellHRegion.MutationBatchOperation.reckonDelta(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) private Map<byte[],List<ExtendedCell>> HRegion.MutationBatchOperation.reckonDeltas(Mutation mutation, List<ExtendedCell> results, long now) private List<ExtendedCell>HRegion.MutationBatchOperation.reckonDeltasByStore(HStore store, Mutation mutation, long now, List<ExtendedCell> deltas, List<ExtendedCell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.private voidCellArrayImmutableSegment.reinitializeCellSet(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreCompactionStrategy.Action action) private voidCellChunkImmutableSegment.reinitializeCellSet(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) private voidHRegion.replayWALBatchMutate(Map<byte[], List<ExtendedCell>> family2Cells) Replay the batch mutate for secondary replica.private voidHRegion.rewriteCellTags(Map<byte[], List<ExtendedCell>> familyMap, Mutation m) Possibly rewrite incoming cell tags.protected SegmentSegment.setCellSet(CellSet<ExtendedCell> cellSetOld, CellSet<ExtendedCell> cellSetNew) Setting the CellSet of the segment - used only for flat immutable segment for setting immutable CellSet after its creation in immutable segment constructorprivate static voidHRegion.updateCellTimestamps(Iterable<List<ExtendedCell>> cellItr, byte[] now) Replace any cell timestamps set toHConstants.LATEST_TIMESTAMPprovided current timestamp.private voidHRegion.updateSequenceId(Iterable<List<ExtendedCell>> cellItr, long sequenceId) voidAbstractMemStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) voidHStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.voidMemStore.upsert(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Update or insert the specified cells.Constructor parameters in org.apache.hadoop.hbase.regionserver with type arguments of type ExtendedCellModifierConstructorDescriptionCustomTieringMultiFileWriter(List<Long> lowerBoundaries, Map<Long, String> lowerBoundariesPolicies, boolean needEmptyFile, Function<ExtendedCell, Long> tieringFunction) DateTieredMultiFileWriter(List<Long> lowerBoundaries, Map<Long, String> lowerBoundariesPolicies, boolean needEmptyFile, Function<ExtendedCell, Long> tieringFunction) protectedMutableSegment(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) protectedSegment(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, TimeRangeTracker trt) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.compactions
Methods in org.apache.hadoop.hbase.regionserver.compactions that return types with arguments of type ExtendedCellModifier and TypeMethodDescriptionprotected List<ExtendedCell>Compactor.decorateCells(List<ExtendedCell> cells) CustomCellTieringValueProvider.decorateCells(List<ExtendedCell> cells) protected List<ExtendedCell>CustomTieredCompactor.decorateCells(List<ExtendedCell> cells) default List<ExtendedCell>CustomTieredCompactor.TieringValueProvider.decorateCells(List<ExtendedCell> cells) Methods in org.apache.hadoop.hbase.regionserver.compactions with parameters of type ExtendedCellModifier and TypeMethodDescriptionlongCustomCellTieringValueProvider.getTieringValue(ExtendedCell cell) longCustomTieredCompactor.TieringValueProvider.getTieringValue(ExtendedCell cell) Method parameters in org.apache.hadoop.hbase.regionserver.compactions with type arguments of type ExtendedCellModifier and TypeMethodDescriptionprotected List<ExtendedCell>Compactor.decorateCells(List<ExtendedCell> cells) CustomCellTieringValueProvider.decorateCells(List<ExtendedCell> cells) protected List<ExtendedCell>CustomTieredCompactor.decorateCells(List<ExtendedCell> cells) default List<ExtendedCell>CustomTieredCompactor.TieringValueProvider.decorateCells(List<ExtendedCell> cells) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as ExtendedCellConstructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type ExtendedCellModifierConstructorDescriptionParallelSeekHandler(KeyValueScanner scanner, ExtendedCell keyValue, long readPoint, CountDownLatch latch) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.querymatcher
Fields in org.apache.hadoop.hbase.regionserver.querymatcher declared as ExtendedCellModifier and TypeFieldDescriptionprivate ExtendedCellScanWildcardColumnTracker.columnCellprivate ExtendedCellUserScanQueryMatcher.curColCellprotected ExtendedCellScanQueryMatcher.currentRowRow the query is onprotected ExtendedCellScanDeleteTracker.deleteCellprotected final ExtendedCellScanQueryMatcher.startKeyKey to seek to in memstore and StoreFilesMethods in org.apache.hadoop.hbase.regionserver.querymatcher that return ExtendedCellModifier and TypeMethodDescriptionprivate static ExtendedCellUserScanQueryMatcher.createStartKey(Scan scan, ScanInfo scanInfo) protected static ExtendedCellScanQueryMatcher.createStartKeyFromRow(byte[] startRow, ScanInfo scanInfo) ScanQueryMatcher.currentRow()Returns a cell represent the current rowScanQueryMatcher.getKeyForNextColumn(ExtendedCell cell) CompactionScanQueryMatcher.getNextKeyHint(ExtendedCell cell) abstract ExtendedCellScanQueryMatcher.getNextKeyHint(ExtendedCell cell) Delegate toFilter.getNextCellHint(Cell).UserScanQueryMatcher.getNextKeyHint(ExtendedCell cell) ScanQueryMatcher.getStartKey()Returns the start keyMethods in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidDeleteTracker.add(ExtendedCell cell) Add the specified cell to the list of deletes to check against for this row operation.voidNewVersionBehaviorTracker.add(ExtendedCell cell) voidScanDeleteTracker.add(ExtendedCell cell) Add the specified Cell to the list of deletes to check against for this row operation.voidNewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete(ExtendedCell cell) ColumnTracker.checkColumn(ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.ExplicitColumnTracker.checkColumn(ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.NewVersionBehaviorTracker.checkColumn(ExtendedCell cell, byte type) ScanWildcardColumnTracker.checkColumn(ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.protected final ScanQueryMatcher.MatchCodeScanQueryMatcher.checkDeleted(DeleteTracker deletes, ExtendedCell cell) ColumnTracker.checkVersions(ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.ExplicitColumnTracker.checkVersions(ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) NewVersionBehaviorTracker.checkVersions(ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) ScanWildcardColumnTracker.checkVersions(ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.intScanQueryMatcher.compareKeyForNextColumn(ExtendedCell nextIndexed, ExtendedCell currentCell) intScanQueryMatcher.compareKeyForNextRow(ExtendedCell nextIndexed, ExtendedCell currentCell) default voidColumnTracker.doneWithColumn(ExtendedCell cell) This method is used to inform the column tracker that we are done with this column.voidExplicitColumnTracker.doneWithColumn(ExtendedCell cell) ScanQueryMatcher.getKeyForNextColumn(ExtendedCell cell) CompactionScanQueryMatcher.getNextKeyHint(ExtendedCell cell) abstract ExtendedCellScanQueryMatcher.getNextKeyHint(ExtendedCell cell) Delegate toFilter.getNextCellHint(Cell).UserScanQueryMatcher.getNextKeyHint(ExtendedCell cell) ColumnTracker.getNextRowOrNextColumn(ExtendedCell cell) Retrieve the MatchCode for the next row or columnExplicitColumnTracker.getNextRowOrNextColumn(ExtendedCell cell) NewVersionBehaviorTracker.getNextRowOrNextColumn(ExtendedCell cell) ScanWildcardColumnTracker.getNextRowOrNextColumn(ExtendedCell cell) private static booleanScanQueryMatcher.isCellTTLExpired(ExtendedCell cell, long oldestTimestamp, long now) Returns true if the cell is expiredprivate booleanNewVersionBehaviorTracker.isColumnQualifierChanged(ExtendedCell cell) DeleteTracker.isDeleted(ExtendedCell cell) Check if the specified cell buffer has been deleted by a previously seen delete.NewVersionBehaviorTracker.isDeleted(ExtendedCell cell) This method is not idempotent, we will save some info to judge VERSION_MASKED.ScanDeleteTracker.isDeleted(ExtendedCell cell) Check if the specified Cell buffer has been deleted by a previously seen delete.IncludeAllCompactionQueryMatcher.match(ExtendedCell cell) MajorCompactionScanQueryMatcher.match(ExtendedCell cell) MinorCompactionScanQueryMatcher.match(ExtendedCell cell) NormalUserScanQueryMatcher.match(ExtendedCell cell) RawScanQueryMatcher.match(ExtendedCell cell) abstract ScanQueryMatcher.MatchCodeScanQueryMatcher.match(ExtendedCell cell) Determines if the caller should do one of several things: seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) seek/skip to the next column (MatchCode.SEEK_NEXT_COL) include the current KeyValue (MatchCode.INCLUDE) ignore the current KeyValue (MatchCode.SKIP) got to the next row (MatchCode.DONE)StripeCompactionScanQueryMatcher.match(ExtendedCell cell) protected final ScanQueryMatcher.MatchCodeUserScanQueryMatcher.matchColumn(ExtendedCell cell, long timestamp, byte typeByte) private final ScanQueryMatcher.MatchCodeUserScanQueryMatcher.mergeFilterResponse(ExtendedCell cell, ScanQueryMatcher.MatchCode matchCode, Filter.ReturnCode filterResponse) Call this when scan has filter.booleanCompactionScanQueryMatcher.moreRowsMayExistAfter(ExtendedCell cell) abstract booleanScanQueryMatcher.moreRowsMayExistAfter(ExtendedCell cell) booleanUserScanQueryMatcher.moreRowsMayExistAfter(ExtendedCell cell) protected final ScanQueryMatcher.MatchCodeScanQueryMatcher.preCheck(ExtendedCell cell) Check before the delete logic.protected longNewVersionBehaviorTracker.prepare(ExtendedCell cell) Reset the map if it is different with the last Cell.private voidScanWildcardColumnTracker.resetCell(ExtendedCell columnCell) voidScanQueryMatcher.setToNewRow(ExtendedCell currentRow) Set the row when there is change in rowprotected final voidCompactionScanQueryMatcher.trackDelete(ExtendedCell cell) protected final ScanQueryMatcher.MatchCodeDropDeletesCompactionScanQueryMatcher.tryDropDelete(ExtendedCell cell) Constructors in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type ExtendedCellModifierConstructorDescriptionprotectedScanQueryMatcher(ExtendedCell startKey, ScanInfo scanInfo, ColumnTracker columns, long oldestUnexpiredTS, long now) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal that return ExtendedCellModifier and TypeMethodDescriptionprotected ExtendedCellSecureWALCellCodec.EncryptedKvDecoder.parseCell()protected ExtendedCellWALCellCodec.CompressedKvDecoder.parseCell()Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidSecureWALCellCodec.EncryptedKvEncoder.write(ExtendedCell cell) voidWALCellCodec.CompressedKvEncoder.write(ExtendedCell cell) voidWALCellCodec.EnsureKvEncoder.write(ExtendedCell cell) Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type ExtendedCellModifier and TypeMethodDescription(package private) static Set<byte[]>FSWALEntry.collectFamilies(List<ExtendedCell> cells) -
Uses of ExtendedCell in org.apache.hadoop.hbase.replication
Methods in org.apache.hadoop.hbase.replication that return ExtendedCellModifier and TypeMethodDescriptionBulkLoadCellFilter.filterCell(ExtendedCell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.Methods in org.apache.hadoop.hbase.replication with parameters of type ExtendedCellModifier and TypeMethodDescriptionBulkLoadCellFilter.filterCell(ExtendedCell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate. -
Uses of ExtendedCell in org.apache.hadoop.hbase.replication.regionserver
Methods in org.apache.hadoop.hbase.replication.regionserver with parameters of type ExtendedCellModifier and TypeMethodDescriptionprivate booleanReplicationSink.isNewRowOrType(ExtendedCell previousCell, ExtendedCell cell) Returns True if we have crossed over onto a new row or type -
Uses of ExtendedCell in org.apache.hadoop.hbase.security.access
Methods in org.apache.hadoop.hbase.security.access with parameters of type ExtendedCellModifier and TypeMethodDescriptionstatic List<Permission>PermissionStorage.getCellPermissionsForUser(User user, ExtendedCell cell) -
Uses of ExtendedCell in org.apache.hadoop.hbase.security.visibility
Methods in org.apache.hadoop.hbase.security.visibility with parameters of type ExtendedCellModifier and TypeMethodDescriptionvoidVisibilityNewVersionBehaivorTracker.add(ExtendedCell cell) voidVisibilityScanDeleteTracker.add(ExtendedCell delCell) voidVisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode.addVersionDelete(ExtendedCell cell) VisibilityController.checkForReservedVisibilityTagPresence(ExtendedCell cell, Pair<Boolean, Tag> pair) Checks whether cell contains any tag with type as VISIBILITY_TAG_TYPE.private CellVisibilityController.createNewCellWithTags(Mutation mutation, ExtendedCell newCell) static ByteVisibilityUtils.extractAndPartitionTags(ExtendedCell cell, List<Tag> visTags, List<Tag> nonVisTags) Extracts and partitions the visibility tags and nonVisibility Tagsprivate booleanVisibilityScanDeleteTracker.extractDeleteCellVisTags(ExtendedCell delCell, KeyValue.Type type) static ByteVisibilityUtils.extractVisibilityTags(ExtendedCell cell, List<Tag> tags) Extract the visibility tags of the given Cell into the given ListVisibilityNewVersionBehaivorTracker.isDeleted(ExtendedCell cell) VisibilityScanDeleteTracker.isDeleted(ExtendedCell cell) static booleanVisibilityUtils.isVisibilityTagsPresent(ExtendedCell cell) private booleanVisibilityNewVersionBehaivorTracker.tagMatched(ExtendedCell put, VisibilityNewVersionBehaivorTracker.TagInfo delInfo) Constructors in org.apache.hadoop.hbase.security.visibility with parameters of type ExtendedCell -
Uses of ExtendedCell in org.apache.hadoop.hbase.thrift2
Fields in org.apache.hadoop.hbase.thrift2 declared as ExtendedCellModifier and TypeFieldDescriptionprivate static final ExtendedCell[]ThriftUtilities.EMPTY_CELL_ARRAY -
Uses of ExtendedCell in org.apache.hadoop.hbase.util
Classes in org.apache.hadoop.hbase.util that implement ExtendedCellModifier and TypeClassDescriptionclassA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Fields in org.apache.hadoop.hbase.util declared as ExtendedCellModifier and TypeFieldDescriptionprivate final ExtendedCellMapReduceExtendedCell.cellprivate ExtendedCellCollectionBackedScanner.currentFields in org.apache.hadoop.hbase.util with type parameters of type ExtendedCellModifier and TypeFieldDescriptionprivate final Iterable<ExtendedCell>CollectionBackedScanner.dataprivate Iterator<ExtendedCell>CollectionBackedScanner.iterMethods in org.apache.hadoop.hbase.util that return ExtendedCellModifier and TypeMethodDescriptionMapReduceExtendedCell.deepClone()private ExtendedCellRowPrefixFixedLengthBloomContext.getRowPrefixCell(ExtendedCell cell) CollectionBackedScanner.next()CollectionBackedScanner.peek()Methods in org.apache.hadoop.hbase.util with parameters of type ExtendedCellModifier and TypeMethodDescriptionprivate ExtendedCellRowPrefixFixedLengthBloomContext.getRowPrefixCell(ExtendedCell cell) protected abstract booleanBloomContext.isNewKey(ExtendedCell cell) Returns true if the cell is a new key as per the bloom typeprotected booleanRowBloomContext.isNewKey(ExtendedCell cell) protected booleanRowColBloomContext.isNewKey(ExtendedCell cell) booleanCollectionBackedScanner.reseek(ExtendedCell seekCell) private voidBloomContext.sanityCheck(ExtendedCell cell) booleanCollectionBackedScanner.seek(ExtendedCell seekCell) voidBloomContext.writeBloom(ExtendedCell cell) Bloom information from the cell is retrievedvoidRowPrefixFixedLengthBloomContext.writeBloom(ExtendedCell cell) Constructors in org.apache.hadoop.hbase.util with parameters of type ExtendedCellModifierConstructorDescriptionCollectionBackedScanner(CellComparator comparator, ExtendedCell... array) Constructor parameters in org.apache.hadoop.hbase.util with type arguments of type ExtendedCellModifierConstructorDescriptionCollectionBackedScanner(List<ExtendedCell> list, CellComparator comparator) CollectionBackedScanner(SortedSet<ExtendedCell> set, CellComparator comparator) -
Uses of ExtendedCell in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal with type parameters of type ExtendedCellMethods in org.apache.hadoop.hbase.wal that return types with arguments of type ExtendedCellModifier and TypeMethodDescription(package private) List<ExtendedCell>WALEdit.getExtendedCells()static List<ExtendedCell>WALEditInternalHelper.getExtendedCells(WALEdit edit) Methods in org.apache.hadoop.hbase.wal with parameters of type ExtendedCellModifier and TypeMethodDescription(package private) WALEditWALEdit.add(ExtendedCell cell) (package private) WALEditWALEdit.add(ExtendedCell cell, byte[] family) private WALEditWALEdit.addCell(ExtendedCell cell) static WALEditWALEditInternalHelper.addExtendedCell(WALEdit edit, ExtendedCell cell) WALPrettyPrinter.toStringMap(ExtendedCell cell) WALPrettyPrinter.toStringMap(ExtendedCell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues) Method parameters in org.apache.hadoop.hbase.wal with type arguments of type ExtendedCellModifier and TypeMethodDescription(package private) WALEditWALEdit.add(List<ExtendedCell> cells) static voidWALEditInternalHelper.addExtendedCell(WALEdit edit, List<ExtendedCell> cells) (package private) voidWALEdit.addMap(Map<byte[], List<ExtendedCell>> familyMap) Append the given map of family-> edits to a WALEdit data structure.static voidWALEditInternalHelper.addMap(WALEdit edit, Map<byte[], List<ExtendedCell>> familyMap) (package private) voidWALEdit.setExtendedCells(ArrayList<ExtendedCell> cells) This is not thread safe.static voidWALEditInternalHelper.setExtendedCells(WALEdit edit, ArrayList<ExtendedCell> cells)