Uses of Interface
org.apache.hadoop.hbase.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
Modifier and TypeClassDescriptionclass
This class is a server side extension to theCell
interface.class
This is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
class
An HBase Key/Value.static class
A 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.class
An extension of the ByteBufferKeyValue where the tags length is always 0class
An extension of the KeyValue where the tags length is always 0private static class
These cells are used in reseeks/seeks to improve the read performance.private static class
These cells are used in reseeks/seeks to improve the read performance.private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
private static class
(package private) static class
(package private) static class
This can be used when a Cell has to change with addition/removal of one or more tags.(package private) static class
(package private) static class
class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
This class is an extension to KeyValue where rowLen and keyLen are cached.class
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Modifier and TypeMethodDescriptionExtendedCellBuilder.build()
ExtendedCellBuilderImpl.build()
(package private) static ExtendedCell
HFilePerformanceEvaluation.createCell
(byte[] keyRow) (package private) static ExtendedCell
HFilePerformanceEvaluation.createCell
(byte[] keyRow, byte[] value) (package private) static ExtendedCell
HFilePerformanceEvaluation.createCell
(int i) (package private) static ExtendedCell
HFilePerformanceEvaluation.createCell
(int i, byte[] value) HFile is Cell-based.static ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, byte[] value, byte[] tags) static ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCell
PrivateCellUtil.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 ExtendedCell
PrivateCellUtil.createFirstOnNextRow
(Cell cell) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, byte[] family, byte[] col) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(Cell cell) static ExtendedCell
PrivateCellUtil.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 ExtendedCell
PrivateCellUtil.createFirstOnRowColTS
(Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static ExtendedCell
PrivateCellUtil.createFirstOnRowFamily
(Cell cell, byte[] fArray, int foff, int flen) static ExtendedCell
PrivateCellUtil.createLastOnRow
(byte[] row) static ExtendedCell
PrivateCellUtil.createLastOnRow
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static ExtendedCell
PrivateCellUtil.createLastOnRowCol
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static ExtendedCell
PrivateCellUtil.createNextOnRowCol
(ExtendedCell cell) Return a new cell is located following input cell.(package private) static ExtendedCell
PrivateCellUtil.createNextOnRowCol
(ExtendedCell cell, long ts, byte type) ExtendedCellScanner.current()
ByteBufferKeyValue.deepClone()
default ExtendedCell
ExtendedCell.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 ExtendedCell
PrivateCellUtil.ensureExtendedCell
(Cell cell) In fact, in HBase, allCell
s areExtendedCell
s.protected abstract ExtendedCell
ExtendedCellBuilderImpl.innerBuild()
IndividualBytesFieldCellBuilder.innerBuild()
protected ExtendedCell
KeyValueBuilder.innerBuild()
Modifier and TypeMethodDescriptionstatic int
KeyValueUtil.appendKeyTo
(ExtendedCell cell, byte[] output, int offset) static int
KeyValueUtil.appendKeyTo
(ExtendedCell cell, ByteBuffer buf, int offset) static int
KeyValueUtil.appendTo
(ExtendedCell cell, ByteBuffer buf, int offset, boolean withTags) Copy the Cell content into the passed buf in KeyValue serialization format.static int
KeyValueUtil.appendToByteArray
(ExtendedCell cell, byte[] output, int offset, boolean withTags) copy key and valueprivate int
KeyValue.calculateHashForKey
(ExtendedCell cell) TagUtil.carryForwardTags
(List<Tag> tagsOrNull, ExtendedCell cell) Add totagsOrNull
any Tagscell
is carrying or null if none.TagUtil.carryForwardTags
(ExtendedCell cell) Returns A List<Tag> of any Tags found incell
else null.static byte[]
PrivateCellUtil.cloneTags
(ExtendedCell cell) static final int
PrivateCellUtil.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 int
PrivateCellUtil.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 int
PrivateCellUtil.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 void
PrivateCellUtil.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 ByteBuffer
KeyValueUtil.copyKeyToNewByteBuffer
(ExtendedCell cell) The position will be set to the beginning of the new ByteBufferstatic int
PrivateCellUtil.copyTagsTo
(ExtendedCell cell, byte[] destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic int
PrivateCellUtil.copyTagsTo
(ExtendedCell cell, ByteBuffer destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic byte[]
KeyValueUtil.copyToNewByteArray
(ExtendedCell cell) static KeyValue
KeyValueUtil.copyToNewKeyValue
(ExtendedCell cell) copy the cell to create a new keyvaluestatic ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, byte[] value, byte[] tags) static ExtendedCell
PrivateCellUtil.createCell
(ExtendedCell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(ExtendedCell[] cellArray) Returns CellScanner interface overcellArray
static ExtendedCell
PrivateCellUtil.createNextOnRowCol
(ExtendedCell cell) Return a new cell is located following input cell.(package private) static ExtendedCell
PrivateCellUtil.createNextOnRowCol
(ExtendedCell cell, long ts, byte type) static KeyValue
KeyValueUtil.ensureKeyValue
(ExtendedCell cell) Deprecated.without any replacement.static boolean
PrivateCellUtil.equals
(ExtendedCell a, ExtendedCell b) static boolean
PrivateCellUtil.equalsIgnoreMvccVersion
(ExtendedCell a, ExtendedCell b) special case for Cell.equalsstatic ByteRange
PrivateCellUtil.fillTagRange
(ExtendedCell cell, ByteRange range) static int
PrivateCellUtil.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 boolean
PrivateCellUtil.isDeleteColumnOrFamily
(ExtendedCell cell) Returns True if this cell is a delete family or column type.static boolean
PrivateCellUtil.isDeleteColumns
(ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteColumnVersion
(ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteFamily
(ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteFamilyVersion
(ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteType
(ExtendedCell cell) Returns True if this cell is aKeyValue.Type.Delete
type.static boolean
PrivateCellUtil.matchingTags
(ExtendedCell left, ExtendedCell right) static boolean
PrivateCellUtil.matchingTags
(ExtendedCell left, ExtendedCell right, int llength, int rlength) static boolean
PrivateCellUtil.matchingType
(ExtendedCell a, ExtendedCell b) PrivateCellUtil.tagsIterator
(ExtendedCell cell) Utility method to iterate through the tags in the given cell.static KeyValue
KeyValueUtil.toNewKeyCell
(ExtendedCell cell) Copies the key to a new KeyValuestatic boolean
PrivateCellUtil.updateLatestStamp
(ExtendedCell cell, long ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP
.(package private) static int
PrivateCellUtil.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 void
PrivateCellUtil.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 void
PrivateCellUtil.writeFlatKey
(ExtendedCell cell, DataOutput out) Writes the Cell's key part as it would have serialized in a KeyValue.static int
PrivateCellUtil.writeFlatKey
(ExtendedCell cell, OutputStream out) static void
PrivateCellUtil.writeTags
(OutputStream out, ExtendedCell cell, int tagsLength) Writes the tag from the given cell to the output streamstatic void
PrivateCellUtil.writeValue
(OutputStream out, ExtendedCell cell, int vlength) Writes the value from the given cell to the output streamModifier and TypeMethodDescriptionstatic ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterable<ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterable
static ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterator<ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterable
or null ifcells
is nullstatic ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(NavigableMap<byte[], List<ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerKeyValueUtil.ensureKeyValues
(List<ExtendedCell> cells) Deprecated.ModifierConstructorDescriptionTagRewriteCell
(ExtendedCell cell, byte[] tags) Construct a TagRewriteCellValueAndTagRewriteCell
(ExtendedCell cell, byte[] value, byte[] tags) -
Uses of ExtendedCell in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate ExtendedCell[]
Result.cells
private ExtendedCell
AllowPartialScanResultCache.lastCell
private ExtendedCell
BatchScanResultCache.lastCell
Modifier and TypeFieldDescriptionprotected final NavigableMap<byte[],
List<ExtendedCell>> Mutation.familyMap
Modifier and TypeMethodDescriptionResult.current()
For client users: You should only use the return value as aCell
,ExtendedCell
is 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()
Modifier 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) Modifier and TypeMethodDescriptionMutation.cellToStringMap
(ExtendedCell c) (package private) static Result
Result.create
(ExtendedCell[] cells) (package private) static Result
Result.create
(ExtendedCell[] cells, Boolean exists, boolean stale) (package private) static Result
Result.create
(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) static Result
ClientInternalHelper.createResult
(ExtendedCell[] cells) static Result
ClientInternalHelper.createResult
(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) (package private) static Result
ConnectionUtils.filterCells
(Result result, ExtendedCell keepCellsAfter) ModifierConstructorDescriptionprivate
Result
(ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Private ctor. -
Uses of ExtendedCell in org.apache.hadoop.hbase.codec
Modifier and TypeFieldDescriptionprivate ExtendedCell
BaseDecoder.current
protected ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.current
Modifier and TypeMethodDescriptionprotected ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) protected ExtendedCell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected ExtendedCell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) BaseDecoder.current()
KeyValueCodec.ByteBuffKeyValueDecoder.current()
protected abstract ExtendedCell
BaseDecoder.parseCell()
Extract a Cell.protected ExtendedCell
CellCodec.CellDecoder.parseCell()
protected ExtendedCell
CellCodecWithTags.CellDecoder.parseCell()
protected ExtendedCell
KeyValueCodec.KeyValueDecoder.parseCell()
protected ExtendedCell
KeyValueCodecWithTags.KeyValueDecoder.parseCell()
protected ExtendedCell
MessageCodec.MessageDecoder.parseCell()
Modifier and TypeMethodDescriptionabstract void
BaseEncoder.write
(ExtendedCell cell) void
CellCodec.CellEncoder.write
(ExtendedCell cell) void
CellCodecWithTags.CellEncoder.write
(ExtendedCell cell) void
KeyValueCodec.KeyValueEncoder.write
(ExtendedCell cell) void
KeyValueCodecWithTags.KeyValueEncoder.write
(ExtendedCell cell) void
MessageCodec.MessageEncoder.write
(ExtendedCell cell) -
Uses of ExtendedCell in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionboolean
DelegatingInternalScanner.next
(List<? super ExtendedCell> result, ScannerContext scannerContext) -
Uses of ExtendedCell in org.apache.hadoop.hbase.filter
Modifier and TypeClassDescription(package private) static class
(package private) static class
-
Uses of ExtendedCell in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionHalfStoreFileReader.getFirstKey()
HalfStoreFileReader.getLastKey()
HalfStoreFileReader.midKey()
Modifier and TypeMethodDescriptionvoid
CellOutputStream.write
(ExtendedCell cell) Implementation must copy the entire state of the Cell. -
Uses of ExtendedCell in org.apache.hadoop.hbase.io.encoding
Modifier and TypeClassDescriptionprotected static class
protected static class
Copies only the key part of the keybuffer by doing a deep copy and passes the seeker state members for taking a clone.Modifier and TypeFieldDescriptionprivate ExtendedCell
RowIndexEncoderV1.lastCell
The Cell previously appended.protected ExtendedCell
EncodingState.prevCell
The previous Cell the encoder encoded.Modifier and TypeMethodDescriptionprotected ExtendedCell
AbstractDataBlockEncoder.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 ExtendedCell
BufferedDataBlockEncoder.SeekerState.toOffheapCell
(ByteBuffer valAndTagsBuffer, int vOffset, int tagsLenSerializationSize) private ExtendedCell
BufferedDataBlockEncoder.SeekerState.toOnheapCell
(ByteBuffer valAndTagsBuffer, int vOffset, int tagsLenSerializationSize) Modifier and TypeMethodDescriptionEncodedDataBlock.getIterator
(int headerSize) Provides access to compressed value.Modifier and TypeMethodDescriptionprotected final int
BufferedDataBlockEncoder.afterEncodingKeyValue
(ExtendedCell cell, DataOutputStream out, HFileBlockDefaultEncodingContext encodingCtx) Returns unencoded size addedprotected boolean
RowIndexEncoderV1.checkRow
(ExtendedCell cell) int
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareKey
(CellComparator comparator, ExtendedCell key) int
DataBlockEncoder.EncodedSeeker.compareKey
(CellComparator comparator, ExtendedCell key) Compare the given key against the current keyint
RowIndexSeekerV1.compareKey
(CellComparator comparator, ExtendedCell key) private int
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareTypeBytes
(ExtendedCell key, ExtendedCell right) private int
DiffKeyDeltaEncoder.compressSingleKeyValue
(DataOutputStream out, ExtendedCell cell, ExtendedCell prevCell) private int
FastDiffDeltaEncoder.compressSingleKeyValue
(DataOutputStream out, ExtendedCell cell, ExtendedCell prevCell) void
BufferedDataBlockEncoder.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) void
DataBlockEncoder.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
RowIndexCodecV1.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) abstract int
BufferedDataBlockEncoder.internalEncode
(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingCtx, DataOutputStream out) int
CopyKeyDataBlockEncoder.internalEncode
(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
DiffKeyDeltaEncoder.internalEncode
(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
FastDiffDeltaEncoder.internalEncode
(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
PrefixKeyDeltaEncoder.internalEncode
(ExtendedCell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
BufferedDataBlockEncoder.BufferedEncodedSeeker.seekToKeyInBlock
(ExtendedCell seekCell, boolean seekBefore) int
DataBlockEncoder.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 ifseekBefore
is false the last key that is strictly less than the given key ifseekBefore
is true.int
RowIndexSeekerV1.seekToKeyInBlock
(ExtendedCell seekCell, boolean seekBefore) int
NoneEncoder.write
(ExtendedCell cell) void
RowIndexEncoderV1.write
(ExtendedCell cell) private void
PrefixKeyDeltaEncoder.writeKeyExcludingCommon
(ExtendedCell cell, int commonPrefix, DataOutputStream out) -
Uses of ExtendedCell in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprivate ExtendedCell[]
HFileBlockIndex.CellBasedKeyBlockIndexReader.blockKeys
private ExtendedCell[]
NoOpIndexBlockEncoder.NoOpEncodedSeeker.blockKeys
protected ExtendedCell
HFileWriterImpl.firstCellInBlock
First cell in a block.protected ExtendedCell
HFileWriterImpl.lastCell
The Cell previously appended.private ExtendedCell
HFileWriterImpl.lastCellOfPreviousBlock
The last(stop) Cell of the previous data block.private ExtendedCell
HFileInfo.lastKeyCell
Last key in the file.private final ExtendedCell
BlockWithScanInfo.nextIndexedKey
The first key in the next block following this one in the HFile.protected ExtendedCell
HFileReaderImpl.HFileScannerImpl.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.private ExtendedCell
CompoundBloomFilterWriter.prevCell
The prev Cell that was processedModifier and TypeFieldDescriptionprivate AtomicReference<ExtendedCell>
HFileBlockIndex.CellBasedKeyBlockIndexReader.midKey
Pre-computed mid-keyprivate AtomicReference<ExtendedCell>
NoOpIndexBlockEncoder.NoOpEncodedSeeker.midKey
Pre-computed mid-keyModifier and TypeMethodDescriptionHFileReaderImpl.EncodedScanner.getCell()
HFileReaderImpl.HFileScannerImpl.getCell()
HFileScanner.getCell()
Returns Instance ofExtendedCell
.protected ExtendedCell
HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock
(HFileBlock curBlock) protected ExtendedCell
HFileReaderImpl.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 ExtendedCell
HFileWriterImpl.getMidpoint
(CellComparator comparator, ExtendedCell left, ExtendedCell right) Try to return a Cell that falls betweenleft
andright
but 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- 1
HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.getRootBlockKey
(int i) from 0 to- 1
HFileIndexBlockEncoder.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) Modifier and TypeMethodDescriptionHFile.Reader.getFirstKey()
HFileReaderImpl.getFirstKey()
HFile.Reader.getLastKey()
HFileReaderImpl.getLastKey()
HFile.Reader.midKey()
HFileReaderImpl.midKey()
Modifier and TypeMethodDescriptionvoid
CompoundBloomFilterWriter.append
(ExtendedCell cell) void
HFileWriterImpl.append
(ExtendedCell cell) Add key/value to file.int
HFileReaderImpl.EncodedScanner.compareKey
(CellComparator comparator, ExtendedCell key) int
HFileReaderImpl.HFileScannerImpl.compareKey
(CellComparator comparator, ExtendedCell key) void
HFileDataBlockEncoder.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
HFileDataBlockEncoderImpl.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) void
NoOpDataBlockEncoder.encode
(ExtendedCell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) static ExtendedCell
HFileWriterImpl.getMidpoint
(CellComparator comparator, ExtendedCell left, ExtendedCell right) Try to return a Cell that falls betweenleft
andright
but that is shorter; i.e.protected int
HFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey
(HFileBlock seekToBlock, ExtendedCell nextIndexedKey, boolean rewind, ExtendedCell key, boolean seekBefore) protected int
HFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey
(HFileBlock seekToBlock, ExtendedCell nextIndexedKey, boolean rewind, ExtendedCell key, boolean seekBefore) abstract BlockWithScanInfo
HFileBlockIndex.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) int
HFileReaderImpl.HFileScannerImpl.reseekTo
(ExtendedCell key) int
HFileScanner.reseekTo
(ExtendedCell cell) Reseek to or just before the passedcell
.boolean
HFileReaderImpl.HFileScannerImpl.seekBefore
(ExtendedCell key) boolean
HFileScanner.seekBefore
(ExtendedCell cell) Consider the cell stream of all the cells in the file,c[0] ..
int
HFileReaderImpl.HFileScannerImpl.seekTo
(ExtendedCell key) int
HFileReaderImpl.HFileScannerImpl.seekTo
(ExtendedCell key, boolean rewind) An internal API function.int
HFileScanner.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.(package private) void
HFileBlock.Writer.write
(ExtendedCell cell) Writes the Cell to this blockModifierConstructorDescriptionBlockWithScanInfo
(HFileBlock hFileBlock, ExtendedCell nextIndexedKey) -
Uses of ExtendedCell in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionprivate static ExtendedCell
Import.convertKv
(ExtendedCell kv, Map<byte[], byte[]> cfRenameMap) static ExtendedCell
Import.filterKv
(Filter filter, ExtendedCell c) Attempt to filter out the keyvalueModifier and TypeMethodDescriptionprivate static ExtendedCell
Import.convertKv
(ExtendedCell kv, Map<byte[], byte[]> cfRenameMap) ExtendedCellSerialization.ExtendedCellDeserializer.deserialize
(ExtendedCell ignore) static ExtendedCell
Import.filterKv
(Filter filter, ExtendedCell c) Attempt to filter out the keyvaluevoid
ExtendedCellSerialization.ExtendedCellSerializer.serialize
(ExtendedCell kv) Modifier and TypeMethodDescriptionExtendedCellSerialization.getDeserializer
(Class<ExtendedCell> t) ExtendedCellSerialization.getSerializer
(Class<ExtendedCell> c) -
Uses of ExtendedCell in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic ExtendedCell
MobUtils.createMobRefCell
(ExtendedCell cell, byte[] fileName, byte[] refCellTags) static ExtendedCell
MobUtils.createMobRefCell
(ExtendedCell cell, byte[] fileName, Tag tableNameTag) Creates a mob reference KeyValue.MobCell.getCell()
Modifier and TypeMethodDescriptionstatic ExtendedCell
MobUtils.createMobRefCell
(ExtendedCell cell, byte[] fileName, byte[] refCellTags) static ExtendedCell
MobUtils.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 boolean
MobUtils.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.ModifierConstructorDescriptionMobCell
(ExtendedCell cell) MobCell
(ExtendedCell cell, StoreFileScanner sfScanner) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
ByteBuffer based cell which has the chunkid at the 0th offsetclass
ByteBuffer based cell which has the chunkid at the 0th offset and with no tagsModifier and TypeFieldDescriptionprivate ExtendedCell
StoreFileScanner.cur
protected ExtendedCell
SegmentScanner.current
private ExtendedCell
SnapshotSegmentScanner.current
private ExtendedCell
StoreFileScanner.delayedSeekKV
private ExtendedCell
StoreFileWriter.deleteColumn
private ExtendedCell
StoreFileWriter.deleteFamily
protected ExtendedCell
RegionScannerImpl.joinedContinuationRow
If the joined heap data gathering is interrupted due to scan limits, this will contain the row for which we are populating the values.private ExtendedCell
SegmentScanner.last
private ExtendedCell
StoreFileWriter.lastCell
static final ExtendedCell
KeyValueScanner.NO_NEXT_INDEXED_KEY
The byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.private ExtendedCell
StoreScanner.prevCell
private ExtendedCell
SegmentScanner.stopSkippingKVsRow
Modifier and TypeFieldDescriptionprivate AtomicReference<CellSet<ExtendedCell>>
Segment.cellSet
private List<ExtendedCell>
StoreFileWriter.deleteColumnVersionList
private List<ExtendedCell>
StoreFileWriter.deleteFamilyVersionList
private Optional<ExtendedCell>
HStoreFile.firstKey
protected Iterator<ExtendedCell>
SegmentScanner.iter
private Iterator<ExtendedCell>
SnapshotSegmentScanner.iter
private final List<ExtendedCell>
MemStoreCompactorSegmentsIterator.kvs
private Iterator<ExtendedCell>
MemStoreCompactorSegmentsIterator.kvsIterator
private Optional<ExtendedCell>
HStoreFile.lastKey
Modifier and TypeMethodDescriptionprivate ExtendedCell
MemStoreLABImpl.copyBBECellInto
(ByteBufferExtendedCell cell, int maxAlloc) Mostly a duplicate of#copyCellInto(Cell, int)
} done for perf sake.private static ExtendedCell
MemStoreLABImpl.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 ExtendedCell
MemStoreLABImpl.copyCellInto
(ExtendedCell cell, int maxAlloc) private ExtendedCell
CellChunkImmutableSegment.copyCellIntoMSLAB
(ExtendedCell cell, MemStoreSizing memstoreSizing) private static ExtendedCell
MemStoreLABImpl.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 ExtendedCell
MemStoreLABImpl.createChunkCell
(ByteBuffer buf, int offset, int len, int tagsLen, long sequenceId) private static ExtendedCell
AbstractMemStore.deepCopyIfNeeded
(ExtendedCell cell) (package private) ExtendedCell
MutableSegment.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 ExtendedCell
SegmentScanner.getHighest
(ExtendedCell first, ExtendedCell second) Private internal method that returns the higher of the two key values, or null if they are both nullprotected ExtendedCell
AbstractMemStore.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 ExtendedCell
AbstractMemStore.getNextRow
(ExtendedCell key, NavigableSet<ExtendedCell> set) (package private) ExtendedCell
CompactingMemStore.getNextRow
(ExtendedCell cell) (package private) ExtendedCell
DefaultMemStore.getNextRow
(ExtendedCell cell) CompositeImmutableSegment.last()
Segment.last()
private ExtendedCell
AbstractMemStore.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 ExtendedCell
HRegion.MutationBatchOperation.reckonDelta
(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) Modifier 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 cellModifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) void
HStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) Adds a value to the memstorevoid
MemStore.add
(ExtendedCell cell, MemStoreSizing memstoreSizing) Write an updatevoid
MutableSegment.add
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentvoid
CellSink.append
(ExtendedCell cell) Append the given cellvoid
DateTieredMultiFileWriter.append
(ExtendedCell cell) void
StoreFileWriter.append
(ExtendedCell cell) private void
StoreFileWriter.SingleStoreFileWriter.append
(ExtendedCell cell) void
StripeMultiFileWriter.BoundaryMultiWriter.append
(ExtendedCell cell) void
StripeMultiFileWriter.SizeMultiWriter.append
(ExtendedCell cell) private void
StoreFileWriter.appendCell
(ExtendedCell cell) private void
StoreFileWriter.SingleStoreFileWriter.appendDeleteFamilyBloomFilter
(ExtendedCell cell) private void
StoreFileWriter.SingleStoreFileWriter.appendGeneralBloomfilter
(ExtendedCell cell) boolean
KeyValueScanner.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 KeyValueboolean
NonReversedNonLazyKeyValueScanner.backwardSeek
(ExtendedCell key) boolean
ReversedKeyValueHeap.backwardSeek
(ExtendedCell seekKey) boolean
ReversedStoreScanner.backwardSeek
(ExtendedCell key) boolean
SegmentScanner.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 KeyValueboolean
StoreFileScanner.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 ExtendedCell
MemStoreLABImpl.copyCellInto
(ExtendedCell cell, int maxAlloc) private ExtendedCell
CellChunkImmutableSegment.copyCellIntoMSLAB
(ExtendedCell cell, MemStoreSizing memstoreSizing) private static ExtendedCell
MemStoreLABImpl.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 ExtendedCell
AbstractMemStore.deepCopyIfNeeded
(ExtendedCell cell) protected void
AbstractMemStore.doAdd
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private void
AbstractMemStore.doAddOrUpsert
(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing, boolean doAdd) static boolean
NonLazyKeyValueScanner.doRealSeek
(KeyValueScanner scanner, ExtendedCell kv, boolean forward) private void
AbstractMemStore.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 boolean
KeyValueHeap.generalizedSeek
(boolean isLazy, ExtendedCell seekKey, boolean forward, boolean useBloom) private ExtendedCell
SegmentScanner.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 ExtendedCell
AbstractMemStore.getLowest
(ExtendedCell a, ExtendedCell b) Returns Return lowest of a or b or null if both a and b are nullprotected ExtendedCell
AbstractMemStore.getNextRow
(ExtendedCell key, NavigableSet<ExtendedCell> set) (package private) ExtendedCell
CompactingMemStore.getNextRow
(ExtendedCell cell) (package private) ExtendedCell
DefaultMemStore.getNextRow
(ExtendedCell cell) CompositeImmutableSegment.headSet
(ExtendedCell firstKeyOnRow) Segment.headSet
(ExtendedCell firstKeyOnRow) void
TimeRangeTracker.includeTimestamp
(ExtendedCell cell) Update the current TimestampRange to include the timestamp fromcell
.private void
AbstractMemStore.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 void
CompositeImmutableSegment.internalAdd
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.internalAdd
(ExtendedCell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) private boolean
StoreFileWriter.isDeleted
(ExtendedCell cell) private boolean
StoreFileWriter.isDeletedByDeleteColumn
(ExtendedCell cell) private boolean
StoreFileWriter.isDeletedByDeleteColumnVersion
(ExtendedCell cell) private boolean
StoreFileWriter.isDeletedByDeleteFamily
(ExtendedCell cell) private boolean
StoreFileWriter.isDeletedByDeleteFamilyVersion
(ExtendedCell cell) private boolean
RegionScannerImpl.joinedHeapMayHaveData
(ExtendedCell currentRowCell) Returns true when the joined heap may have data for the current rowprivate ExtendedCell
AbstractMemStore.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 void
StoreScanner.parallelSeek
(List<? extends KeyValueScanner> scanners, ExtendedCell kv) Seek storefiles in parallel to optimize IO latency as much as possibleboolean
StoreFileReader.passesGeneralRowColBloomFilter
(ExtendedCell cell) A method for checking Bloom filters.private boolean
RegionScannerImpl.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 boolean
AbstractMemStore.preUpdate
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected boolean
CompactingMemStore.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 boolean
DefaultMemStore.preUpdate
(MutableSegment currentActive, ExtendedCell cell, MemStoreSizing memstoreSizing) private MobCell
HMobStore.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 ExtendedCell
HRegion.MutationBatchOperation.reckonDelta
(ExtendedCell delta, ExtendedCell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<ExtendedCell, byte[]> supplier) boolean
KeyValueHeap.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.boolean
KeyValueScanner.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.boolean
NonLazyKeyValueScanner.requestSeek
(ExtendedCell kv, boolean forward, boolean useBloom) boolean
ReversedKeyValueHeap.requestSeek
(ExtendedCell key, boolean forward, boolean useBloom) boolean
SegmentScanner.requestSeek
(ExtendedCell c, boolean forward, boolean useBloom) boolean
StoreFileScanner.requestSeek
(ExtendedCell kv, boolean forward, boolean useBloom) Pretend we have done a seek but don't do it yet, if possible.boolean
KeyValueHeap.reseek
(ExtendedCell seekKey) This function is identical to theKeyValueHeap.seek(ExtendedCell)
function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).boolean
KeyValueScanner.reseek
(ExtendedCell key) Reseek the scanner at or after the specified KeyValue.boolean
ReversedKeyValueHeap.reseek
(ExtendedCell seekKey) boolean
ReversedStoreScanner.reseek
(ExtendedCell kv) boolean
SegmentScanner.reseek
(ExtendedCell cell) Reseek the scanner at or after the specified KeyValue.boolean
SnapshotSegmentScanner.reseek
(ExtendedCell seekCell) boolean
StoreFileScanner.reseek
(ExtendedCell key) boolean
StoreScanner.reseek
(ExtendedCell kv) private boolean
StoreFileScanner.reseekAtOrAfter
(ExtendedCell seekKey) (package private) static boolean
StoreFileScanner.reseekAtOrAfter
(HFileScanner s, ExtendedCell k) private void
StoreScanner.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 void
HRegion.restoreEdit
(HStore s, ExtendedCell cell, MemStoreSizing memstoreAccounting) Used by testsboolean
KeyValueHeap.seek
(ExtendedCell seekKey) Seeks all scanners at or below the specified seek key.boolean
KeyValueScanner.seek
(ExtendedCell key) Seek the scanner at or after the specified KeyValue.boolean
ReversedKeyValueHeap.seek
(ExtendedCell seekKey) boolean
ReversedStoreScanner.seek
(ExtendedCell key) boolean
SegmentScanner.seek
(ExtendedCell cell) Seek the scanner at or after the specified Cell.boolean
SnapshotSegmentScanner.seek
(ExtendedCell seekCell) boolean
StoreFileScanner.seek
(ExtendedCell key) boolean
StoreScanner.seek
(ExtendedCell key) protected boolean
ReversedStoreScanner.seekAsDirection
(ExtendedCell kv) Do a backwardSeek in a reversed StoreScanner(scan backward)protected boolean
StoreScanner.seekAsDirection
(ExtendedCell kv) Do a reseek in a normal StoreScanner(scan forward)private boolean
StoreFileScanner.seekAtOrAfter
(ExtendedCell seekKey) static boolean
StoreFileScanner.seekAtOrAfter
(HFileScanner s, ExtendedCell k) Returns false if not found or if k is after the end.private boolean
StoreFileScanner.seekBefore
(ExtendedCell seekKey) private void
StoreFileScanner.seekBeforeAndSaveKeyToPreviousRow
(ExtendedCell seekKey) Seeks before the seek target cell and saves the location toStoreFileScanner.previousRow
.private void
StoreScanner.seekOrSkipToNextColumn
(ExtendedCell cell) private void
StoreScanner.seekOrSkipToNextRow
(ExtendedCell cell) protected void
ReversedStoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) protected void
StoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected boolean
ReversedStoreScanner.seekToNextRow
(ExtendedCell kv) protected boolean
StoreScanner.seekToNextRow
(ExtendedCell c) boolean
KeyValueScanner.seekToPreviousRow
(ExtendedCell key) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
NonReversedNonLazyKeyValueScanner.seekToPreviousRow
(ExtendedCell key) boolean
ReversedKeyValueHeap.seekToPreviousRow
(ExtendedCell seekKey) boolean
ReversedStoreScanner.seekToPreviousRow
(ExtendedCell key) boolean
SegmentScanner.seekToPreviousRow
(ExtendedCell cell) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
StoreFileScanner.seekToPreviousRow
(ExtendedCell originalKey) private boolean
StoreFileScanner.seekToPreviousRowStateless
(ExtendedCell originalKey) This variant of theStoreFileScanner#seekToPreviousRow(Cell)
method requires two seeks.protected void
StoreFileScanner.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 cellprivate void
StoreFileWriter.SingleStoreFileWriter.trackTimestamps
(ExtendedCell cell) Record the earlest Put timestamp.protected boolean
StoreScanner.trySkipToNextColumn
(ExtendedCell cell) protected boolean
StoreScanner.trySkipToNextRow
(ExtendedCell cell) See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).protected void
CompositeImmutableSegment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(ExtendedCell cellToAdd, boolean succ, MemStoreSizing memstoreSizing) private void
AbstractMemStore.upsert
(ExtendedCell cell, long readpoint, MemStoreSizing memstoreSizing) void
MutableSegment.upsert
(ExtendedCell cell, long readpoint, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Modifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) void
HStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoid
MemStore.add
(Iterable<ExtendedCell> cells, MemStoreSizing memstoreSizing) Write the updatesprotected void
HRegion.BatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.BatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.MutationBatchOperation.addNonSkipWALMutationsToWALEdit
(MiniBatchOperationInProgress<Mutation> miniBatchOp, WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) default void
CellSink.appendAll
(List<ExtendedCell> cellList) Append the given (possibly partial) list of cells of a rowvoid
StoreFileWriter.appendAll
(List<ExtendedCell> cellList) protected void
HRegion.BatchOperation.applyFamilyMapToMemStore
(Map<byte[], List<ExtendedCell>> familyMap, MemStoreSizing memstoreAccounting) Atomically apply the given map of family->edits to the memstore.private void
HRegion.applyToMemStore
(HStore store, List<ExtendedCell> cells, boolean delta, MemStoreSizing memstoreAccounting) protected abstract void
HRegion.BatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) protected void
HRegion.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 theMutation
whichMutation.getDurability()
isDurability.SKIP_WAL
in miniBatchOp.protected void
HRegion.ReplayBatchOperation.cacheSkipWALMutationForRegionReplication
(MiniBatchOperationInProgress<Mutation> miniBatchOp, List<Pair<NonceKey, WALEdit>> walEdits, Map<byte[], List<ExtendedCell>> familyCellMap) Deprecated.protected static void
HRegion.BatchOperation.doAddCellsToWALEdit
(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected static void
HRegion.BatchOperation.doAddCellsToWALEdit
(WALEdit walEdit, List<ExtendedCell> cellsFromCP, Map<byte[], List<ExtendedCell>> familyCellMap) protected ExtendedCell
AbstractMemStore.getNextRow
(ExtendedCell key, NavigableSet<ExtendedCell> set) private void
HRegion.MutationBatchOperation.mergeFamilyMaps
(Map<byte[], List<ExtendedCell>> familyMap, Map<byte[], List<ExtendedCell>> toBeMerged) private ScannerContext.NextState
StoreScanner.needToReturn
(List<? super ExtendedCell> outResult) If the top cell won't be flushed into disk, the new top cell may be changed after #reopenAfterFlush.default boolean
InternalScanner.next
(List<? super ExtendedCell> result) Grab the next row's worth of values.boolean
InternalScanner.next
(List<? super ExtendedCell> result, ScannerContext scannerContext) Grab the next row's worth of values.boolean
KeyValueHeap.next
(List<? super ExtendedCell> result, ScannerContext scannerContext) Gets the next row of keys from the top-most scanner.boolean
MobStoreScanner.next
(List<? super ExtendedCell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.boolean
RegionScannerImpl.next
(List<? super ExtendedCell> outResults) boolean
RegionScannerImpl.next
(List<? super ExtendedCell> outResults, ScannerContext scannerContext) boolean
ReversedMobStoreScanner.next
(List<? super ExtendedCell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.boolean
StoreScanner.next
(List<? super ExtendedCell> outResult, ScannerContext scannerContext) Get the next row of values from this Store.private boolean
RegionScannerImpl.nextInternal
(List<? super ExtendedCell> results, ScannerContext scannerContext) boolean
RegionScanner.nextRaw
(List<? super ExtendedCell> result) Grab the next row's worth of values.boolean
RegionScanner.nextRaw
(List<? super ExtendedCell> result, ScannerContext scannerContext) Grab the next row's worth of values.boolean
RegionScannerImpl.nextRaw
(List<? super ExtendedCell> outResults) boolean
RegionScannerImpl.nextRaw
(List<? super ExtendedCell> outResults, ScannerContext scannerContext) private boolean
RegionScannerImpl.populateFromJoinedHeap
(List<? super ExtendedCell> results, ScannerContext scannerContext) Returns true if more cells exist after this batch, false if scanner is doneprivate boolean
RegionScannerImpl.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 void
HRegion.prepareDeleteTimestamps
(Mutation mutation, Map<byte[], List<ExtendedCell>> familyMap, byte[] byteNow) Set up correct timestamps in the KVs in Delete object.private static ExtendedCell
HRegion.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 void
CellArrayImmutableSegment.reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreCompactionStrategy.Action action) private void
CellChunkImmutableSegment.reinitializeCellSet
(int numOfCells, KeyValueScanner segmentScanner, CellSet<ExtendedCell> oldCellSet, MemStoreSizing memstoreSizing, MemStoreCompactionStrategy.Action action) private void
HRegion.replayWALBatchMutate
(Map<byte[], List<ExtendedCell>> family2Cells) Replay the batch mutate for secondary replica.private void
HRegion.rewriteCellTags
(Map<byte[], List<ExtendedCell>> familyMap, Mutation m) Possibly rewrite incoming cell tags.protected Segment
Segment.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 void
HRegion.updateCellTimestamps
(Iterable<List<ExtendedCell>> cellItr, byte[] now) Replace any cell timestamps set toHConstants.LATEST_TIMESTAMP
provided current timestamp.private void
HRegion.updateSequenceId
(Iterable<List<ExtendedCell>> cellItr, long sequenceId) void
AbstractMemStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) void
HStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.void
MemStore.upsert
(Iterable<ExtendedCell> cells, long readpoint, MemStoreSizing memstoreSizing) Update or insert the specified cells.ModifierConstructorDescriptionprotected
MutableSegment
(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, MemStoreSizing memstoreSizing) protected
Segment
(CellSet<ExtendedCell> cellSet, CellComparator comparator, MemStoreLAB memStoreLAB, TimeRangeTracker trt) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.handler
ModifierConstructorDescriptionParallelSeekHandler
(KeyValueScanner scanner, ExtendedCell keyValue, long readPoint, CountDownLatch latch) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.querymatcher
Modifier and TypeFieldDescriptionprivate ExtendedCell
ScanWildcardColumnTracker.columnCell
private ExtendedCell
UserScanQueryMatcher.curColCell
protected ExtendedCell
ScanQueryMatcher.currentRow
Row the query is onprotected ExtendedCell
ScanDeleteTracker.deleteCell
protected final ExtendedCell
ScanQueryMatcher.startKey
Key to seek to in memstore and StoreFilesModifier and TypeMethodDescriptionprivate static ExtendedCell
UserScanQueryMatcher.createStartKey
(Scan scan, ScanInfo scanInfo) protected static ExtendedCell
ScanQueryMatcher.createStartKeyFromRow
(byte[] startRow, ScanInfo scanInfo) ScanQueryMatcher.currentRow()
Returns a cell represent the current rowScanQueryMatcher.getKeyForNextColumn
(ExtendedCell cell) CompactionScanQueryMatcher.getNextKeyHint
(ExtendedCell cell) abstract ExtendedCell
ScanQueryMatcher.getNextKeyHint
(ExtendedCell cell) Delegate toFilter.getNextCellHint(Cell)
.UserScanQueryMatcher.getNextKeyHint
(ExtendedCell cell) ScanQueryMatcher.getStartKey()
Returns the start keyModifier and TypeMethodDescriptionvoid
DeleteTracker.add
(ExtendedCell cell) Add the specified cell to the list of deletes to check against for this row operation.void
NewVersionBehaviorTracker.add
(ExtendedCell cell) void
ScanDeleteTracker.add
(ExtendedCell cell) Add the specified Cell to the list of deletes to check against for this row operation.void
NewVersionBehaviorTracker.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.MatchCode
ScanQueryMatcher.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.int
ScanQueryMatcher.compareKeyForNextColumn
(ExtendedCell nextIndexed, ExtendedCell currentCell) int
ScanQueryMatcher.compareKeyForNextRow
(ExtendedCell nextIndexed, ExtendedCell currentCell) default void
ColumnTracker.doneWithColumn
(ExtendedCell cell) This method is used to inform the column tracker that we are done with this column.void
ExplicitColumnTracker.doneWithColumn
(ExtendedCell cell) ScanQueryMatcher.getKeyForNextColumn
(ExtendedCell cell) CompactionScanQueryMatcher.getNextKeyHint
(ExtendedCell cell) abstract ExtendedCell
ScanQueryMatcher.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 boolean
ScanQueryMatcher.isCellTTLExpired
(ExtendedCell cell, long oldestTimestamp, long now) Returns true if the cell is expiredprivate boolean
NewVersionBehaviorTracker.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.MatchCode
ScanQueryMatcher.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.MatchCode
UserScanQueryMatcher.matchColumn
(ExtendedCell cell, long timestamp, byte typeByte) private final ScanQueryMatcher.MatchCode
UserScanQueryMatcher.mergeFilterResponse
(ExtendedCell cell, ScanQueryMatcher.MatchCode matchCode, Filter.ReturnCode filterResponse) Call this when scan has filter.boolean
CompactionScanQueryMatcher.moreRowsMayExistAfter
(ExtendedCell cell) abstract boolean
ScanQueryMatcher.moreRowsMayExistAfter
(ExtendedCell cell) boolean
UserScanQueryMatcher.moreRowsMayExistAfter
(ExtendedCell cell) protected final ScanQueryMatcher.MatchCode
ScanQueryMatcher.preCheck
(ExtendedCell cell) Check before the delete logic.protected long
NewVersionBehaviorTracker.prepare
(ExtendedCell cell) Reset the map if it is different with the last Cell.private void
ScanWildcardColumnTracker.resetCell
(ExtendedCell columnCell) void
ScanQueryMatcher.setToNewRow
(ExtendedCell currentRow) Set the row when there is change in rowprotected final void
CompactionScanQueryMatcher.trackDelete
(ExtendedCell cell) protected final ScanQueryMatcher.MatchCode
DropDeletesCompactionScanQueryMatcher.tryDropDelete
(ExtendedCell cell) ModifierConstructorDescriptionprotected
ScanQueryMatcher
(ExtendedCell startKey, ScanInfo scanInfo, ColumnTracker columns, long oldestUnexpiredTS, long now) -
Uses of ExtendedCell in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprotected ExtendedCell
SecureWALCellCodec.EncryptedKvDecoder.parseCell()
protected ExtendedCell
WALCellCodec.CompressedKvDecoder.parseCell()
Modifier and TypeMethodDescriptionvoid
SecureWALCellCodec.EncryptedKvEncoder.write
(ExtendedCell cell) void
WALCellCodec.CompressedKvEncoder.write
(ExtendedCell cell) void
WALCellCodec.EnsureKvEncoder.write
(ExtendedCell cell) Modifier and TypeMethodDescription(package private) static Set<byte[]>
FSWALEntry.collectFamilies
(List<ExtendedCell> cells) -
Uses of ExtendedCell in org.apache.hadoop.hbase.replication
Modifier 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.Modifier 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
Modifier and TypeMethodDescriptionprivate boolean
ReplicationSink.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
Modifier and TypeMethodDescriptionstatic List<Permission>
PermissionStorage.getCellPermissionsForUser
(User user, ExtendedCell cell) -
Uses of ExtendedCell in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionvoid
VisibilityNewVersionBehaivorTracker.add
(ExtendedCell cell) void
VisibilityScanDeleteTracker.add
(ExtendedCell delCell) void
VisibilityNewVersionBehaivorTracker.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 Cell
VisibilityController.createNewCellWithTags
(Mutation mutation, ExtendedCell newCell) static Byte
VisibilityUtils.extractAndPartitionTags
(ExtendedCell cell, List<Tag> visTags, List<Tag> nonVisTags) Extracts and partitions the visibility tags and nonVisibility Tagsprivate boolean
VisibilityScanDeleteTracker.extractDeleteCellVisTags
(ExtendedCell delCell, KeyValue.Type type) static Byte
VisibilityUtils.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 boolean
VisibilityUtils.isVisibilityTagsPresent
(ExtendedCell cell) private boolean
VisibilityNewVersionBehaivorTracker.tagMatched
(ExtendedCell put, VisibilityNewVersionBehaivorTracker.TagInfo delInfo) -
Uses of ExtendedCell in org.apache.hadoop.hbase.thrift2
Modifier and TypeFieldDescriptionprivate static final ExtendedCell[]
ThriftUtilities.EMPTY_CELL_ARRAY
-
Uses of ExtendedCell in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Modifier and TypeFieldDescriptionprivate final ExtendedCell
MapReduceExtendedCell.cell
private ExtendedCell
CollectionBackedScanner.current
Modifier and TypeFieldDescriptionprivate final Iterable<ExtendedCell>
CollectionBackedScanner.data
private Iterator<ExtendedCell>
CollectionBackedScanner.iter
Modifier and TypeMethodDescriptionMapReduceExtendedCell.deepClone()
private ExtendedCell
RowPrefixFixedLengthBloomContext.getRowPrefixCell
(ExtendedCell cell) CollectionBackedScanner.next()
CollectionBackedScanner.peek()
Modifier and TypeMethodDescriptionprivate ExtendedCell
RowPrefixFixedLengthBloomContext.getRowPrefixCell
(ExtendedCell cell) protected abstract boolean
BloomContext.isNewKey
(ExtendedCell cell) Returns true if the cell is a new key as per the bloom typeprotected boolean
RowBloomContext.isNewKey
(ExtendedCell cell) protected boolean
RowColBloomContext.isNewKey
(ExtendedCell cell) boolean
CollectionBackedScanner.reseek
(ExtendedCell seekCell) private void
BloomContext.sanityCheck
(ExtendedCell cell) boolean
CollectionBackedScanner.seek
(ExtendedCell seekCell) void
BloomContext.writeBloom
(ExtendedCell cell) Bloom information from the cell is retrievedvoid
RowPrefixFixedLengthBloomContext.writeBloom
(ExtendedCell cell) ModifierConstructorDescriptionCollectionBackedScanner
(CellComparator comparator, ExtendedCell... array) ModifierConstructorDescriptionCollectionBackedScanner
(List<ExtendedCell> list, CellComparator comparator) CollectionBackedScanner
(SortedSet<ExtendedCell> set, CellComparator comparator) -
Uses of ExtendedCell in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescription(package private) List<ExtendedCell>
WALEdit.getExtendedCells()
static List<ExtendedCell>
WALEditInternalHelper.getExtendedCells
(WALEdit edit) Modifier and TypeMethodDescription(package private) WALEdit
WALEdit.add
(ExtendedCell cell) (package private) WALEdit
WALEdit.add
(ExtendedCell cell, byte[] family) private WALEdit
WALEdit.addCell
(ExtendedCell cell) static WALEdit
WALEditInternalHelper.addExtendedCell
(WALEdit edit, ExtendedCell cell) WALPrettyPrinter.toStringMap
(ExtendedCell cell) WALPrettyPrinter.toStringMap
(ExtendedCell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues) Modifier and TypeMethodDescription(package private) WALEdit
WALEdit.add
(List<ExtendedCell> cells) static void
WALEditInternalHelper.addExtendedCell
(WALEdit edit, List<ExtendedCell> cells) (package private) void
WALEdit.addMap
(Map<byte[], List<ExtendedCell>> familyMap) Append the given map of family-> edits to a WALEdit data structure.static void
WALEditInternalHelper.addMap
(WALEdit edit, Map<byte[], List<ExtendedCell>> familyMap) (package private) void
WALEdit.setExtendedCells
(ArrayList<ExtendedCell> cells) This is not thread safe.static void
WALEditInternalHelper.setExtendedCells
(WALEdit edit, ArrayList<ExtendedCell> cells)