Uses of Interface
org.apache.hadoop.hbase.ExtendedCell
Package
Description
Provides HBase Client
Provides implementations of
HFile
and HFile
BlockCache
.Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.ByteBufferExtendedCell
This class is a server side extension to theCell
interface.class
org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
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
org.apache.hadoop.hbase.ByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.IndividualBytesFieldCell
class
org.apache.hadoop.hbase.KeyValue
An HBase Key/Value.static class
org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
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
org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0class
org.apache.hadoop.hbase.NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0class
org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.class
org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
ExtendedCellBuilder.build()
org.apache.hadoop.hbase.ExtendedCell
ExtendedCellBuilderImpl.build()
static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] value, byte[] tags) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnNextRow
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, byte[] family, byte[] col) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowColTS
(org.apache.hadoop.hbase.Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowFamily
(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createLastOnRow
(byte[] row) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createLastOnRow
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createLastOnRowCol
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createNextOnRowCol
(org.apache.hadoop.hbase.ExtendedCell cell) Return a new cell is located following input cell.org.apache.hadoop.hbase.ExtendedCell
ExtendedCellScanner.current()
org.apache.hadoop.hbase.ExtendedCell
ByteBufferKeyValue.deepClone()
default org.apache.hadoop.hbase.ExtendedCell
ExtendedCell.deepClone()
Does a deep copy of the contents to a new memory area and returns it as a new cell.org.apache.hadoop.hbase.ExtendedCell
KeyValue.deepClone()
org.apache.hadoop.hbase.ExtendedCell
NoTagsByteBufferKeyValue.deepClone()
org.apache.hadoop.hbase.ExtendedCell
NoTagsKeyValue.deepClone()
static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.ensureExtendedCell
(org.apache.hadoop.hbase.Cell cell) In fact, in HBase, allCell
s areExtendedCell
s.protected abstract org.apache.hadoop.hbase.ExtendedCell
ExtendedCellBuilderImpl.innerBuild()
Modifier and TypeMethodDescriptionstatic int
KeyValueUtil.appendKeyTo
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] output, int offset) static int
KeyValueUtil.appendKeyTo
(org.apache.hadoop.hbase.ExtendedCell cell, ByteBuffer buf, int offset) static int
KeyValueUtil.appendTo
(org.apache.hadoop.hbase.ExtendedCell cell, ByteBuffer buf, int offset, boolean withTags) Copy the Cell content into the passed buf in KeyValue serialization format.static int
KeyValueUtil.appendToByteArray
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] output, int offset, boolean withTags) copy key and valuestatic List<org.apache.hadoop.hbase.Tag>
TagUtil.carryForwardTags
(List<org.apache.hadoop.hbase.Tag> tagsOrNull, org.apache.hadoop.hbase.ExtendedCell cell) Add totagsOrNull
any Tagscell
is carrying or null if none.static List<org.apache.hadoop.hbase.Tag>
TagUtil.carryForwardTags
(org.apache.hadoop.hbase.ExtendedCell cell) Returns A List<Tag> of any Tags found incell
else null.static byte[]
PrivateCellUtil.cloneTags
(org.apache.hadoop.hbase.ExtendedCell cell) static final int
PrivateCellUtil.compare
(CellComparator comparator, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.ExtendedCell nextIndexedCell, org.apache.hadoop.hbase.ExtendedCell currentCell, int foff, int flen, byte[] colHint, int coff, int clen, long ts, byte type) Used to compare two cells based on the column hint provided.static void
PrivateCellUtil.compressTags
(OutputStream out, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.TagCompressionContext tagCompressionContext) Compresses the tags to the given outputstream using the TagcompressionContextstatic byte[]
TagUtil.concatTags
(byte[] tags, org.apache.hadoop.hbase.ExtendedCell cell) static ByteBuffer
KeyValueUtil.copyKeyToNewByteBuffer
(org.apache.hadoop.hbase.ExtendedCell cell) The position will be set to the beginning of the new ByteBufferstatic int
PrivateCellUtil.copyTagsTo
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic int
PrivateCellUtil.copyTagsTo
(org.apache.hadoop.hbase.ExtendedCell cell, ByteBuffer destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic byte[]
KeyValueUtil.copyToNewByteArray
(org.apache.hadoop.hbase.ExtendedCell cell) static org.apache.hadoop.hbase.KeyValue
KeyValueUtil.copyToNewKeyValue
(org.apache.hadoop.hbase.ExtendedCell cell) copy the cell to create a new keyvaluestatic org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] value, byte[] tags) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createCell
(org.apache.hadoop.hbase.ExtendedCell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(org.apache.hadoop.hbase.ExtendedCell[] cellArray) Returns CellScanner interface overcellArray
static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createNextOnRowCol
(org.apache.hadoop.hbase.ExtendedCell cell) Return a new cell is located following input cell.static org.apache.hadoop.hbase.KeyValue
KeyValueUtil.ensureKeyValue
(org.apache.hadoop.hbase.ExtendedCell cell) Deprecated.without any replacement.static boolean
PrivateCellUtil.equals
(org.apache.hadoop.hbase.ExtendedCell a, org.apache.hadoop.hbase.ExtendedCell b) static boolean
PrivateCellUtil.equalsIgnoreMvccVersion
(org.apache.hadoop.hbase.ExtendedCell a, org.apache.hadoop.hbase.ExtendedCell b) special case for Cell.equalsstatic org.apache.hadoop.hbase.util.ByteRange
PrivateCellUtil.fillTagRange
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.util.ByteRange range) static int
PrivateCellUtil.findCommonPrefixInFlatKey
(org.apache.hadoop.hbase.ExtendedCell c1, org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell cell) This method exists just to encapsulate how we serialize keys.static Optional<org.apache.hadoop.hbase.Tag>
PrivateCellUtil.getTag
(org.apache.hadoop.hbase.ExtendedCell cell, byte type) Retrieve Cell's first tag, matching the passed in typestatic List<org.apache.hadoop.hbase.Tag>
PrivateCellUtil.getTags
(org.apache.hadoop.hbase.ExtendedCell cell) Return tags in the given Cell as a Liststatic boolean
PrivateCellUtil.isDeleteColumnOrFamily
(org.apache.hadoop.hbase.ExtendedCell cell) Returns True if this cell is a delete family or column type.static boolean
PrivateCellUtil.isDeleteColumns
(org.apache.hadoop.hbase.ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteColumnVersion
(org.apache.hadoop.hbase.ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteFamily
(org.apache.hadoop.hbase.ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteFamilyVersion
(org.apache.hadoop.hbase.ExtendedCell cell) static boolean
PrivateCellUtil.isDeleteType
(org.apache.hadoop.hbase.ExtendedCell cell) Returns True if this cell is aKeyValue.Type.Delete
type.static boolean
PrivateCellUtil.matchingTags
(org.apache.hadoop.hbase.ExtendedCell left, org.apache.hadoop.hbase.ExtendedCell right) static boolean
PrivateCellUtil.matchingTags
(org.apache.hadoop.hbase.ExtendedCell left, org.apache.hadoop.hbase.ExtendedCell right, int llength, int rlength) static boolean
PrivateCellUtil.matchingType
(org.apache.hadoop.hbase.ExtendedCell a, org.apache.hadoop.hbase.ExtendedCell b) static Iterator<org.apache.hadoop.hbase.Tag>
PrivateCellUtil.tagsIterator
(org.apache.hadoop.hbase.ExtendedCell cell) Utility method to iterate through the tags in the given cell.static org.apache.hadoop.hbase.KeyValue
KeyValueUtil.toNewKeyCell
(org.apache.hadoop.hbase.ExtendedCell cell) Copies the key to a new KeyValuestatic boolean
PrivateCellUtil.updateLatestStamp
(org.apache.hadoop.hbase.ExtendedCell cell, long ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP
.static void
PrivateCellUtil.writeFlatKey
(org.apache.hadoop.hbase.ExtendedCell cell, DataOutput out) Writes the Cell's key part as it would have serialized in a KeyValue.static int
PrivateCellUtil.writeFlatKey
(org.apache.hadoop.hbase.ExtendedCell cell, OutputStream out) static void
PrivateCellUtil.writeTags
(OutputStream out, org.apache.hadoop.hbase.ExtendedCell cell, int tagsLength) Writes the tag from the given cell to the output streamstatic void
PrivateCellUtil.writeValue
(OutputStream out, org.apache.hadoop.hbase.ExtendedCell cell, int vlength) Writes the value from the given cell to the output streamModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cellIterable) Returns ExtendedCellScanner interface overcellIterable
static org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(Iterator<org.apache.hadoop.hbase.ExtendedCell> cells) Returns ExtendedCellScanner interface overcellIterable
or null ifcells
is nullstatic org.apache.hadoop.hbase.ExtendedCellScanner
PrivateCellUtil.createExtendedCellScanner
(NavigableMap<byte[], List<org.apache.hadoop.hbase.ExtendedCell>> map) Flatten the map of cells out under the ExtendedCellScannerstatic List<org.apache.hadoop.hbase.KeyValue>
KeyValueUtil.ensureKeyValues
(List<org.apache.hadoop.hbase.ExtendedCell> cells) Deprecated.ModifierConstructorDescriptionKeyValue
(org.apache.hadoop.hbase.ExtendedCell c) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected final NavigableMap<byte[],
List<org.apache.hadoop.hbase.ExtendedCell>> Mutation.familyMap
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
Result.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 org.apache.hadoop.hbase.ExtendedCell[]
ClientInternalHelper.getExtendedRawCells
(org.apache.hadoop.hbase.client.Result result) Modifier and TypeMethodDescriptionstatic NavigableMap<byte[],
List<org.apache.hadoop.hbase.ExtendedCell>> ClientInternalHelper.getExtendedFamilyCellMap
(org.apache.hadoop.hbase.client.Mutation m) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Result
ClientInternalHelper.createResult
(org.apache.hadoop.hbase.ExtendedCell[] cells) static org.apache.hadoop.hbase.client.Result
ClientInternalHelper.createResult
(org.apache.hadoop.hbase.ExtendedCell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.codec
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.current
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) protected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) org.apache.hadoop.hbase.ExtendedCell
BaseDecoder.current()
org.apache.hadoop.hbase.ExtendedCell
KeyValueCodec.ByteBuffKeyValueDecoder.current()
protected abstract org.apache.hadoop.hbase.ExtendedCell
BaseDecoder.parseCell()
Extract a Cell.protected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodec.KeyValueDecoder.parseCell()
protected org.apache.hadoop.hbase.ExtendedCell
KeyValueCodecWithTags.KeyValueDecoder.parseCell()
Modifier and TypeMethodDescriptionabstract void
BaseEncoder.write
(org.apache.hadoop.hbase.ExtendedCell cell) void
KeyValueCodec.KeyValueEncoder.write
(org.apache.hadoop.hbase.ExtendedCell cell) void
KeyValueCodecWithTags.KeyValueEncoder.write
(org.apache.hadoop.hbase.ExtendedCell cell) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.ExtendedCell>
HalfStoreFileReader.getFirstKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HalfStoreFileReader.getLastKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HalfStoreFileReader.midKey()
Modifier and TypeMethodDescriptionvoid
CellOutputStream.write
(org.apache.hadoop.hbase.ExtendedCell cell) Implementation must copy the entire state of the Cell. -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.io.encoding
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
EncodingState.prevCell
The previous Cell the encoder encoded.Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
AbstractDataBlockEncoder.createFirstKeyCell
(ByteBuffer key, int keyLength) org.apache.hadoop.hbase.ExtendedCell
DataBlockEncoder.EncodedSeeker.getCell()
Returns the Cell at the current position.org.apache.hadoop.hbase.ExtendedCell
RowIndexSeekerV1.getCell()
org.apache.hadoop.hbase.ExtendedCell
CopyKeyDataBlockEncoder.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCell
DataBlockEncoder.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) Return first key in block as a cell.org.apache.hadoop.hbase.ExtendedCell
DiffKeyDeltaEncoder.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCell
FastDiffDeltaEncoder.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCell
PrefixKeyDeltaEncoder.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCell
RowIndexCodecV1.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.ExtendedCell
DataBlockEncoder.EncodedSeeker.getKey()
From the current position creates a cell using the key part of the current bufferorg.apache.hadoop.hbase.ExtendedCell
RowIndexSeekerV1.getKey()
Modifier and TypeMethodDescriptionIterator<org.apache.hadoop.hbase.ExtendedCell>
EncodedDataBlock.getIterator
(int headerSize) Provides access to compressed value.Modifier and TypeMethodDescriptionprotected boolean
RowIndexEncoderV1.checkRow
(org.apache.hadoop.hbase.ExtendedCell cell) int
DataBlockEncoder.EncodedSeeker.compareKey
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell key) Compare the given key against the current keyint
RowIndexSeekerV1.compareKey
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell key) void
DataBlockEncoder.encode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
RowIndexCodecV1.encode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) int
CopyKeyDataBlockEncoder.internalEncode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
DiffKeyDeltaEncoder.internalEncode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
FastDiffDeltaEncoder.internalEncode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
PrefixKeyDeltaEncoder.internalEncode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
DataBlockEncoder.EncodedSeeker.seekToKeyInBlock
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell seekCell, boolean seekBefore) int
NoneEncoder.write
(org.apache.hadoop.hbase.ExtendedCell cell) void
RowIndexEncoderV1.write
(org.apache.hadoop.hbase.ExtendedCell cell) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
HFileWriterImpl.firstCellInBlock
First cell in a block.protected org.apache.hadoop.hbase.ExtendedCell
HFileWriterImpl.lastCell
The Cell previously appended.protected org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.HFileScannerImpl.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.EncodedScanner.getCell()
org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.HFileScannerImpl.getCell()
org.apache.hadoop.hbase.ExtendedCell
HFileScanner.getCell()
Returns Instance ofExtendedCell
.protected org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) protected org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock
(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.EncodedScanner.getKey()
org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.HFileScannerImpl.getKey()
org.apache.hadoop.hbase.ExtendedCell
HFileScanner.getKey()
Gets the current key in the form of a cell.org.apache.hadoop.hbase.ExtendedCell
HFileInfo.getLastKeyCell()
static org.apache.hadoop.hbase.ExtendedCell
HFileWriterImpl.getMidpoint
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell left, org.apache.hadoop.hbase.ExtendedCell right) Try to return a Cell that falls betweenleft
andright
but that is shorter; i.e.org.apache.hadoop.hbase.ExtendedCell
BlockWithScanInfo.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
HFileReaderImpl.HFileScannerImpl.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
HFileScanner.getNextIndexedKey()
Returns the next key in the index (the key to seek to the next block)org.apache.hadoop.hbase.ExtendedCell
HFileIndexBlockEncoder.EncodedSeeker.getRootBlockKey
(int i) org.apache.hadoop.hbase.ExtendedCell
NoOpIndexBlockEncoder.NoOpEncodedSeeker.getRootBlockKey
(int i) org.apache.hadoop.hbase.ExtendedCell
HFileIndexBlockEncoder.EncodedSeeker.midkey
(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) org.apache.hadoop.hbase.ExtendedCell
NoOpIndexBlockEncoder.NoOpEncodedSeeker.midkey
(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) Modifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.ExtendedCell>
HFile.Reader.getFirstKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HFileReaderImpl.getFirstKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HFile.Reader.getLastKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HFileReaderImpl.getLastKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HFile.Reader.midKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
HFileReaderImpl.midKey()
Modifier and TypeMethodDescriptionvoid
CompoundBloomFilterWriter.append
(org.apache.hadoop.hbase.ExtendedCell cell) void
HFileWriterImpl.append
(org.apache.hadoop.hbase.ExtendedCell cell) Add key/value to file.int
HFileReaderImpl.EncodedScanner.compareKey
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell key) int
HFileReaderImpl.HFileScannerImpl.compareKey
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell key) void
HFileDataBlockEncoder.encode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
HFileDataBlockEncoderImpl.encode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) void
NoOpDataBlockEncoder.encode
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) static org.apache.hadoop.hbase.ExtendedCell
HFileWriterImpl.getMidpoint
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell left, org.apache.hadoop.hbase.ExtendedCell right) Try to return a Cell that falls betweenleft
andright
but that is shorter; i.e.protected int
HFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey
(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.ExtendedCell key, boolean seekBefore) protected int
HFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey
(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.ExtendedCell key, boolean seekBefore) org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
HFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo
(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) org.apache.hadoop.hbase.io.hfile.BlockWithScanInfo
NoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo
(org.apache.hadoop.hbase.ExtendedCell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) int
HFileReaderImpl.HFileScannerImpl.reseekTo
(org.apache.hadoop.hbase.ExtendedCell key) int
HFileScanner.reseekTo
(org.apache.hadoop.hbase.ExtendedCell cell) Reseek to or just before the passedcell
.boolean
HFileReaderImpl.HFileScannerImpl.seekBefore
(org.apache.hadoop.hbase.ExtendedCell key) boolean
HFileScanner.seekBefore
(org.apache.hadoop.hbase.ExtendedCell cell) Consider the cell stream of all the cells in the file,c[0] ..
int
HFileReaderImpl.HFileScannerImpl.seekTo
(org.apache.hadoop.hbase.ExtendedCell key) int
HFileReaderImpl.HFileScannerImpl.seekTo
(org.apache.hadoop.hbase.ExtendedCell key, boolean rewind) An internal API function.int
HFileScanner.seekTo
(org.apache.hadoop.hbase.ExtendedCell cell) SeekTo or just before the passedcell
.ModifierConstructorDescriptionBlockWithScanInfo
(org.apache.hadoop.hbase.io.hfile.HFileBlock hFileBlock, org.apache.hadoop.hbase.ExtendedCell nextIndexedKey) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ExtendedCell
Import.filterKv
(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.ExtendedCell c) Attempt to filter out the keyvalueModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.KeyValue
ExtendedCellSerialization.ExtendedCellDeserializer.deserialize
(org.apache.hadoop.hbase.ExtendedCell ignore) static org.apache.hadoop.hbase.ExtendedCell
Import.filterKv
(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.ExtendedCell c) Attempt to filter out the keyvaluevoid
ExtendedCellSerialization.ExtendedCellSerializer.serialize
(org.apache.hadoop.hbase.ExtendedCell kv) Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
ExtendedCellSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.ExtendedCell> t) org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
ExtendedCellSerialization.getSerializer
(Class<org.apache.hadoop.hbase.ExtendedCell> c) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ExtendedCell
MobUtils.createMobRefCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] fileName, byte[] refCellTags) static org.apache.hadoop.hbase.ExtendedCell
MobUtils.createMobRefCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag) Creates a mob reference KeyValue.org.apache.hadoop.hbase.ExtendedCell
MobCell.getCell()
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ExtendedCell
MobUtils.createMobRefCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] fileName, byte[] refCellTags) static org.apache.hadoop.hbase.ExtendedCell
MobUtils.createMobRefCell
(org.apache.hadoop.hbase.ExtendedCell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag) Creates a mob reference KeyValue.static Optional<org.apache.hadoop.hbase.TableName>
MobUtils.getTableName
(org.apache.hadoop.hbase.ExtendedCell cell) Get the table name from when this cell was written into a mob hfile as a TableName.MobUtils.getTableNameString
(org.apache.hadoop.hbase.ExtendedCell cell) Gets the table name from when this cell was written into a mob hfile as a string.static boolean
MobUtils.isMobReferenceCell
(org.apache.hadoop.hbase.ExtendedCell cell) Whether the current cell is a mob reference cell.org.apache.hadoop.hbase.mob.MobCell
MobFile.readCell
(org.apache.hadoop.hbase.ExtendedCell search, boolean cacheMobBlocks) Reads a cell from the mob file.org.apache.hadoop.hbase.mob.MobCell
MobFile.readCell
(org.apache.hadoop.hbase.ExtendedCell search, boolean cacheMobBlocks, long readPt) Reads a cell from the mob file.ModifierConstructorDescriptionMobCell
(org.apache.hadoop.hbase.ExtendedCell cell) MobCell
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.StoreFileScanner sfScanner) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offsetclass
org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tagsModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
SegmentScanner.current
static final org.apache.hadoop.hbase.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.Modifier and TypeFieldDescriptionprotected Iterator<org.apache.hadoop.hbase.ExtendedCell>
SegmentScanner.iter
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
ImmutableMemStoreLAB.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
MemStoreLAB.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.ExtendedCell
MemStoreLABImpl.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
ImmutableMemStoreLAB.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) The process of merging assumes all cells are allocated on mslab.org.apache.hadoop.hbase.ExtendedCell
MemStoreLAB.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.ExtendedCell
MemStoreLABImpl.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.protected org.apache.hadoop.hbase.ExtendedCell
AbstractMemStore.getLowest
(org.apache.hadoop.hbase.ExtendedCell a, org.apache.hadoop.hbase.ExtendedCell b) Returns Return lowest of a or b or null if both a and b are nullorg.apache.hadoop.hbase.ExtendedCell
KeyValueHeap.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
KeyValueScanner.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
NonLazyKeyValueScanner.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
SegmentScanner.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
StoreFileScanner.getNextIndexedKey()
org.apache.hadoop.hbase.ExtendedCell
StoreScanner.getNextIndexedKey()
protected org.apache.hadoop.hbase.ExtendedCell
AbstractMemStore.getNextRow
(org.apache.hadoop.hbase.ExtendedCell key, NavigableSet<org.apache.hadoop.hbase.ExtendedCell> set) org.apache.hadoop.hbase.ExtendedCell
CompositeImmutableSegment.last()
org.apache.hadoop.hbase.ExtendedCell
Segment.last()
org.apache.hadoop.hbase.ExtendedCell
CompositeImmutableSegment.maybeCloneWithAllocator
(org.apache.hadoop.hbase.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 returnedorg.apache.hadoop.hbase.ExtendedCell
Segment.maybeCloneWithAllocator
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.ExtendedCell
KeyValueHeap.next()
org.apache.hadoop.hbase.ExtendedCell
KeyValueScanner.next()
Return the next Cell in this scanner, iterating the scannerorg.apache.hadoop.hbase.ExtendedCell
MemStoreCompactorSegmentsIterator.next()
org.apache.hadoop.hbase.ExtendedCell
MemStoreMergerSegmentsIterator.next()
org.apache.hadoop.hbase.ExtendedCell
ReversedKeyValueHeap.next()
org.apache.hadoop.hbase.ExtendedCell
SegmentScanner.next()
Return the next Cell in this scanner, iterating the scannerorg.apache.hadoop.hbase.ExtendedCell
SnapshotSegmentScanner.next()
org.apache.hadoop.hbase.ExtendedCell
StoreFileScanner.next()
org.apache.hadoop.hbase.ExtendedCell
KeyValueHeap.peek()
org.apache.hadoop.hbase.ExtendedCell
KeyValueScanner.peek()
Look at the next Cell in this scanner, but do not iterate scanner.org.apache.hadoop.hbase.ExtendedCell
SegmentScanner.peek()
Look at the next Cell in this scanner, but do not iterate the scannerorg.apache.hadoop.hbase.ExtendedCell
SnapshotSegmentScanner.peek()
org.apache.hadoop.hbase.ExtendedCell
StoreFileScanner.peek()
org.apache.hadoop.hbase.ExtendedCell
StoreScanner.peek()
Modifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.getCellSet()
Returns a set of all cells in the segmentprotected org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell>
Segment.getCellSet()
Returns a set of all cells in the segmentOptional<org.apache.hadoop.hbase.ExtendedCell>
HStoreFile.getFirstKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
StoreFile.getFirstKey()
Get the first key in this store file.Optional<org.apache.hadoop.hbase.ExtendedCell>
StoreFileReader.getFirstKey()
protected Iterator<org.apache.hadoop.hbase.ExtendedCell>
SegmentScanner.getIterator
(org.apache.hadoop.hbase.ExtendedCell cell) Optional<org.apache.hadoop.hbase.ExtendedCell>
HStoreFile.getLastKey()
Optional<org.apache.hadoop.hbase.ExtendedCell>
StoreFile.getLastKey()
Get the last key in this store file.Optional<org.apache.hadoop.hbase.ExtendedCell>
StoreFileReader.getLastKey()
SortedSet<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.headSet
(org.apache.hadoop.hbase.ExtendedCell firstKeyOnRow) SortedSet<org.apache.hadoop.hbase.ExtendedCell>
Segment.headSet
(org.apache.hadoop.hbase.ExtendedCell firstKeyOnRow) Iterator<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.iterator()
Iterator<org.apache.hadoop.hbase.ExtendedCell>
Segment.iterator()
Optional<org.apache.hadoop.hbase.ExtendedCell>
StoreFileReader.midKey()
protected SortedSet<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.tailSet
(org.apache.hadoop.hbase.ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<org.apache.hadoop.hbase.ExtendedCell>
Segment.tailSet
(org.apache.hadoop.hbase.ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellModifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) void
HStore.add
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds a value to the memstorevoid
MemStore.add
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Write an updatevoid
MutableSegment.add
(org.apache.hadoop.hbase.ExtendedCell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentvoid
CellSink.append
(org.apache.hadoop.hbase.ExtendedCell cell) Append the given cellvoid
DateTieredMultiFileWriter.append
(org.apache.hadoop.hbase.ExtendedCell cell) void
StoreFileWriter.append
(org.apache.hadoop.hbase.ExtendedCell cell) void
StripeMultiFileWriter.BoundaryMultiWriter.append
(org.apache.hadoop.hbase.ExtendedCell cell) void
StripeMultiFileWriter.SizeMultiWriter.append
(org.apache.hadoop.hbase.ExtendedCell cell) boolean
KeyValueScanner.backwardSeek
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell key) boolean
ReversedKeyValueHeap.backwardSeek
(org.apache.hadoop.hbase.ExtendedCell seekKey) boolean
ReversedStoreScanner.backwardSeek
(org.apache.hadoop.hbase.ExtendedCell key) boolean
SegmentScanner.backwardSeek
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell key) org.apache.hadoop.hbase.ExtendedCell
ImmutableMemStoreLAB.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
MemStoreLAB.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.ExtendedCell
MemStoreLABImpl.copyCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) protected void
AbstractMemStore.doAdd
(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) static boolean
NonLazyKeyValueScanner.doRealSeek
(org.apache.hadoop.hbase.regionserver.KeyValueScanner scanner, org.apache.hadoop.hbase.ExtendedCell kv, boolean forward) org.apache.hadoop.hbase.ExtendedCell
ImmutableMemStoreLAB.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) The process of merging assumes all cells are allocated on mslab.org.apache.hadoop.hbase.ExtendedCell
MemStoreLAB.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.ExtendedCell
MemStoreLABImpl.forceCopyOfBigCellInto
(org.apache.hadoop.hbase.ExtendedCell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.protected Iterator<org.apache.hadoop.hbase.ExtendedCell>
SegmentScanner.getIterator
(org.apache.hadoop.hbase.ExtendedCell cell) protected org.apache.hadoop.hbase.ExtendedCell
AbstractMemStore.getLowest
(org.apache.hadoop.hbase.ExtendedCell a, org.apache.hadoop.hbase.ExtendedCell b) Returns Return lowest of a or b or null if both a and b are nullprotected org.apache.hadoop.hbase.ExtendedCell
AbstractMemStore.getNextRow
(org.apache.hadoop.hbase.ExtendedCell key, NavigableSet<org.apache.hadoop.hbase.ExtendedCell> set) SortedSet<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.headSet
(org.apache.hadoop.hbase.ExtendedCell firstKeyOnRow) SortedSet<org.apache.hadoop.hbase.ExtendedCell>
Segment.headSet
(org.apache.hadoop.hbase.ExtendedCell firstKeyOnRow) void
TimeRangeTracker.includeTimestamp
(org.apache.hadoop.hbase.ExtendedCell cell) Update the current TimestampRange to include the timestamp fromcell
.protected void
CompositeImmutableSegment.internalAdd
(org.apache.hadoop.hbase.ExtendedCell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.internalAdd
(org.apache.hadoop.hbase.ExtendedCell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) org.apache.hadoop.hbase.ExtendedCell
CompositeImmutableSegment.maybeCloneWithAllocator
(org.apache.hadoop.hbase.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 returnedorg.apache.hadoop.hbase.ExtendedCell
Segment.maybeCloneWithAllocator
(org.apache.hadoop.hbase.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.boolean
StoreFileReader.passesGeneralRowColBloomFilter
(org.apache.hadoop.hbase.ExtendedCell cell) A method for checking Bloom filters.protected abstract boolean
AbstractMemStore.preUpdate
(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected boolean
CompactingMemStore.preUpdate
(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.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
(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) boolean
KeyValueHeap.requestSeek
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell kv, boolean forward, boolean useBloom) boolean
ReversedKeyValueHeap.requestSeek
(org.apache.hadoop.hbase.ExtendedCell key, boolean forward, boolean useBloom) boolean
SegmentScanner.requestSeek
(org.apache.hadoop.hbase.ExtendedCell c, boolean forward, boolean useBloom) boolean
StoreFileScanner.requestSeek
(org.apache.hadoop.hbase.ExtendedCell kv, boolean forward, boolean useBloom) Pretend we have done a seek but don't do it yet, if possible.boolean
KeyValueHeap.reseek
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.ExtendedCell key) Reseek the scanner at or after the specified KeyValue.boolean
ReversedKeyValueHeap.reseek
(org.apache.hadoop.hbase.ExtendedCell seekKey) boolean
ReversedStoreScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell kv) boolean
SegmentScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell cell) Reseek the scanner at or after the specified KeyValue.boolean
SnapshotSegmentScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell seekCell) boolean
StoreFileScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell key) boolean
StoreScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell kv) org.apache.hadoop.hbase.mob.MobCell
HMobStore.resolve
(org.apache.hadoop.hbase.ExtendedCell reference, boolean cacheBlocks) Reads the cell from the mob file, and the read point does not count.org.apache.hadoop.hbase.mob.MobCell
HMobStore.resolve
(org.apache.hadoop.hbase.ExtendedCell reference, boolean cacheBlocks, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file with readEmptyValueOnMobCellMissorg.apache.hadoop.hbase.mob.MobCell
HMobStore.resolve
(org.apache.hadoop.hbase.ExtendedCell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file.protected void
HRegion.restoreEdit
(org.apache.hadoop.hbase.regionserver.HStore s, org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreAccounting) Used by testsboolean
KeyValueHeap.seek
(org.apache.hadoop.hbase.ExtendedCell seekKey) Seeks all scanners at or below the specified seek key.boolean
KeyValueScanner.seek
(org.apache.hadoop.hbase.ExtendedCell key) Seek the scanner at or after the specified KeyValue.boolean
ReversedKeyValueHeap.seek
(org.apache.hadoop.hbase.ExtendedCell seekKey) boolean
ReversedStoreScanner.seek
(org.apache.hadoop.hbase.ExtendedCell key) boolean
SegmentScanner.seek
(org.apache.hadoop.hbase.ExtendedCell cell) Seek the scanner at or after the specified Cell.boolean
SnapshotSegmentScanner.seek
(org.apache.hadoop.hbase.ExtendedCell seekCell) boolean
StoreFileScanner.seek
(org.apache.hadoop.hbase.ExtendedCell key) boolean
StoreScanner.seek
(org.apache.hadoop.hbase.ExtendedCell key) protected boolean
ReversedStoreScanner.seekAsDirection
(org.apache.hadoop.hbase.ExtendedCell kv) Do a backwardSeek in a reversed StoreScanner(scan backward)protected boolean
StoreScanner.seekAsDirection
(org.apache.hadoop.hbase.ExtendedCell kv) Do a reseek in a normal StoreScanner(scan forward)static boolean
StoreFileScanner.seekAtOrAfter
(org.apache.hadoop.hbase.io.hfile.HFileScanner s, org.apache.hadoop.hbase.ExtendedCell k) Returns false if not found or if k is after the end.protected void
ReversedStoreScanner.seekScanners
(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) protected void
StoreScanner.seekScanners
(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.ExtendedCell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected boolean
ReversedStoreScanner.seekToNextRow
(org.apache.hadoop.hbase.ExtendedCell kv) protected boolean
StoreScanner.seekToNextRow
(org.apache.hadoop.hbase.ExtendedCell c) boolean
KeyValueScanner.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell key) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
NonReversedNonLazyKeyValueScanner.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell key) boolean
ReversedKeyValueHeap.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell seekKey) boolean
ReversedStoreScanner.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell key) boolean
SegmentScanner.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell cell) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
StoreFileScanner.seekToPreviousRow
(org.apache.hadoop.hbase.ExtendedCell originalKey) protected void
StoreFileScanner.setCurrentCell
(org.apache.hadoop.hbase.ExtendedCell newVal) protected SortedSet<org.apache.hadoop.hbase.ExtendedCell>
CompositeImmutableSegment.tailSet
(org.apache.hadoop.hbase.ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<org.apache.hadoop.hbase.ExtendedCell>
Segment.tailSet
(org.apache.hadoop.hbase.ExtendedCell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected boolean
StoreScanner.trySkipToNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) SeeStoreScanner.trySkipToNextRow(ExtendedCell)
protected boolean
StoreScanner.trySkipToNextRow
(org.apache.hadoop.hbase.ExtendedCell cell) See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).protected void
CompositeImmutableSegment.updateMetaInfo
(org.apache.hadoop.hbase.ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(org.apache.hadoop.hbase.ExtendedCell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(org.apache.hadoop.hbase.ExtendedCell cellToAdd, boolean succ, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) void
MutableSegment.upsert
(org.apache.hadoop.hbase.ExtendedCell cell, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Modifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) void
HStore.add
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoid
MemStore.add
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Write the updatesdefault void
CellSink.appendAll
(List<org.apache.hadoop.hbase.ExtendedCell> cellList) Append the given (possibly partial) list of cells of a rowvoid
StoreFileWriter.appendAll
(List<org.apache.hadoop.hbase.ExtendedCell> cellList) protected org.apache.hadoop.hbase.ExtendedCell
AbstractMemStore.getNextRow
(org.apache.hadoop.hbase.ExtendedCell key, NavigableSet<org.apache.hadoop.hbase.ExtendedCell> set) default boolean
InternalScanner.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> result) Grab the next row's worth of values.boolean
InternalScanner.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Grab the next row's worth of values.boolean
KeyValueHeap.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Gets the next row of keys from the top-most scanner.boolean
MobStoreScanner.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx) Firstly reads the cells from the HBase.boolean
ReversedMobStoreScanner.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx) Firstly reads the cells from the HBase.boolean
StoreScanner.next
(List<? super org.apache.hadoop.hbase.ExtendedCell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Get the next row of values from this Store.boolean
RegionScanner.nextRaw
(List<? super org.apache.hadoop.hbase.ExtendedCell> result) Grab the next row's worth of values.boolean
RegionScanner.nextRaw
(List<? super org.apache.hadoop.hbase.ExtendedCell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Grab the next row's worth of values.protected org.apache.hadoop.hbase.regionserver.Segment
Segment.setCellSet
(org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell> cellSetOld, org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell> cellSetNew) Setting the CellSet of the segment - used only for flat immutable segment for setting immutable CellSet after its creation in immutable segment constructorvoid
AbstractMemStore.upsert
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) void
HStore.upsert
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.void
MemStore.upsert
(Iterable<org.apache.hadoop.hbase.ExtendedCell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Update or insert the specified cells.ModifierConstructorDescriptionprotected
MutableSegment
(org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell> cellSet, CellComparator comparator, org.apache.hadoop.hbase.regionserver.MemStoreLAB memStoreLAB, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) protected
Segment
(org.apache.hadoop.hbase.regionserver.CellSet<org.apache.hadoop.hbase.ExtendedCell> cellSet, CellComparator comparator, org.apache.hadoop.hbase.regionserver.MemStoreLAB memStoreLAB, org.apache.hadoop.hbase.regionserver.TimeRangeTracker trt) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.regionserver.querymatcher
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.currentRow
Row the query is onprotected org.apache.hadoop.hbase.ExtendedCell
ScanDeleteTracker.deleteCell
protected final org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.startKey
Key to seek to in memstore and StoreFilesModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.createStartKeyFromRow
(byte[] startRow, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo) org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.currentRow()
Returns a cell represent the current roworg.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.getKeyForNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
CompactionScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) abstract org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) Delegate toFilter.getNextCellHint(Cell)
.org.apache.hadoop.hbase.ExtendedCell
UserScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.getStartKey()
Returns the start keyModifier and TypeMethodDescriptionvoid
DeleteTracker.add
(org.apache.hadoop.hbase.ExtendedCell cell) Add the specified cell to the list of deletes to check against for this row operation.void
NewVersionBehaviorTracker.add
(org.apache.hadoop.hbase.ExtendedCell cell) void
ScanDeleteTracker.add
(org.apache.hadoop.hbase.ExtendedCell cell) Add the specified Cell to the list of deletes to check against for this row operation.void
NewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ColumnTracker.checkColumn
(org.apache.hadoop.hbase.ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ExplicitColumnTracker.checkColumn
(org.apache.hadoop.hbase.ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
NewVersionBehaviorTracker.checkColumn
(org.apache.hadoop.hbase.ExtendedCell cell, byte type) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanWildcardColumnTracker.checkColumn
(org.apache.hadoop.hbase.ExtendedCell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanQueryMatcher.checkDeleted
(org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker deletes, org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ColumnTracker.checkVersions
(org.apache.hadoop.hbase.ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ExplicitColumnTracker.checkVersions
(org.apache.hadoop.hbase.ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
NewVersionBehaviorTracker.checkVersions
(org.apache.hadoop.hbase.ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanWildcardColumnTracker.checkVersions
(org.apache.hadoop.hbase.ExtendedCell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.int
ScanQueryMatcher.compareKeyForNextColumn
(org.apache.hadoop.hbase.ExtendedCell nextIndexed, org.apache.hadoop.hbase.ExtendedCell currentCell) int
ScanQueryMatcher.compareKeyForNextRow
(org.apache.hadoop.hbase.ExtendedCell nextIndexed, org.apache.hadoop.hbase.ExtendedCell currentCell) default void
ColumnTracker.doneWithColumn
(org.apache.hadoop.hbase.ExtendedCell cell) This method is used to inform the column tracker that we are done with this column.void
ExplicitColumnTracker.doneWithColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.getKeyForNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.ExtendedCell
CompactionScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) abstract org.apache.hadoop.hbase.ExtendedCell
ScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) Delegate toFilter.getNextCellHint(Cell)
.org.apache.hadoop.hbase.ExtendedCell
UserScanQueryMatcher.getNextKeyHint
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ColumnTracker.getNextRowOrNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) Retrieve the MatchCode for the next row or columnorg.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ExplicitColumnTracker.getNextRowOrNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
NewVersionBehaviorTracker.getNextRowOrNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanWildcardColumnTracker.getNextRowOrNextColumn
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
DeleteTracker.isDeleted
(org.apache.hadoop.hbase.ExtendedCell cell) Check if the specified cell buffer has been deleted by a previously seen delete.org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
NewVersionBehaviorTracker.isDeleted
(org.apache.hadoop.hbase.ExtendedCell cell) This method is not idempotent, we will save some info to judge VERSION_MASKED.org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResult
ScanDeleteTracker.isDeleted
(org.apache.hadoop.hbase.ExtendedCell cell) Check if the specified Cell buffer has been deleted by a previously seen delete.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
IncludeAllCompactionQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
MajorCompactionScanQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
MinorCompactionScanQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
NormalUserScanQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
RawScanQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) abstract org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanQueryMatcher.match
(org.apache.hadoop.hbase.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)org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
StripeCompactionScanQueryMatcher.match
(org.apache.hadoop.hbase.ExtendedCell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
UserScanQueryMatcher.matchColumn
(org.apache.hadoop.hbase.ExtendedCell cell, long timestamp, byte typeByte) boolean
CompactionScanQueryMatcher.moreRowsMayExistAfter
(org.apache.hadoop.hbase.ExtendedCell cell) abstract boolean
ScanQueryMatcher.moreRowsMayExistAfter
(org.apache.hadoop.hbase.ExtendedCell cell) boolean
UserScanQueryMatcher.moreRowsMayExistAfter
(org.apache.hadoop.hbase.ExtendedCell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
ScanQueryMatcher.preCheck
(org.apache.hadoop.hbase.ExtendedCell cell) Check before the delete logic.protected long
NewVersionBehaviorTracker.prepare
(org.apache.hadoop.hbase.ExtendedCell cell) Reset the map if it is different with the last Cell.void
ScanQueryMatcher.setToNewRow
(org.apache.hadoop.hbase.ExtendedCell currentRow) Set the row when there is change in rowprotected final void
CompactionScanQueryMatcher.trackDelete
(org.apache.hadoop.hbase.ExtendedCell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCode
DropDeletesCompactionScanQueryMatcher.tryDropDelete
(org.apache.hadoop.hbase.ExtendedCell cell) ModifierConstructorDescriptionprotected
ScanQueryMatcher
(org.apache.hadoop.hbase.ExtendedCell startKey, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo, org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker columns, long oldestUnexpiredTS, long now) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionvoid
WALCellCodec.EnsureKvEncoder.write
(org.apache.hadoop.hbase.ExtendedCell cell) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
BulkLoadCellFilter.filterCell
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
BulkLoadCellFilter.filterCell
(org.apache.hadoop.hbase.ExtendedCell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate. -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.ExtendedCell
ProtobufUtil.toCell
(org.apache.hadoop.hbase.ExtendedCellBuilder cellBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.Cell cell, boolean decodeTags) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.Cell
ProtobufUtil.toCell
(org.apache.hadoop.hbase.ExtendedCell kv, boolean encodeTags) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.util.MapReduceExtendedCell
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ExtendedCell
MapReduceExtendedCell.deepClone()
org.apache.hadoop.hbase.ExtendedCell
CollectionBackedScanner.next()
org.apache.hadoop.hbase.ExtendedCell
CollectionBackedScanner.peek()
Modifier and TypeMethodDescriptionprotected abstract boolean
BloomContext.isNewKey
(org.apache.hadoop.hbase.ExtendedCell cell) Returns true if the cell is a new key as per the bloom typeprotected boolean
RowBloomContext.isNewKey
(org.apache.hadoop.hbase.ExtendedCell cell) protected boolean
RowColBloomContext.isNewKey
(org.apache.hadoop.hbase.ExtendedCell cell) boolean
CollectionBackedScanner.reseek
(org.apache.hadoop.hbase.ExtendedCell seekCell) boolean
CollectionBackedScanner.seek
(org.apache.hadoop.hbase.ExtendedCell seekCell) void
BloomContext.writeBloom
(org.apache.hadoop.hbase.ExtendedCell cell) Bloom information from the cell is retrievedvoid
RowPrefixFixedLengthBloomContext.writeBloom
(org.apache.hadoop.hbase.ExtendedCell cell) ModifierConstructorDescriptionCollectionBackedScanner
(CellComparator comparator, org.apache.hadoop.hbase.ExtendedCell... array) MapReduceExtendedCell
(org.apache.hadoop.hbase.ExtendedCell cell) ModifierConstructorDescriptionCollectionBackedScanner
(List<org.apache.hadoop.hbase.ExtendedCell> list) CollectionBackedScanner
(List<org.apache.hadoop.hbase.ExtendedCell> list, CellComparator comparator) CollectionBackedScanner
(SortedSet<org.apache.hadoop.hbase.ExtendedCell> set) CollectionBackedScanner
(SortedSet<org.apache.hadoop.hbase.ExtendedCell> set, CellComparator comparator) -
Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.ExtendedCell>
WALEditInternalHelper.getExtendedCells
(org.apache.hadoop.hbase.wal.WALEdit edit) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.wal.WALEdit
WALEditInternalHelper.addExtendedCell
(org.apache.hadoop.hbase.wal.WALEdit edit, org.apache.hadoop.hbase.ExtendedCell cell) WALPrettyPrinter.toStringMap
(org.apache.hadoop.hbase.ExtendedCell cell) WALPrettyPrinter.toStringMap
(org.apache.hadoop.hbase.ExtendedCell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues) Modifier and TypeMethodDescriptionstatic void
WALEditInternalHelper.addExtendedCell
(org.apache.hadoop.hbase.wal.WALEdit edit, List<org.apache.hadoop.hbase.ExtendedCell> cells) static void
WALEditInternalHelper.addMap
(org.apache.hadoop.hbase.wal.WALEdit edit, Map<byte[], List<org.apache.hadoop.hbase.ExtendedCell>> familyMap) static void
WALEditInternalHelper.setExtendedCells
(org.apache.hadoop.hbase.wal.WALEdit edit, ArrayList<org.apache.hadoop.hbase.ExtendedCell> cells)