Uses of Interface
org.apache.hadoop.hbase.Cell
Package
Description
Provides HBase Client
Provides client classes for invoking Coprocessor RPC protocols
Overview
Example Usage
Table of Contents
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
HBase REST
Provides an HBase Thrift
service.
Provides an HBase Thrift
service.
-
Uses of Cell in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
Extension toCell
with server side required functions.interface
An extended version of Cell that allows CPs manipulate Tags.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 TypeMethodDescriptionCellBuilder.build()
static Cell
CellUtil.cloneIfNecessary
(Cell cell) static Cell
CellUtil.createCell
(byte[] row) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] value) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] family, byte[] qualifier) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, byte[] tags, long memstoreTS) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, long memstoreTS) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] row, byte[] family, byte[] qualifier, long timestamp, KeyValue.Type type, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(byte[] rowArray, int rowOffset, int rowLength, byte[] familyArray, int familyOffset, int familyLength, byte[] qualifierArray, int qualifierOffset, int qualifierLength) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(Cell cell, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(Cell cell, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(Cell cell, List<Tag> tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
PrivateCellUtil.createCell
(Cell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static Cell
PrivateCellUtil.createCell
(Cell cell, byte[] value, byte[] tags) static Cell
PrivateCellUtil.createCell
(Cell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static Cell
RawCell.createCell
(Cell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static Cell
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 Cell
PrivateCellUtil.createFirstOnNextRow
(Cell cell) static Cell
PrivateCellUtil.createFirstOnRow
(byte[] row) static Cell
PrivateCellUtil.createFirstOnRow
(byte[] row, byte[] family, byte[] col) static Cell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength) static Cell
PrivateCellUtil.createFirstOnRow
(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength) static Cell
PrivateCellUtil.createFirstOnRow
(Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static Cell
PrivateCellUtil.createFirstOnRowCol
(Cell cell) static Cell
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 Cell
PrivateCellUtil.createFirstOnRowColTS
(Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static Cell
PrivateCellUtil.createFirstOnRowFamily
(Cell cell, byte[] fArray, int foff, int flen) static Cell
PrivateCellUtil.createLastOnRow
(byte[] row) static Cell
PrivateCellUtil.createLastOnRow
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static Cell
PrivateCellUtil.createLastOnRowCol
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static Cell
PrivateCellUtil.createNextOnRowCol
(Cell cell) Return a new cell is located following input cell.(package private) static Cell
PrivateCellUtil.createNextOnRowCol
(Cell cell, long ts, byte type) CellScanner.current()
Returns the current Cell which may be mutablestatic Cell
Deep clones the given cell if the cell supports deep cloningModifier and TypeMethodDescriptionCellComparator.getSimpleComparator()
Return a dumbed-down, fast comparator for hbase2 base-type, theByteBufferKeyValue
.Modifier and TypeMethodDescriptionstatic int
KeyValueUtil.appendKeyTo
(Cell cell, byte[] output, int offset) static int
KeyValueUtil.appendKeyTo
(Cell cell, ByteBuffer buf, int offset) static int
KeyValueUtil.appendTo
(Cell cell, ByteBuffer buf, int offset, boolean withTags) Copy the Cell content into the passed buf in KeyValue serialization format.static int
KeyValueUtil.appendToByteArray
(Cell cell, byte[] output, int offset, boolean withTags) copy key and valueprivate int
KeyValue.calculateHashForKey
(Cell cell) TagUtil.carryForwardTags
(List<Tag> tagsOrNull, Cell cell) Add totagsOrNull
any Tagscell
is carrying or null if none.TagUtil.carryForwardTags
(Cell cell) Returns A List<Tag> of any Tags found incell
else null.static byte[]
CellUtil.cloneFamily
(Cell cell) static Cell
CellUtil.cloneIfNecessary
(Cell cell) static byte[]
CellUtil.cloneQualifier
(Cell cell) static byte[]
get individual arrays for testsstatic byte[]
Deprecated.As of HBase-2.0.static byte[]
static byte[]
CellUtil.cloneValue
(Cell cell) int
Lexographically compares two cells.int
Compare cells.final int
int
static final int
CellUtil.compare
(CellComparator comparator, Cell left, byte[] key, int offset, int length) Deprecated.As of HBase-2.0.int
Deprecated.Compares the Key of a cell -- with fields being more significant in this order: rowkey, colfam/qual, timestamp, type, mvccint
Deprecated.Compare key portion of aKeyValue
for keys inhbase:meta
table.int
static final int
PrivateCellUtil.compare
(CellComparator comparator, Cell left, byte[] key, int offset, int length) Used when a cell needs to be compared with a key byte[] such as cases of finding the index from the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this method cannot be used.private int
CellComparatorImpl.compareColumns
(Cell left, int leftFamLen, int leftQualLen, Cell right, int rightFamLen, int rightQualLen) final int
CellComparatorImpl.compareColumns
(Cell left, Cell right) Compares the family and qualifier part of the cellstatic final int
CellUtil.compareColumns
(Cell left, byte[] right, int rfoffset, int rflength, int rqoffset, int rqlength) Compares the cell's column (family and qualifier) with the given byte[](package private) int
KeyValue.KVComparator.compareColumns
(Cell left, short lrowlength, Cell right, short rrowlength) Deprecated.int
CellComparator.compareFamilies
(Cell leftCell, Cell rightCell) Lexicographically compares the families of the two cellsprotected int
CellComparatorImpl.compareFamilies
(Cell left, int leftFamLen, Cell right, int rightFamLen) This method will be overridden when we compare cells inner store to bypass family comparing.final int
CellComparatorImpl.compareFamilies
(Cell left, Cell right) Compare the families of left and right cellstatic final int
CellUtil.compareFamilies
(Cell left, byte[] right, int roffset, int rlength) Compares the cell's family with the given byte[]protected int
InnerStoreCellComparator.compareFamilies
(Cell left, int leftFamilyLength, Cell right, int rightFamilyLength) static int
PrivateCellUtil.compareFamily
(Cell cell, ByteArrayComparable comparator) Compare cell's column family against given comparatorint
KeyValue.KVComparator.compareKey
(Cell cell, byte[] row, int roff, int rlen, byte[] fam, int foff, int flen, byte[] col, int coff, int clen, long ts, byte type) Deprecated.static final int
PrivateCellUtil.compareKeyBasedOnColHint
(CellComparator comparator, Cell nextIndexedCell, Cell currentCell, int foff, int flen, byte[] colHint, int coff, int clen, long ts, byte type) Used to compare two cells based on the column hint provided.static final int
PrivateCellUtil.compareKeyIgnoresMvcc
(CellComparator comparator, Cell left, Cell right) Compares only the key portion of a cell.int
KeyValue.KVComparator.compareOnlyKeyPortion
(Cell left, Cell right) Deprecated.int
KeyValue.MetaComparator.compareOnlyKeyPortion
(Cell left, Cell right) Deprecated.static int
PrivateCellUtil.compareQualifier
(Cell cell, ByteArrayComparable comparator) Compare cell's qualifier against given comparatorint
CellComparator.compareQualifiers
(Cell leftCell, Cell rightCell) Lexicographically compares the qualifiers of the two cellsprivate final int
CellComparatorImpl.compareQualifiers
(Cell left, int leftQualLen, Cell right, int rightQualLen) final int
CellComparatorImpl.compareQualifiers
(Cell left, Cell right) Compare the qualifiers part of the left and right cells.static final int
CellUtil.compareQualifiers
(Cell left, byte[] right, int rOffset, int rLength) Compares the cell's qualifier with the given byte[]static int
PrivateCellUtil.compareRow
(Cell cell, ByteArrayComparable comparator) Compare cell's row against given comparatorprotected int
KeyValue.KVComparator.compareRowKey
(Cell left, Cell right) Deprecated.Compares the only the user specified portion of a Key.protected int
KeyValue.MetaComparator.compareRowKey
(Cell l, Cell r) Deprecated.Override the row key comparison to parse and compare the meta row key parts.default int
CellComparator.compareRows
(ByteBuffer row, Cell cell) Lexicographically compare two rowsint
CellComparator.compareRows
(Cell cell, byte[] bytes, int offset, int length) Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.int
CellComparator.compareRows
(Cell leftCell, Cell rightCell) Lexographically compares the rows of two cells.int
CellComparatorImpl.compareRows
(Cell left, byte[] right, int roffset, int rlength) Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.(package private) static int
CellComparatorImpl.compareRows
(Cell left, int leftRowLength, Cell right, int rightRowLength) int
CellComparatorImpl.compareRows
(Cell left, Cell right) Compares the rows of the left and right cell.int
KeyValue.KVComparator.compareRows
(Cell left, Cell right) Deprecated.Compares the rows of a cellint
MetaCellComparator.compareRows
(ByteBuffer row, Cell cell) int
MetaCellComparator.compareRows
(Cell left, byte[] right, int roffset, int rlength) int
MetaCellComparator.compareRows
(Cell left, Cell right) int
CellComparator.compareTimestamps
(Cell leftCell, Cell rightCell) Compares cell's timestamps in DESCENDING order.int
CellComparatorImpl.compareTimestamps
(Cell left, Cell right) int
KeyValue.KVComparator.compareTimestamps
(Cell left, Cell right) Deprecated.static int
PrivateCellUtil.compareValue
(Cell cell, ByteArrayComparable comparator) Compare cell's value against given comparatorint
CellComparator.compareWithoutRow
(Cell leftCell, Cell rightCell) Lexicographically compares the two cells excluding the row part.final int
CellComparatorImpl.compareWithoutRow
(Cell left, Cell right) (package private) static final int
PrivateCellUtil.compareWithoutRow
(CellComparator comparator, Cell left, byte[] right, int roffset, int rlength, short rowlength) Compare columnFamily, qualifier, timestamp, and key type (everything except the row).static void
PrivateCellUtil.compressFamily
(OutputStream out, Cell cell, Dictionary dict) static void
PrivateCellUtil.compressQualifier
(OutputStream out, Cell cell, Dictionary dict) static void
PrivateCellUtil.compressRow
(OutputStream out, Cell cell, Dictionary dict) static void
PrivateCellUtil.compressTags
(OutputStream out, Cell cell, TagCompressionContext tagCompressionContext) Compresses the tags to the given outputstream using the TagcompressionContextstatic byte[]
TagUtil.concatTags
(byte[] tags, Cell cell) static int
CellUtil.copyFamilyTo
(Cell cell, byte[] destination, int destinationOffset) Copies the family to the given byte[]static int
CellUtil.copyFamilyTo
(Cell cell, ByteBuffer destination, int destinationOffset) Copies the family to the given bytebufferstatic ByteBuffer
KeyValueUtil.copyKeyToNewByteBuffer
(Cell cell) The position will be set to the beginning of the new ByteBufferstatic int
CellUtil.copyQualifierTo
(Cell cell, byte[] destination, int destinationOffset) Copies the qualifier to the given byte[]static int
CellUtil.copyQualifierTo
(Cell cell, ByteBuffer destination, int destinationOffset) Copies the qualifier to the given bytebufferstatic byte[]
Copies the row to a new byte[]static int
Copies the row to the given byte[]static int
CellUtil.copyRowTo
(Cell cell, ByteBuffer destination, int destinationOffset) Copies the row to the given bytebufferstatic int
PrivateCellUtil.copyTagsTo
(Cell cell, byte[] destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic int
PrivateCellUtil.copyTagsTo
(Cell cell, ByteBuffer destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic int
Deprecated.As of HBase-2.0.static int
CellUtil.copyTagTo
(Cell cell, ByteBuffer destination, int destinationOffset) Deprecated.As of HBase-2.0.static byte[]
KeyValueUtil.copyToNewByteArray
(Cell cell) static KeyValue
KeyValueUtil.copyToNewKeyValue
(Cell cell) copy the cell to create a new keyvaluestatic int
CellUtil.copyValueTo
(Cell cell, byte[] destination, int destinationOffset) Copies the value to the given byte[]static int
CellUtil.copyValueTo
(Cell cell, ByteBuffer destination, int destinationOffset) Copies the value to the given bytebufferstatic Cell
CellUtil.createCell
(Cell cell, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(Cell cell, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
CellUtil.createCell
(Cell cell, List<Tag> tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static Cell
PrivateCellUtil.createCell
(Cell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static Cell
PrivateCellUtil.createCell
(Cell cell, byte[] value, byte[] tags) static Cell
PrivateCellUtil.createCell
(Cell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static Cell
RawCell.createCell
(Cell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.static CellScanner
CellUtil.createCellScanner
(Cell[] cellArray) Returns CellScanner interface overcellArray
static Cell
PrivateCellUtil.createFirstOnNextRow
(Cell cell) static Cell
PrivateCellUtil.createFirstOnRow
(Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static Cell
PrivateCellUtil.createFirstOnRowCol
(Cell cell) static Cell
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 Cell
PrivateCellUtil.createFirstOnRowColTS
(Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static Cell
PrivateCellUtil.createFirstOnRowFamily
(Cell cell, byte[] fArray, int foff, int flen) static Cell
PrivateCellUtil.createLastOnRow
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static Cell
PrivateCellUtil.createLastOnRowCol
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static Cell
PrivateCellUtil.createNextOnRowCol
(Cell cell) Return a new cell is located following input cell.(package private) static Cell
PrivateCellUtil.createNextOnRowCol
(Cell cell, long ts, byte type) static Cell
Deep clones the given cell if the cell supports deep cloningstatic KeyValue
KeyValueUtil.ensureKeyValue
(Cell cell) Deprecated.without any replacement.static boolean
equalsstatic boolean
CellUtil.equalsIgnoreMvccVersion
(Cell a, Cell b) Deprecated.As of HBase-2.0.static boolean
PrivateCellUtil.equalsIgnoreMvccVersion
(Cell a, Cell b) special case for Cell.equalsstatic long
CellUtil.estimatedHeapSizeOf
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static int
CellUtil.estimatedSerializedSizeOf
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static int
PrivateCellUtil.estimatedSerializedSizeOf
(Cell cell) Estimate based on keyvalue's serialization format in the RPC layer.static int
CellUtil.estimatedSerializedSizeOfKey
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static int
PrivateCellUtil.estimatedSerializedSizeOfKey
(Cell cell) Calculates the serialized key size.static ByteRange
CellUtil.fillFamilyRange
(Cell cell, ByteRange range) Deprecated.As of HBase-2.0.static ByteRange
PrivateCellUtil.fillFamilyRange
(Cell cell, ByteRange range) static ByteRange
CellUtil.fillQualifierRange
(Cell cell, ByteRange range) Deprecated.As of HBase-2.0.static ByteRange
PrivateCellUtil.fillQualifierRange
(Cell cell, ByteRange range) static ByteRange
CellUtil.fillRowRange
(Cell cell, ByteRange range) Deprecated.As of HBase-2.0.static ByteRange
PrivateCellUtil.fillRowRange
(Cell cell, ByteRange range) ByteRangestatic ByteRange
CellUtil.fillTagRange
(Cell cell, ByteRange range) Deprecated.As of HBase-2.0.static ByteRange
PrivateCellUtil.fillTagRange
(Cell cell, ByteRange range) static ByteRange
CellUtil.fillValueRange
(Cell cell, ByteRange range) Deprecated.As of HBase-2.0.static ByteRange
PrivateCellUtil.fillValueRange
(Cell cell, ByteRange range) static int
CellUtil.findCommonPrefixInFlatKey
(Cell c1, Cell c2, boolean bypassFamilyCheck, boolean withTsType) Deprecated.As of HBase-2.0.static int
PrivateCellUtil.findCommonPrefixInFlatKey
(Cell c1, Cell c2, boolean bypassFamilyCheck, boolean withTsType) Find length of common prefix in keys of the cells, considering key as byte[] if serialized inKeyValue
.static String
CellUtil.getCellKeyAsString
(Cell cell) Return the key portion of the passedcell
as a String.static String
CellUtil.getCellKeyAsString
(Cell cell, Function<Cell, String> rowConverter) Return the Key portion of the passedcell
as a String.static byte[]
CellUtil.getCellKeySerializedAsKeyValueKey
(Cell cell) Deprecated.As of HBase-2.0.static byte[]
PrivateCellUtil.getCellKeySerializedAsKeyValueKey
(Cell cell) This method exists just to encapsulate how we serialize keys.static List<RegionInfo>
MetaTableAccessor.getMergeRegions
(Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells
.static Map<String,
RegionInfo> MetaTableAccessor.getMergeRegionsWithName
(Cell[] cells) Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array ofcells
.static ByteBuffer
CellUtil.getQualifierBufferShallowCopy
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static byte
PrivateCellUtil.getQualifierByte
(Cell cell, int index) private static long
MetaTableAccessor.getReplicationBarrier
(Cell c) static int
PrivateCellUtil.getRowAsInt
(Cell cell) Converts the rowkey bytes of the given cell into an int valuestatic byte
CellUtil.getRowByte
(Cell cell, int index) Deprecated.static byte
PrivateCellUtil.getRowByte
(Cell cell, int index) miscstatic int
KeyValueUtil.getSerializedSize
(Cell cell, boolean withTags) private static int
CellUtil.getSumOfCellElementLengths
(Cell cell) Return sum of the lengths of all the elements in a Cell; does not count in any infrastructureprivate static int
CellUtil.getSumOfCellKeyElementLengths
(Cell cell) Return sum of all elements that make up a key; does not include infrastructure, tags or values.static Tag
Deprecated.As of 2.0.0 and will be removed in HBase-3.0.0 UseRawCell.getTag(byte)
Retrieve Cell's first tag, matching the passed in typestatic byte[]
CellUtil.getTagArray
(Cell cell) Deprecated.As of HBase-2.0.Deprecated.As of 2.0.0 and will be removed in 3.0.0Return tags in the given Cell as a Liststatic BigDecimal
PrivateCellUtil.getValueAsBigDecimal
(Cell cell) Converts the value bytes of the given cell into a BigDecimalstatic double
PrivateCellUtil.getValueAsDouble
(Cell cell) Converts the value bytes of the given cell into a double valuestatic int
PrivateCellUtil.getValueAsInt
(Cell cell) Converts the value bytes of the given cell into a int valuestatic long
PrivateCellUtil.getValueAsLong
(Cell cell) Converts the value bytes of the given cell into a long valuestatic ByteBuffer
CellUtil.getValueBufferShallowCopy
(Cell cell) Deprecated.As of HBase-2.0.static ByteBuffer
PrivateCellUtil.getValueBufferShallowCopy
(Cell cell) static boolean
MetaTableAccessor.hasMergeRegions
(Cell[] cells) Returns True if any merge regions present incells
; i.e.static boolean
Return true if a delete type, aKeyValue.Type.Delete
or a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumn
KeyValue type.static boolean
CellUtil.isDeleteColumnOrFamily
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteColumnOrFamily
(Cell cell) Returns True if this cell is a delete family or column type.static boolean
CellUtil.isDeleteColumns
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteColumns
(Cell cell) static boolean
CellUtil.isDeleteColumnVersion
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteColumnVersion
(Cell cell) static boolean
CellUtil.isDeleteFamily
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteFamily
(Cell cell) static boolean
CellUtil.isDeleteFamilyVersion
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteFamilyVersion
(Cell cell) static boolean
CellUtil.isDeleteType
(Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
PrivateCellUtil.isDeleteType
(Cell cell) Returns True if this cell is aKeyValue.Type.Delete
type.private static boolean
MetaTableAccessor.isMergeQualifierPrefix
(Cell cell) Returns True if the column incell
matches the regex 'info:merge.*'.static boolean
Returns True if this cell is a Put.static int
Returns number of bytes this cell's key part would have been used if serialized as inKeyValue
.static boolean
CellUtil.matchingColumn
(Cell left, byte[] fam, byte[] qual) static boolean
CellUtil.matchingColumn
(Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.private static boolean
CellUtil.matchingColumn
(Cell left, byte lFamLen, int lQualLength, Cell right, byte rFamLen, int rQualLength) static boolean
CellUtil.matchingColumn
(Cell left, Cell right) static boolean
PrivateCellUtil.matchingColumn
(Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) static boolean
CellUtil.matchingColumnFamilyAndQualifierPrefix
(Cell left, byte[] fam, byte[] qual) Returns True if matching column family and the qualifier starts withqual
static boolean
CellUtil.matchingFamily
(Cell left, byte[] buf) static boolean
CellUtil.matchingFamily
(Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
CellUtil.matchingFamily
(Cell left, byte lfamlength, Cell right, byte rfamlength) static boolean
CellUtil.matchingFamily
(Cell left, Cell right) static boolean
PrivateCellUtil.matchingFamily
(Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingQualifier
(Cell left, byte[] buf) Finds if the qualifier part of the cell and the KV serialized byte[] are equal.static boolean
CellUtil.matchingQualifier
(Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.private static boolean
CellUtil.matchingQualifier
(Cell left, int lqlength, Cell right, int rqlength) static boolean
CellUtil.matchingQualifier
(Cell left, Cell right) static boolean
PrivateCellUtil.matchingQualifier
(Cell left, byte[] buf, int offset, int length) Finds if the qualifier part of the cell and the KV serialized byte[] are equalstatic boolean
CellUtil.matchingRow
(Cell left, byte[] buf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
CellUtil.matchingRow
(Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
CellUtil.matchingRow
(Cell left, Cell right) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static boolean
CellUtil.matchingRowColumn
(Cell left, Cell right) Compares the row and column of two keyvalues for equalityboolean
KeyValue.KVComparator.matchingRowColumn
(Cell left, Cell right) Deprecated.Compares the row and column of two keyvalues for equalitystatic boolean
CellUtil.matchingRowColumnBytes
(Cell left, Cell right) Compares the row and column of two keyvalues for equalitystatic boolean
CellUtil.matchingRows
(Cell left, byte[] buf) static boolean
CellUtil.matchingRows
(Cell left, short lrowlength, Cell right, short rrowlength) Compares the row of two keyvalues for equalitystatic boolean
CellUtil.matchingRows
(Cell left, Cell right) Compares the row of two keyvalues for equalityprivate boolean
KeyValue.KVComparator.matchingRows
(Cell left, short lrowlength, Cell right, short rrowlength) Deprecated.Compares the row of two keyvalues for equalityboolean
KeyValue.KVComparator.matchingRows
(Cell left, Cell right) Deprecated.Compares the row of two keyvalues for equalitystatic boolean
PrivateCellUtil.matchingRows
(Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingTags
(Cell left, Cell right) static boolean
PrivateCellUtil.matchingTags
(Cell left, Cell right, int llength, int rlength) static boolean
CellUtil.matchingTimestamp
(Cell a, Cell b) static boolean
CellUtil.matchingType
(Cell a, Cell b) Deprecated.As of HBase-2.0.static boolean
PrivateCellUtil.matchingType
(Cell a, Cell b) static boolean
CellUtil.matchingValue
(Cell left, byte[] buf) static boolean
CellUtil.matchingValue
(Cell left, Cell right) static boolean
PrivateCellUtil.matchingValue
(Cell left, Cell right, int lvlength, int rvlength) static int
KeyValueUtil.oswrite
(Cell cell, OutputStream out, boolean withTags) static boolean
PrivateCellUtil.qualifierStartsWith
(Cell left, byte[] startsWith) Finds if the start of the qualifier part of the Cell matchesbuf
static void
CellUtil.setSequenceId
(Cell cell, long seqId) Deprecated.As of HBase-2.0.static void
PrivateCellUtil.setSequenceId
(Cell cell, long seqId) Sets the given seqId to the cell.static void
CellUtil.setTimestamp
(Cell cell, byte[] ts, int tsOffset) Deprecated.As of HBase-2.0.static void
CellUtil.setTimestamp
(Cell cell, long ts) Deprecated.As of HBase-2.0.static void
PrivateCellUtil.setTimestamp
(Cell cell, byte[] ts) Sets the given timestamp to the cell.static void
PrivateCellUtil.setTimestamp
(Cell cell, long ts) Sets the given timestamp to the cell.PrivateCellUtil.tagsIterator
(Cell cell) Utility method to iterate through the tags in the given cell.static KeyValue
KeyValueUtil.toNewKeyCell
(Cell cell) Copies the key to a new KeyValuestatic String
Returns a string representation of the cellstatic boolean
CellUtil.updateLatestStamp
(Cell cell, byte[] ts, int tsOffset) Deprecated.As of HBase-2.0.static boolean
CellUtil.updateLatestStamp
(Cell cell, long ts) Deprecated.As of HBase-2.0.static boolean
PrivateCellUtil.updateLatestStamp
(Cell cell, byte[] ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP
.static boolean
PrivateCellUtil.updateLatestStamp
(Cell 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, Cell 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, Cell cell, byte[] value, byte[] tags) Made into a static method so as to reuse the logic within ValueAndTagRewriteByteBufferExtendedCellstatic int
PrivateCellUtil.writeCell
(Cell cell, OutputStream out, boolean withTags) Writes the cell to the given OutputStreamstatic void
PrivateCellUtil.writeCellToBuffer
(Cell cell, ByteBuffer buf, int offset) Writes a cell to the buffer at the given offsetstatic void
PrivateCellUtil.writeFamily
(OutputStream out, Cell cell, byte flength) Writes the family from the given cell to the output streamstatic void
CellUtil.writeFlatKey
(Cell cell, DataOutputStream out) Deprecated.As of HBase-2.0.static void
PrivateCellUtil.writeFlatKey
(Cell cell, DataOutput out) Writes the Cell's key part as it would have serialized in a KeyValue.static int
PrivateCellUtil.writeFlatKey
(Cell cell, OutputStream out) static void
PrivateCellUtil.writeQualifier
(OutputStream out, Cell cell, int qlength) Writes the qualifier from the given cell to the output streamstatic void
PrivateCellUtil.writeQualifierSkippingBytes
(DataOutputStream out, Cell cell, int qlength, int commonPrefix) Writes the qualifier from the given cell to the output stream excluding the common prefixstatic void
PrivateCellUtil.writeRow
(OutputStream out, Cell cell, short rlength) Writes the row from the given cell to the output streamstatic void
CellUtil.writeRowKeyExcludingCommon
(Cell cell, short rLen, int commonPrefix, DataOutputStream out) Deprecated.As of HBase-2.0.static void
PrivateCellUtil.writeRowKeyExcludingCommon
(Cell cell, short rLen, int commonPrefix, DataOutputStream out) Write rowkey excluding the common part.static void
CellUtil.writeRowSkippingBytes
(DataOutputStream out, Cell cell, short rlength, int commonPrefix) Deprecated.As of 2.0.static void
PrivateCellUtil.writeRowSkippingBytes
(DataOutputStream out, Cell cell, short rlength, int commonPrefix) Writes the row from the given cell to the output stream excluding the common prefixstatic void
PrivateCellUtil.writeTags
(OutputStream out, Cell cell, int tagsLength) Writes the tag from the given cell to the output streamstatic void
PrivateCellUtil.writeValue
(OutputStream out, Cell cell, int vlength) Writes the value from the given cell to the output streamModifier and TypeMethodDescriptionstatic void
CellUtil.cloneIfNecessary
(ArrayList<Cell> cells) static boolean
KeyValueTestUtil.containsIgnoreMvccVersion
(Collection<? extends Cell> kvCollection1, Collection<? extends Cell> kvCollection2) Checks whether KeyValues from kvCollection2 are contained in kvCollection1.static CellScanner
CellUtil.createCellScanner
(Iterable<Cell> cellIterable) Returns CellScanner interface overcellIterable
static CellScanner
CellUtil.createCellScanner
(Iterator<Cell> cells) Returns CellScanner interface overcellIterable
or null ifcells
is nullstatic CellScanner
CellUtil.createCellScanner
(NavigableMap<byte[], List<Cell>> map) Flatten the map of cells out under the CellScannerKeyValueUtil.ensureKeyValues
(List<Cell> cells) Deprecated.static String
CellUtil.getCellKeyAsString
(Cell cell, Function<Cell, String> rowConverter) Return the Key portion of the passedcell
as a String.ModifierConstructorDescriptionTagRewriteCell
(Cell cell, byte[] tags) Construct a TagRewriteCellValueAndTagRewriteCell
(Cell cell, byte[] value, byte[] tags) -
Uses of Cell in org.apache.hadoop.hbase.backup.impl
Modifier and TypeMethodDescriptionprivate String
BackupSystemTable.cellKeyToBackupSetName
(Cell current) Converts cell key to backup set name.private BackupInfo
BackupSystemTable.cellToBackupInfo
(Cell current) Converts cell to backup info instance.private String[]
BackupSystemTable.cellValueToBackupSet
(Cell current) Converts cell to backup set list. -
Uses of Cell in org.apache.hadoop.hbase.backup.mapreduce
Modifier and TypeMethodDescriptionvoid
MapReduceHFileSplitterJob.HFileCellMapper.map
(org.apache.hadoop.io.NullWritable key, Cell value, org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.io.NullWritable, Cell, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Mapper.Context context) -
Uses of Cell in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final Cell
Mutation.CellWrapper.cell
private Cell[]
Result.cells
private Cell
AllowPartialScanResultCache.lastCell
private Cell
BatchScanResultCache.lastCell
Modifier and TypeFieldDescriptionprotected NavigableMap<byte[],
List<Cell>> Mutation.familyMap
ClientSideRegionScanner.values
Modifier and TypeMethodDescriptionResult.current()
Result.getColumnLatestCell
(byte[] family, byte[] qualifier) The Cell for the most recent timestamp for a given column.Result.getColumnLatestCell
(byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength) The Cell for the most recent timestamp for a given column.Cell[]
Result.rawCells()
Return the array of Cells backing this Result instance.Modifier and TypeMethodDescriptionMutation.get
(byte[] family, byte[] qualifier) Returns a list of all KeyValue objects with matching column family and qualifier.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.Result.getColumnCells
(byte[] family, byte[] qualifier) Return the Cells for the specific column.NavigableMap<byte[],
List<Cell>> Mutation.getFamilyCellMap()
Method for retrieving the put's familyMapResult.listCells()
Create a sorted list of the Cell's in this result.Modifier and TypeMethodDescriptionAdd column and value to this Append operation.Add an existing delete marker to this Delete object.Add the specified KeyValue to this operation.(package private) Mutation
Add the specified KeyValue to this Put operation.Delete.addDeleteMarker
(Cell kv) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.protected int
Result.binarySearch
(Cell[] kvs, byte[] family, byte[] qualifier) protected int
Result.binarySearch
(Cell[] kvs, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength) Searches for the latest value for the specified column.Mutation.cellToStringMap
(Cell c) static Result
Instantiate a Result with the specified array of KeyValues.static Result
static Result
(package private) static Result
ConnectionUtils.filterCells
(Result result, Cell keepCellsAfter) Modifier and TypeMethodDescriptionstatic Result
Instantiate a Result with the specified List of KeyValues.static Result
static Result
static Result
Append.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Delete.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Increment.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Mutation.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Put.setFamilyCellMap
(NavigableMap<byte[], List<Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.ModifierConstructorDescriptionAppend
(byte[] row, long ts, NavigableMap<byte[], List<Cell>> familyMap) Construct the Append with user defined data.Delete
(byte[] row, long ts, NavigableMap<byte[], List<Cell>> familyMap) Construct the Delete with user defined data.Increment
(byte[] row, long ts, NavigableMap<byte[], List<Cell>> familyMap) Construct the Increment with user defined data.protected
Mutation
(byte[] row, long ts, NavigableMap<byte[], List<Cell>> familyMap) Construct the mutation with user defined data.Put
(byte[] row, long ts, NavigableMap<byte[], List<Cell>> familyMap) Construct the Put with user defined data. -
Uses of Cell in org.apache.hadoop.hbase.client.coprocessor
Modifier and TypeMethodDescription -
Uses of Cell in org.apache.hadoop.hbase.codec
Modifier and TypeFieldDescriptionprivate Cell
BaseDecoder.current
protected Cell
KeyValueCodec.ByteBuffKeyValueDecoder.current
Modifier and TypeMethodDescriptionprotected Cell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected Cell
KeyValueCodec.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) protected Cell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(byte[] buf, int offset, int len) protected Cell
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell
(ByteBuffer bb, int pos, int len) BaseDecoder.current()
KeyValueCodec.ByteBuffKeyValueDecoder.current()
protected abstract Cell
BaseDecoder.parseCell()
Extract a Cell.protected Cell
CellCodec.CellDecoder.parseCell()
protected Cell
CellCodecWithTags.CellDecoder.parseCell()
protected Cell
KeyValueCodec.KeyValueDecoder.parseCell()
protected Cell
KeyValueCodecWithTags.KeyValueDecoder.parseCell()
protected Cell
MessageCodec.MessageDecoder.parseCell()
Modifier and TypeMethodDescriptionabstract void
void
void
void
void
void
-
Uses of Cell in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault Cell
RegionObserver.postMutationBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.Modifier and TypeMethodDescriptionRegionObserver.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.RegionObserver.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.RegionObserver.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.RegionObserver.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.Modifier and TypeMethodDescriptionabstract T
Returns value of type Tdefault Cell
RegionObserver.postMutationBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default boolean
RegionObserver.postScannerFilterRow
(ObserverContext<RegionCoprocessorEnvironment> c, InternalScanner s, Cell curRowCell, boolean hasMore) This will be called by the scan flow when the current scanned row is being filtered out by the filter.default void
RegionObserver.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0.Modifier and TypeMethodDescriptionRegionObserver.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.RegionObserver.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an append operation, but before they are committed to the WAL or memstore.default void
RegionObserver.postGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called after the client performs a GetRegionObserver.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.RegionObserver.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Called after a list of new cells has been created during an increment operation, but before they are committed to the WAL or memstore.void
MetaTableMetrics.ExampleRegionObserverMeta.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) default void
RegionObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called before the client performs a Get -
Uses of Cell in org.apache.hadoop.hbase.coprocessor.example
Modifier and TypeMethodDescriptionprivate Cell
WriteHeavyIncrementObserver.createCell
(byte[] row, byte[] family, byte[] qualifier, long ts, long value) Modifier and TypeMethodDescriptionprivate Delete
BulkDeleteEndpoint.createDeleteMutation
(List<Cell> deleteRow, org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType deleteType, Long timestamp) boolean
DelegatingInternalScanner.next
(List<Cell> result, ScannerContext scannerContext) void
ExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
ExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
WriteHeavyIncrementObserver.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) -
Uses of Cell in org.apache.hadoop.hbase.filter
Modifier and TypeClassDescription(package private) static class
(package private) static class
Modifier and TypeMethodDescriptionprivate Cell
KeyOnlyFilter.createKeyOnlyCell
(Cell c) ColumnPaginationFilter.getNextCellHint
(Cell cell) ColumnPrefixFilter.getNextCellHint
(Cell cell) ColumnRangeFilter.getNextCellHint
(Cell cell) abstract Cell
Filter.getNextCellHint
(Cell currentCell) If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.FilterBase.getNextCellHint
(Cell currentCell) Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.FilterList.getNextCellHint
(Cell currentCell) FilterListWithAND.getNextCellHint
(Cell currentCell) FilterListWithOR.getNextCellHint
(Cell currentCell) FilterWrapper.getNextCellHint
(Cell currentCell) FuzzyRowFilter.getNextCellHint
(Cell currentCell) MultipleColumnPrefixFilter.getNextCellHint
(Cell cell) MultiRowRangeFilter.getNextCellHint
(Cell currentKV) TimestampsFilter.getNextCellHint
(Cell currentCell) Pick the next cell that the scanner should seek to.abstract Cell
Filter.transformCell
(Cell v) Give the filter a chance to transform the passed KeyValue.FilterBase.transformCell
(Cell v) By default no transformation takes place Give the filter a chance to transform the passed KeyValue.FilterList.transformCell
(Cell c) FilterListBase.transformCell
(Cell c) For FilterList, we can consider a filter list as a node in a tree.FilterWrapper.transformCell
(Cell v) KeyOnlyFilter.transformCell
(Cell cell) SkipFilter.transformCell
(Cell v) WhileMatchFilter.transformCell
(Cell v) Modifier and TypeMethodDescriptionprivate Filter.ReturnCode
FilterListWithOR.calculateReturnCodeByPrevCellAndRC
(Filter subFilter, Cell currentCell, Cell prevCell, Filter.ReturnCode prevCode) For MUST_PASS_ONE, we cannot make sure that when filter-A in filter list return NEXT_COL then the next cell passing to filterList will be the first cell in next column, because if filter-B in filter list return SKIP, then the filter list will return SKIP.protected int
FilterListBase.compareCell
(Cell a, Cell b) protected boolean
CompareFilter.compareFamily
(CompareOperator op, ByteArrayComparable comparator, Cell cell) protected boolean
CompareFilter.compareFamily
(CompareFilter.CompareOp compareOp, ByteArrayComparable comparator, Cell cell) Deprecated.Since 2.0.0.protected boolean
CompareFilter.compareQualifier
(CompareOperator op, ByteArrayComparable comparator, Cell cell) protected boolean
CompareFilter.compareQualifier
(CompareFilter.CompareOp compareOp, ByteArrayComparable comparator, Cell cell) Deprecated.Since 2.0.0.private static int
ColumnPrefixFilter.compareQualifierPart
(Cell cell, int length, byte[] prefix) protected boolean
CompareFilter.compareRow
(CompareOperator op, ByteArrayComparable comparator, Cell cell) protected boolean
CompareFilter.compareRow
(CompareFilter.CompareOp compareOp, ByteArrayComparable comparator, Cell cell) Deprecated.Since 2.0.0.private boolean
ColumnValueFilter.compareValue
(CompareOperator op, ByteArrayComparable comparator, Cell cell) This method is used to determine a cell should be included or filtered out.protected boolean
CompareFilter.compareValue
(CompareOperator op, ByteArrayComparable comparator, Cell cell) protected boolean
CompareFilter.compareValue
(CompareFilter.CompareOp compareOp, ByteArrayComparable comparator, Cell cell) Deprecated.Since 2.0.0.private Cell
KeyOnlyFilter.createKeyOnlyCell
(Cell c) ColumnCountGetFilter.filterCell
(Cell c) ColumnPaginationFilter.filterCell
(Cell c) ColumnPrefixFilter.filterCell
(Cell cell) ColumnRangeFilter.filterCell
(Cell c) ColumnValueFilter.filterCell
(Cell c) DependentColumnFilter.filterCell
(Cell c) FamilyFilter.filterCell
(Cell c) Filter.filterCell
(Cell c) A way to filter based on the column family, column qualifier and/or the column value.FilterList.filterCell
(Cell c) FilterListWithAND.filterCell
(Cell c) FilterListWithOR.filterCell
(Cell c) FilterWrapper.filterCell
(Cell c) FirstKeyOnlyFilter.filterCell
(Cell c) FirstKeyValueMatchingQualifiersFilter.filterCell
(Cell c) Deprecated.FuzzyRowFilter.filterCell
(Cell c) InclusiveStopFilter.filterCell
(Cell c) KeyOnlyFilter.filterCell
(Cell ignored) MultipleColumnPrefixFilter.filterCell
(Cell c) MultiRowRangeFilter.filterCell
(Cell ignored) PageFilter.filterCell
(Cell ignored) PrefixFilter.filterCell
(Cell c) QualifierFilter.filterCell
(Cell c) RandomRowFilter.filterCell
(Cell c) RowFilter.filterCell
(Cell v) SingleColumnValueFilter.filterCell
(Cell c) SkipFilter.filterCell
(Cell c) TimestampsFilter.filterCell
(Cell c) ValueFilter.filterCell
(Cell c) WhileMatchFilter.filterCell
(Cell c) ColumnPrefixFilter.filterColumn
(Cell cell) MultipleColumnPrefixFilter.filterColumn
(Cell cell) private boolean
SingleColumnValueFilter.filterColumnValue
(Cell cell) ColumnCountGetFilter.filterKeyValue
(Cell c) Deprecated.ColumnPaginationFilter.filterKeyValue
(Cell c) Deprecated.ColumnPrefixFilter.filterKeyValue
(Cell c) Deprecated.ColumnRangeFilter.filterKeyValue
(Cell c) Deprecated.DependentColumnFilter.filterKeyValue
(Cell c) Deprecated.FamilyFilter.filterKeyValue
(Cell c) Deprecated.Filter.filterKeyValue
(Cell c) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.FilterList.filterKeyValue
(Cell c) Deprecated.FilterListBase.filterKeyValue
(Cell c) FilterWrapper.filterKeyValue
(Cell c) Deprecated.FirstKeyOnlyFilter.filterKeyValue
(Cell c) Deprecated.FirstKeyValueMatchingQualifiersFilter.filterKeyValue
(Cell c) Deprecated.FuzzyRowFilter.filterKeyValue
(Cell c) Deprecated.InclusiveStopFilter.filterKeyValue
(Cell c) Deprecated.KeyOnlyFilter.filterKeyValue
(Cell ignored) Deprecated.MultipleColumnPrefixFilter.filterKeyValue
(Cell c) Deprecated.MultiRowRangeFilter.filterKeyValue
(Cell ignored) Deprecated.PageFilter.filterKeyValue
(Cell c) Deprecated.PrefixFilter.filterKeyValue
(Cell c) Deprecated.QualifierFilter.filterKeyValue
(Cell c) Deprecated.RandomRowFilter.filterKeyValue
(Cell c) Deprecated.RowFilter.filterKeyValue
(Cell c) Deprecated.SingleColumnValueFilter.filterKeyValue
(Cell c) Deprecated.SkipFilter.filterKeyValue
(Cell c) Deprecated.TimestampsFilter.filterKeyValue
(Cell c) Deprecated.ValueFilter.filterKeyValue
(Cell c) Deprecated.WhileMatchFilter.filterKeyValue
(Cell c) Deprecated.boolean
ColumnCountGetFilter.filterRowKey
(Cell cell) boolean
ColumnPaginationFilter.filterRowKey
(Cell cell) boolean
ColumnPrefixFilter.filterRowKey
(Cell cell) boolean
ColumnRangeFilter.filterRowKey
(Cell cell) boolean
ColumnValueFilter.filterRowKey
(Cell cell) boolean
CompareFilter.filterRowKey
(Cell cell) abstract boolean
Filter.filterRowKey
(Cell firstRowCell) Filters a row based on the row key.boolean
FilterBase.filterRowKey
(Cell cell) boolean
FilterList.filterRowKey
(Cell firstRowCell) boolean
FilterListWithAND.filterRowKey
(Cell firstRowCell) boolean
FilterListWithOR.filterRowKey
(Cell firstRowCell) boolean
FilterWrapper.filterRowKey
(Cell cell) boolean
FirstKeyOnlyFilter.filterRowKey
(Cell cell) boolean
InclusiveStopFilter.filterRowKey
(Cell firstRowCell) boolean
KeyOnlyFilter.filterRowKey
(Cell cell) boolean
MultipleColumnPrefixFilter.filterRowKey
(Cell cell) boolean
MultiRowRangeFilter.filterRowKey
(Cell firstRowCell) boolean
PageFilter.filterRowKey
(Cell cell) boolean
PrefixFilter.filterRowKey
(Cell firstRowCell) boolean
RandomRowFilter.filterRowKey
(Cell firstRowCell) boolean
RowFilter.filterRowKey
(Cell firstRowCell) boolean
SingleColumnValueFilter.filterRowKey
(Cell cell) boolean
SkipFilter.filterRowKey
(Cell cell) boolean
TimestampsFilter.filterRowKey
(Cell cell) boolean
WhileMatchFilter.filterRowKey
(Cell cell) ColumnPaginationFilter.getNextCellHint
(Cell cell) ColumnPrefixFilter.getNextCellHint
(Cell cell) ColumnRangeFilter.getNextCellHint
(Cell cell) abstract Cell
Filter.getNextCellHint
(Cell currentCell) If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is the next key it must seek to.FilterBase.getNextCellHint
(Cell currentCell) Filters that are not sure which key must be next seeked to, can inherit this implementation that, by default, returns a null Cell.FilterList.getNextCellHint
(Cell currentCell) FilterListWithAND.getNextCellHint
(Cell currentCell) FilterListWithOR.getNextCellHint
(Cell currentCell) FilterWrapper.getNextCellHint
(Cell currentCell) FuzzyRowFilter.getNextCellHint
(Cell currentCell) MultipleColumnPrefixFilter.getNextCellHint
(Cell cell) MultiRowRangeFilter.getNextCellHint
(Cell currentKV) TimestampsFilter.getNextCellHint
(Cell currentCell) Pick the next cell that the scanner should seek to.private boolean
FirstKeyValueMatchingQualifiersFilter.hasOneMatchingQualifier
(Cell c) Deprecated.(package private) boolean
abstract Cell
Filter.transformCell
(Cell v) Give the filter a chance to transform the passed KeyValue.FilterBase.transformCell
(Cell v) By default no transformation takes place Give the filter a chance to transform the passed KeyValue.FilterList.transformCell
(Cell c) FilterListBase.transformCell
(Cell c) For FilterList, we can consider a filter list as a node in a tree.FilterWrapper.transformCell
(Cell v) KeyOnlyFilter.transformCell
(Cell cell) SkipFilter.transformCell
(Cell v) WhileMatchFilter.transformCell
(Cell v) private void
FilterListWithOR.updatePrevCellList
(int index, Cell currentCell, Filter.ReturnCode currentRC) (package private) boolean
FuzzyRowFilter.RowTracker.updateTracker
(Cell currentCell) (package private) void
FuzzyRowFilter.RowTracker.updateWith
(Cell currentCell, Pair<byte[], byte[]> fuzzyData) Modifier and TypeMethodDescriptionvoid
DependentColumnFilter.filterRowCells
(List<Cell> kvs) abstract void
Filter.filterRowCells
(List<Cell> kvs) Chance to alter the list of Cells to be submitted.void
FilterBase.filterRowCells
(List<Cell> ignored) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterList.filterRowCells
(List<Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterListBase.filterRowCells
(List<Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterWrapper.filterRowCells
(List<Cell> kvs) void
SingleColumnValueExcludeFilter.filterRowCells
(List<Cell> kvs) FilterWrapper.filterRowCellsWithRet
(List<Cell> kvs) -
Uses of Cell in org.apache.hadoop.hbase.io
Modifier and TypeMethodDescriptionHalfStoreFileReader.getFirstKey()
HalfStoreFileReader.getLastKey()
HalfStoreFileReader.midKey()
-
Uses of Cell 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 Cell
RowIndexEncoderV1.lastCell
The Cell previously appended.protected Cell
EncodingState.prevCell
The previous Cell the encoder encoded.Modifier and TypeMethodDescriptionprotected Cell
AbstractDataBlockEncoder.createFirstKeyCell
(ByteBuffer key, int keyLength) 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 Cell
BufferedDataBlockEncoder.SeekerState.toOffheapCell
(ByteBuffer valAndTagsBuffer, int vOffset, int tagsLenSerializationSize) private Cell
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
(Cell cell, DataOutputStream out, HFileBlockDefaultEncodingContext encodingCtx) Returns unencoded size addedprivate int
RowIndexSeekerV1.binarySearch
(Cell seekCell, boolean seekBefore) protected boolean
static int
BufferedDataBlockEncoder.compareCommonFamilyPrefix
(Cell left, Cell right, int familyCommonPrefix) static int
BufferedDataBlockEncoder.compareCommonQualifierPrefix
(Cell left, Cell right, int qualCommonPrefix) static int
BufferedDataBlockEncoder.compareCommonRowPrefix
(Cell left, Cell right, int rowCommonPrefix) common prefixesint
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareKey
(CellComparator comparator, Cell key) int
DataBlockEncoder.EncodedSeeker.compareKey
(CellComparator comparator, Cell key) Compare the given key against the current keyint
RowIndexSeekerV1.compareKey
(CellComparator comparator, Cell key) private int
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareTypeBytes
(Cell key, Cell right) private int
DiffKeyDeltaEncoder.compressSingleKeyValue
(DataOutputStream out, Cell cell, Cell prevCell) private int
FastDiffDeltaEncoder.compressSingleKeyValue
(DataOutputStream out, Cell cell, Cell prevCell) void
BufferedDataBlockEncoder.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) void
DataBlockEncoder.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
RowIndexCodecV1.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) private static int
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInFamilyPart
(Cell left, KeyValue.KeyOnlyKeyValue right, int familyCommonPrefix) private static int
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInQualifierPart
(Cell left, KeyValue.KeyOnlyKeyValue right, int qualifierCommonPrefix) private static int
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInRowPart
(Cell left, KeyValue.KeyOnlyKeyValue right, int rowCommonPrefix) abstract int
BufferedDataBlockEncoder.internalEncode
(Cell cell, HFileBlockDefaultEncodingContext encodingCtx, DataOutputStream out) int
CopyKeyDataBlockEncoder.internalEncode
(Cell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
DiffKeyDeltaEncoder.internalEncode
(Cell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
FastDiffDeltaEncoder.internalEncode
(Cell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
PrefixKeyDeltaEncoder.internalEncode
(Cell cell, HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) int
BufferedDataBlockEncoder.BufferedEncodedSeeker.seekToKeyInBlock
(Cell seekCell, boolean seekBefore) int
DataBlockEncoder.EncodedSeeker.seekToKeyInBlock
(Cell 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
(Cell seekCell, boolean seekBefore) int
void
private void
PrefixKeyDeltaEncoder.writeKeyExcludingCommon
(Cell cell, int commonPrefix, DataOutputStream out) -
Uses of Cell in org.apache.hadoop.hbase.io.hfile
Modifier and TypeFieldDescriptionprivate Cell
HFileInfo.biggestCell
Biggest Cell in the file, key only.private Cell[]
HFileBlockIndex.CellBasedKeyBlockIndexReader.blockKeys
private Cell[]
NoOpIndexBlockEncoder.NoOpEncodedSeeker.blockKeys
protected Cell
HFileWriterImpl.firstCellInBlock
First cell in a block.protected Cell
HFileWriterImpl.lastCell
The Cell previously appended.private Cell
HFileWriterImpl.lastCellOfPreviousBlock
The last(stop) Cell of the previous data block.private Cell
HFileInfo.lastKeyCell
Last key in the file.private final Cell
BlockWithScanInfo.nextIndexedKey
The first key in the next block following this one in the HFile.protected Cell
HFileReaderImpl.HFileScannerImpl.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.private Cell
CompoundBloomFilterWriter.prevCell
The prev Cell that was processedprivate Cell
HFilePrettyPrinter.KeyValueStatsCollector.prevCell
Modifier and TypeFieldDescriptionprivate AtomicReference<Cell>
HFileBlockIndex.CellBasedKeyBlockIndexReader.midKey
Pre-computed mid-keyprivate AtomicReference<Cell>
NoOpIndexBlockEncoder.NoOpEncodedSeeker.midKey
Pre-computed mid-keyModifier and TypeMethodDescriptionHFileReaderImpl.EncodedScanner.getCell()
HFileReaderImpl.HFileScannerImpl.getCell()
HFileScanner.getCell()
Returns Instance ofCell
.protected Cell
HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock
(HFileBlock curBlock) protected Cell
HFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock
(HFileBlock curBlock) HFileReaderImpl.EncodedScanner.getKey()
HFileReaderImpl.HFileScannerImpl.getKey()
HFileScanner.getKey()
Gets the current key in the form of a cell.HFileWriterImpl.getLastCell()
HFileInfo.getLastKeyCell()
static Cell
HFileWriterImpl.getMidpoint
(CellComparator comparator, Cell left, Cell 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)CompoundBloomFilterWriter.getPrevCell()
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) abstract Cell
HFileBlockIndex.BlockIndexReader.midkey
(HFile.CachingBlockReader cachingBlockReader) An approximation to theHFile
's mid-key.HFileBlockIndex.ByteArrayKeyBlockIndexReader.midkey
(HFile.CachingBlockReader cachingBlockReader) 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
void
Add key/value to file.(package private) static int
HFileBlockIndex.BlockIndexReader.binarySearchNonRootIndex
(Cell key, ByteBuff nonRootIndex, CellComparator comparator) Performs a binary search over a non-root level index block.protected int
Within a loaded block, seek looking for the last key that is smaller than (or equal to?) the key we are interested in.protected boolean
Checks that the given Cell's key does not violate the key order.void
int
HFileReaderImpl.EncodedScanner.compareKey
(CellComparator comparator, Cell key) int
HFileReaderImpl.HFileScannerImpl.compareKey
(CellComparator comparator, Cell key) boolean
private boolean
CompoundBloomFilter.containsInternal
(Cell keyCell, ByteBuff bloom, BloomType type) void
HFileDataBlockEncoder.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.void
HFileDataBlockEncoderImpl.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) void
NoOpDataBlockEncoder.encode
(Cell cell, HFileBlockEncodingContext encodingCtx, DataOutputStream out) private String
HFileWriterImpl.getLexicalErrorMessage
(Cell cell) static Cell
HFileWriterImpl.getMidpoint
(CellComparator comparator, Cell left, Cell right) Try to return a Cell that falls betweenleft
andright
but that is shorter; i.e.protected int
HFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey
(HFileBlock seekToBlock, Cell nextIndexedKey, boolean rewind, Cell key, boolean seekBefore) protected int
HFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey
(HFileBlock seekToBlock, Cell nextIndexedKey, boolean rewind, Cell key, boolean seekBefore) abstract BlockWithScanInfo
HFileBlockIndex.BlockIndexReader.loadDataBlockWithScanInfo
(Cell 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
(Cell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileBlockIndex.CellBasedKeyBlockIndexReader.loadDataBlockWithScanInfo
(Cell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.loadDataBlockWithScanInfo
(Cell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) HFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo
(Cell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) NoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo
(Cell key, HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, DataBlockEncoding expectedDataBlockEncoding, HFile.CachingBlockReader cachingBlockReader) (package private) static int
HFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry
(ByteBuff nonRootBlock, Cell key, CellComparator comparator) Search for one key using the secondary index in a non-root block.int
int
Reseek to or just before the passedcell
.abstract int
HFileBlockIndex.BlockIndexReader.rootBlockContainingKey
(Cell key) Finds the root-level index block containing the given key.int
HFileBlockIndex.ByteArrayKeyBlockIndexReader.rootBlockContainingKey
(Cell key) int
HFileBlockIndex.CellBasedKeyBlockIndexReader.rootBlockContainingKey
(Cell key) int
HFileBlockIndex.CellBasedKeyBlockIndexReaderV2.rootBlockContainingKey
(Cell key) int
HFileIndexBlockEncoder.EncodedSeeker.rootBlockContainingKey
(Cell key) int
NoOpIndexBlockEncoder.NoOpEncodedSeeker.rootBlockContainingKey
(Cell key) boolean
HFileReaderImpl.HFileScannerImpl.seekBefore
(Cell key) boolean
HFileScanner.seekBefore
(Cell cell) Consider the cell stream of all the cells in the file,c[0] ..
int
int
An internal API function.int
SeekTo or just before the passedcell
.HFileBlockIndex.BlockIndexReader.seekToDataBlock
(Cell 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
Writes the Cell to this block -
Uses of Cell in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate Cell
Import.CellWritableComparable.kv
private Cell
HFileInputFormat.HFileRecordReader.value
A private cache of the key value so it doesn't need to be loaded twice from the scanner.Modifier and TypeMethodDescription(package private) static <V extends Cell>
org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,V> HFileOutputFormat2.createRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context, org.apache.hadoop.mapreduce.OutputCommitter committer) Modifier and TypeMethodDescriptionprivate Cell
SyncTable.SyncMapper.checkAndResetTimestamp
(Cell sourceCell) private static Cell
CellCreator.create
(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength) CellCreator.create
(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength, String visExpression) Deprecated.since 0.98.9CellCreator.create
(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength, long timestamp, byte[] value, int voffset, int vlength, List<Tag> tags) static Cell
Attempt to filter out the keyvalueHFileInputFormat.HFileRecordReader.getCurrentValue()
SyncTable.SyncMapper.CellScanner.nextCellInRow()
Returns the next Cell in the current row or null iff none remain.Modifier and TypeMethodDescriptionorg.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,
Cell> HFileInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,
Cell> HFileOutputFormat2.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) Modifier and TypeMethodDescriptionprotected void
Import.Importer.addPutToKv
(Put put, Cell kv) private Cell
SyncTable.SyncMapper.checkAndResetTimestamp
(Cell sourceCell) private int
SyncTable.SyncMapper.compareCellKeysWithinRow
(Cell c1, Cell c2) Compare families, qualifiers, and timestamps of the given Cells.private static Cell
CellSerialization.CellDeserializer.deserialize
(Cell ignore) protected boolean
WALPlayer.WALMapper.filter
(org.apache.hadoop.mapreduce.Mapper<WALKey, WALEdit, ImmutableBytesWritable, Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, Cell cell) static Cell
Attempt to filter out the keyvalueint
Import.CellWritableComparablePartitioner.getPartition
(Import.CellWritableComparable key, Cell value, int numPartitions) void
Modifier and TypeMethodDescriptionCellSerialization.getDeserializer
(Class<Cell> t) CellSerialization.getSerializer
(Class<Cell> c) protected void
CellSortReducer.reduce
(ImmutableBytesWritable row, Iterable<Cell> kvs, org.apache.hadoop.mapreduce.Reducer<ImmutableBytesWritable, Cell, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) protected void
Import.CellReducer.reduce
(Import.CellWritableComparable row, Iterable<Cell> kvs, org.apache.hadoop.mapreduce.Reducer<Import.CellWritableComparable, Cell, ImmutableBytesWritable, Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) -
Uses of Cell in org.apache.hadoop.hbase.master.region
-
Uses of Cell in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic Cell
MobUtils.createMobRefCell
(Cell cell, byte[] fileName, byte[] refCellTags) static Cell
MobUtils.createMobRefCell
(Cell cell, byte[] fileName, Tag tableNameTag) Creates a mob reference KeyValue.MobCell.getCell()
Modifier and TypeMethodDescriptionstatic Cell
MobUtils.createMobRefCell
(Cell cell, byte[] fileName, byte[] refCellTags) static Cell
MobUtils.createMobRefCell
(Cell cell, byte[] fileName, Tag tableNameTag) Creates a mob reference KeyValue.static String
MobUtils.getMobFileName
(Cell cell) Gets the mob file name from the mob ref cell.static int
MobUtils.getMobValueLength
(Cell cell) Gets the mob value length from the mob ref cell.MobUtils.getTableName
(Cell cell) Get the table name from when this cell was written into a mob hfile as a TableName.MobUtils.getTableNameString
(Cell cell) Gets the table name from when this cell was written into a mob hfile as a string.MobUtils.getTableNameTag
(Cell cell) Gets the table name tag.static boolean
MobUtils.hasValidMobRefCellValue
(Cell cell) Indicates whether the current mob ref cell has a valid value.static boolean
MobUtils.isMobReferenceCell
(Cell cell) Whether the current cell is a mob reference cell.Reads a cell from the mob file.Reads a cell from the mob file. -
Uses of Cell in org.apache.hadoop.hbase.procedure2.store.region
-
Uses of Cell in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionprotected static String
QuotaTableUtil.extractSnapshotNameFromSizeCell
(Cell c) (package private) static long
QuotaTableUtil.parseSnapshotSize
(Cell c) Parses the snapshot size from the given Cell's value. -
Uses of Cell 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 final Cell[]
CellArrayMap.block
private final Cell
CellFlatMap.CellFlatMapEntry.cell
private Cell
StoreFileScanner.cur
protected Cell
SegmentScanner.current
private Cell
SnapshotSegmentScanner.current
private Cell
StoreFileScanner.delayedSeekKV
protected Cell
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 Cell
SegmentScanner.last
private Cell
StripeMultiFileWriter.BoundaryMultiWriter.lastCell
private Cell
StripeMultiFileWriter.SizeMultiWriter.lastCell
private Cell
ScannerContext.lastPeekedCell
static final Cell
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 Cell
StoreScanner.prevCell
private Cell
StoreFileScanner.previousRow
private Cell
SegmentScanner.stopSkippingKVsRow
Modifier and TypeFieldDescriptionprivate final Comparator<? super Cell>
CellFlatMap.comparator
private final NavigableMap<Cell,
Cell> CellSet.delegatee
private final NavigableMap<Cell,
Cell> CellSet.delegatee
HStoreFile.firstKey
SegmentScanner.iter
SnapshotSegmentScanner.iter
MemStoreCompactorSegmentsIterator.kvs
MemStoreCompactorSegmentsIterator.kvsIterator
HStoreFile.lastKey
RegionScannerImpl.MOCKED_LIST
A mocked list implementation - discards all updates.Modifier and TypeMethodDescriptionCellFlatMap.ceilingKey
(Cell k) private Cell
MemStoreLABImpl.copyBBECellInto
(ByteBufferExtendedCell cell, int maxAlloc) Mostly a duplicate ofMemStoreLABImpl.copyCellInto(Cell, int)
} done for perf sake.private static Cell
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
(Cell cell) MemStoreLAB.copyCellInto
(Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.copyCellInto
(Cell cell) private Cell
MemStoreLABImpl.copyCellInto
(Cell cell, int maxAlloc) private Cell
CellChunkImmutableSegment.copyCellIntoMSLAB
(Cell cell, MemStoreSizing memstoreSizing) private static Cell
MemStoreLABImpl.copyToChunkCell
(Cell 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 Cell
MemStoreLABImpl.createChunkCell
(ByteBuffer buf, int offset, int len, int tagsLen, long sequenceId) private static Cell
AbstractMemStore.deepCopyIfNeeded
(Cell cell) CellSet.first()
(package private) Cell
MutableSegment.first()
Returns the first cell in the segmentCellFlatMap.firstKey()
ImmutableMemStoreLAB.forceCopyOfBigCellInto
(Cell cell) The process of merging assumes all cells are allocated on mslab.MemStoreLAB.forceCopyOfBigCellInto
(Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.forceCopyOfBigCellInto
(Cell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.protected Cell
CellArrayMap.getCell
(int i) protected Cell
CellChunkMap.getCell
(int i) protected abstract Cell
CellFlatMap.getCell
(int i) private Cell
SegmentScanner.getHighest
(Cell first, Cell second) Private internal method that returns the higher of the two key values, or null if they are both nullCellFlatMap.CellFlatMapEntry.getKey()
(package private) Cell
ScannerContext.getLastPeekedCell()
protected Cell
KeyValueHeap.getNextIndexedKey()
KeyValueScanner.getNextIndexedKey()
NonLazyKeyValueScanner.getNextIndexedKey()
SegmentScanner.getNextIndexedKey()
StoreFileScanner.getNextIndexedKey()
StoreScanner.getNextIndexedKey()
protected Cell
AbstractMemStore.getNextRow
(Cell key, NavigableSet<Cell> set) (package private) Cell
CompactingMemStore.getNextRow
(Cell cell) (package private) Cell
DefaultMemStore.getNextRow
(Cell cell) CellFlatMap.CellFlatMapEntry.getValue()
CellSet.last()
CompositeImmutableSegment.last()
Segment.last()
CellFlatMap.lastKey()
private Cell
AbstractMemStore.maybeCloneWithAllocator
(MutableSegment currentActive, Cell 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
(Cell 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
(Cell 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.CellFlatMap.CellFlatMapIterator.next()
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()
CellSet.pollFirst()
CellSet.pollLast()
private static Cell
HRegion.MutationBatchOperation.reckonDelta
(Cell delta, Cell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<Cell, byte[]> supplier) Modifier and TypeMethodDescriptionCellFlatMap.ceilingEntry
(Cell k) CellFlatMap.ceilingEntry
(Cell k) Comparator<? super Cell>
CellFlatMap.comparator()
Comparator<? super Cell>
CellSet.comparator()
SnapshotSegmentScanner.createIterator
(Segment segment) CellSet.descendingIterator()
CellFlatMap.descendingKeySet()
CellFlatMap.descendingMap()
CellFlatMap.descendingMap()
CellSet.descendingSet()
CellFlatMap.entrySet()
CellFlatMap.entrySet()
CellFlatMap.firstEntry()
CellFlatMap.firstEntry()
CellFlatMap.floorEntry
(Cell k) CellFlatMap.floorEntry
(Cell k) Do a get based on the get parameter.(package private) NavigableMap<Cell,
Cell> CellSet.getDelegatee()
(package private) NavigableMap<Cell,
Cell> CellSet.getDelegatee()
HStoreFile.getFirstKey()
StoreFile.getFirstKey()
Get the first key in this store file.StoreFileReader.getFirstKey()
HRegion.getInternal
(Get get, boolean withCoprocessor, long nonceGroup, long nonce) SegmentScanner.getIterator
(Cell cell) HStoreFile.getLastKey()
StoreFile.getLastKey()
Get the last key in this store file.StoreFileReader.getLastKey()
CellFlatMap.higherEntry
(Cell k) CellFlatMap.higherEntry
(Cell k) CellFlatMap.CellFlatMapCollection.iterator()
CellSet.iterator()
CompositeImmutableSegment.iterator()
Segment.iterator()
CellFlatMap.keySet()
CellFlatMap.lastEntry()
CellFlatMap.lastEntry()
CellFlatMap.lowerEntry
(Cell k) CellFlatMap.lowerEntry
(Cell k) StoreFileReader.midKey()
CellFlatMap.navigableKeySet()
CellFlatMap.pollFirstEntry()
CellFlatMap.pollFirstEntry()
CellFlatMap.pollLastEntry()
CellFlatMap.pollLastEntry()
HRegion.MutationBatchOperation.reckonDeltas
(Mutation mutation, List<Cell> results, long now) HRegion.MutationBatchOperation.reckonDeltasByStore
(HStore store, Mutation mutation, long now, List<Cell> deltas, List<Cell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.Returns a subset of the segment cell set, which starts with the given cellReturns a subset of the segment cell set, which starts with the given cellCellFlatMap.values()
Modifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(Cell cell, MemStoreSizing memstoreSizing) boolean
boolean
void
HStore.add
(Cell cell, MemStoreSizing memstoreSizing) Adds a value to the memstorevoid
MemStore.add
(Cell cell, MemStoreSizing memstoreSizing) Write an updatevoid
MutableSegment.add
(Cell cell, boolean mslabUsed, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentvoid
Append the given cellvoid
void
void
void
private void
StoreFileWriter.appendDeleteFamilyBloomFilter
(Cell cell) private void
StoreFileWriter.appendGeneralBloomfilter
(Cell cell) private void
HRegion.applyToMemStore
(HStore store, Cell cell, MemStoreSizing memstoreAccounting) boolean
KeyValueScanner.backwardSeek
(Cell 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
(Cell key) boolean
ReversedKeyValueHeap.backwardSeek
(Cell seekKey) boolean
ReversedStoreScanner.backwardSeek
(Cell key) boolean
SegmentScanner.backwardSeek
(Cell 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
(Cell key) CellFlatMap.ceilingEntry
(Cell k) CellFlatMap.ceilingKey
(Cell k) protected boolean
CompactingMemStore.checkAndAddToActiveSize
(MutableSegment currActive, Cell cellToAdd, MemStoreSizing memstoreSizing) Check whether anything need to be done based on the current active set size.private boolean
StoreFileReader.checkGeneralBloomFilter
(byte[] key, Cell kvKey, BloomFilter bloomFilter) protected void
ReversedStoreScanner.checkScanOrder
(Cell prevKV, Cell kv, CellComparator comparator) protected void
StoreScanner.checkScanOrder
(Cell prevKV, Cell kv, CellComparator comparator) Check whether scan as expected orderint
int
Compares two KeyValueint
int
CompositeImmutableSegment.compareRows
(Cell left, Cell right) int
ReversedKeyValueHeap.ReversedKVScannerComparator.compareRows
(Cell left, Cell right) Compares rows of two KeyValueint
Segment.compareRows
(Cell left, Cell right) ImmutableMemStoreLAB.copyCellInto
(Cell cell) MemStoreLAB.copyCellInto
(Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.copyCellInto
(Cell cell) private Cell
MemStoreLABImpl.copyCellInto
(Cell cell, int maxAlloc) private Cell
CellChunkImmutableSegment.copyCellIntoMSLAB
(Cell cell, MemStoreSizing memstoreSizing) private static Cell
MemStoreLABImpl.copyToChunkCell
(Cell 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 Cell
AbstractMemStore.deepCopyIfNeeded
(Cell cell) protected void
AbstractMemStore.doAdd
(MutableSegment currentActive, Cell cell, MemStoreSizing memstoreSizing) private void
AbstractMemStore.doAddOrUpsert
(Cell cell, long readpoint, MemStoreSizing memstoreSizing, boolean doAdd) static boolean
NonLazyKeyValueScanner.doRealSeek
(KeyValueScanner scanner, Cell kv, boolean forward) private void
AbstractMemStore.doUpsert
(MutableSegment currentActive, Cell cell, long readpoint, MemStoreSizing memstoreSizing) MobReferenceOnlyFilter.filterCell
(Cell cell) private boolean
RegionScannerImpl.filterRowKey
(Cell current) private int
Binary search for a given key in between given boundaries of the array.CellFlatMap.floorEntry
(Cell k) ImmutableMemStoreLAB.forceCopyOfBigCellInto
(Cell cell) The process of merging assumes all cells are allocated on mslab.MemStoreLAB.forceCopyOfBigCellInto
(Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.MemStoreLABImpl.forceCopyOfBigCellInto
(Cell 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, Cell seekKey, boolean forward, boolean useBloom) (package private) static int
Segment.getCellLength
(Cell cell) Get cell length after serialized inKeyValue
private Cell
SegmentScanner.getHighest
(Cell first, Cell second) Private internal method that returns the higher of the two key values, or null if they are both nullSegmentScanner.getIterator
(Cell cell) private static long
HRegion.MutationBatchOperation.getLongValue
(Cell cell) Returns Get the long out of the passed in Cellprotected Cell
protected Cell
AbstractMemStore.getNextRow
(Cell key, NavigableSet<Cell> set) (package private) Cell
CompactingMemStore.getNextRow
(Cell cell) (package private) Cell
DefaultMemStore.getNextRow
(Cell cell) private HStore
Return HStore instance.private int
CellFlatMap.getValidIndex
(Cell key, boolean inclusive, boolean tail) Get the index of the given anchor key for creating subsequent set.protected long
Segment.heapSizeChange
(Cell cell, boolean allocated) CellFlatMap.higherEntry
(Cell k) void
TimeRangeTracker.includeTimestamp
(Cell cell) Update the current TimestampRange to include the timestamp fromcell
.private void
AbstractMemStore.internalAdd
(MutableSegment currentActive, Cell toAdd, boolean mslabUsed, MemStoreSizing memstoreSizing) protected void
CompositeImmutableSegment.internalAdd
(Cell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.internalAdd
(Cell cell, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) private boolean
StripeMultiFileWriter.BoundaryMultiWriter.isCellAfterCurrentWriter
(Cell cell) private static final boolean
private boolean
StoreFileScanner.isStillAtSeekTargetAfterSkippingNewerKvs
(Cell seekKey) private boolean
RegionScannerImpl.joinedHeapMayHaveData
(Cell currentRowCell) Returns true when the joined heap may have data for the current rowCellFlatMap.lowerEntry
(Cell k) private Cell
AbstractMemStore.maybeCloneWithAllocator
(MutableSegment currentActive, Cell 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
(Cell 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
(Cell 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 boolean
RegionScannerImpl.moreCellsInRow
(Cell nextKv, Cell currentRowCell) Based on the nextKv in the heap, and the current row, decide whether or not there are more cells to be read in the heap.protected boolean
RegionScannerImpl.nextRow
(ScannerContext scannerContext, Cell curRowCell) protected boolean
ReversedRegionScannerImpl.nextRow
(ScannerContext scannerContext, Cell curRowCell) private final int
StripeStoreFileManager.nonOpenRowCompare
(Cell k1, byte[] k2) protected long
Segment.offHeapSizeChange
(Cell cell, boolean allocated) private void
StoreScanner.parallelSeek
(List<? extends KeyValueScanner> scanners, Cell kv) Seek storefiles in parallel to optimize IO latency as much as possibleboolean
StoreFileReader.passesGeneralRowColBloomFilter
(Cell cell) A method for checking Bloom filters.private boolean
RegionScannerImpl.populateResult
(List<Cell> results, KeyValueHeap heap, ScannerContext scannerContext, Cell currentRowCell) Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is reached, or remainingResultSize (if not -1) is reacedboolean
RegionCoprocessorHost.postScannerFilterRow
(InternalScanner s, Cell curRowCell) This will be called by the scan flow when the current scanned row is being filtered out by the filter.private void
StripeMultiFileWriter.BoundaryMultiWriter.prepareWriterFor
(Cell cell) boolean
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion
(Mutation mutation, Cell kv, byte[] byteNow, Get get) Deprecated.In hbase-2.0.0.protected abstract boolean
AbstractMemStore.preUpdate
(MutableSegment currentActive, Cell cell, MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected boolean
CompactingMemStore.preUpdate
(MutableSegment currentActive, Cell 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, Cell cell, MemStoreSizing memstoreSizing) private MobCell
HMobStore.readCell
(List<org.apache.hadoop.fs.Path> locations, String fileName, Cell search, boolean cacheMobBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from a mob file.private static Cell
HRegion.MutationBatchOperation.reckonDelta
(Cell delta, Cell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<Cell, byte[]> supplier) boolean
KeyValueHeap.requestSeek
(Cell key, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.Cell)
(orKeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)
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
(Cell kv, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.Cell)
(orKeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)
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
(Cell kv, boolean forward, boolean useBloom) boolean
ReversedKeyValueHeap.requestSeek
(Cell key, boolean forward, boolean useBloom) boolean
SegmentScanner.requestSeek
(Cell c, boolean forward, boolean useBloom) boolean
StoreFileScanner.requestSeek
(Cell kv, boolean forward, boolean useBloom) Pretend we have done a seek but don't do it yet, if possible.boolean
This function is identical to theKeyValueHeap.seek(Cell)
function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).boolean
Reseek the scanner at or after the specified KeyValue.boolean
boolean
boolean
Reseek the scanner at or after the specified KeyValue.boolean
boolean
boolean
private boolean
StoreFileScanner.reseekAtOrAfter
(Cell seekKey) (package private) static boolean
StoreFileScanner.reseekAtOrAfter
(HFileScanner s, Cell k) private void
StoreScanner.resetQueryMatcher
(Cell lastTopKey) Reads the cell from the mob file, and the read point does not count.Reads the cell from the mob file with readEmptyValueOnMobCellMissHMobStore.resolve
(Cell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file.protected void
HRegion.restoreEdit
(HStore s, Cell cell, MemStoreSizing memstoreAccounting) Used by testsprotected void
StripeMultiFileWriter.sanityCheckLeft
(byte[] left, Cell cell) Subclasses can call this method to make sure the first KV is within multi-writer range.protected void
StripeMultiFileWriter.sanityCheckRight
(byte[] right, Cell cell) Subclasses can call this method to make sure the last KV is within multi-writer range.boolean
Seeks all scanners at or below the specified seek key.boolean
Seek the scanner at or after the specified KeyValue.boolean
boolean
boolean
Seek the scanner at or after the specified Cell.boolean
boolean
boolean
protected boolean
ReversedStoreScanner.seekAsDirection
(Cell kv) Do a backwardSeek in a reversed StoreScanner(scan backward)protected boolean
StoreScanner.seekAsDirection
(Cell kv) Do a reseek in a normal StoreScanner(scan forward)private boolean
StoreFileScanner.seekAtOrAfter
(Cell seekKey) static boolean
StoreFileScanner.seekAtOrAfter
(HFileScanner s, Cell k) Returns false if not found or if k is after the end.private boolean
StoreFileScanner.seekBefore
(Cell seekKey) private void
StoreFileScanner.seekBeforeAndSaveKeyToPreviousRow
(Cell seekKey) Seeks before the seek target cell and saves the location toStoreFileScanner.previousRow
.private void
StoreScanner.seekOrSkipToNextColumn
(Cell cell) private void
StoreScanner.seekOrSkipToNextRow
(Cell cell) protected void
ReversedStoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, Cell seekKey, boolean isLazy, boolean isParallelSeek) protected void
StoreScanner.seekScanners
(List<? extends KeyValueScanner> scanners, Cell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected boolean
ReversedStoreScanner.seekToNextRow
(Cell kv) protected boolean
StoreScanner.seekToNextRow
(Cell c) boolean
KeyValueScanner.seekToPreviousRow
(Cell key) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
NonReversedNonLazyKeyValueScanner.seekToPreviousRow
(Cell key) boolean
ReversedKeyValueHeap.seekToPreviousRow
(Cell seekKey) boolean
ReversedStoreScanner.seekToPreviousRow
(Cell key) boolean
SegmentScanner.seekToPreviousRow
(Cell cell) Seek the scanner at the first Cell of the row which is the previous row of specified keyboolean
StoreFileScanner.seekToPreviousRow
(Cell originalKey) private boolean
StoreFileScanner.seekToPreviousRowStateless
(Cell originalKey) This variant of theStoreFileScanner.seekToPreviousRow(Cell)
method requires two seeks.private boolean
StoreFileScanner.seekToPreviousRowWithoutHint
(Cell originalKey) This variant of theStoreFileScanner.seekToPreviousRow(Cell)
method requires two seeks and one reseek.protected void
StoreFileScanner.setCurrentCell
(Cell newVal) (package private) void
ScannerContext.setLastPeekedCell
(Cell lastPeekedCell) protected boolean
RegionScannerImpl.shouldStop
(Cell currentRowCell) protected boolean
ReversedRegionScannerImpl.shouldStop
(Cell currentRowCell) Returns a subset of the segment cell set, which starts with the given cellReturns a subset of the segment cell set, which starts with the given cellvoid
StoreFileWriter.trackTimestamps
(Cell cell) Record the earlest Put timestamp.protected boolean
StoreScanner.trySkipToNextColumn
(Cell cell) protected boolean
StoreScanner.trySkipToNextRow
(Cell cell) See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) StoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) Updates the candidate list for finding row key before.StripeStoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods.private void
HRegion.updateDeleteLatestVersionTimestamp
(Cell cell, Get get, int count, byte[] byteNow) protected void
CompositeImmutableSegment.updateMetaInfo
(Cell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(Cell cellToAdd, boolean succ, boolean mslabUsed, MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected void
Segment.updateMetaInfo
(Cell cellToAdd, boolean succ, MemStoreSizing memstoreSizing) private void
AbstractMemStore.upsert
(Cell cell, long readpoint, MemStoreSizing memstoreSizing) void
MutableSegment.upsert
(Cell cell, long readpoint, MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Modifier and TypeMethodDescriptionvoid
AbstractMemStore.add
(Iterable<Cell> cells, MemStoreSizing memstoreSizing) void
HStore.add
(Iterable<Cell> cells, MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoid
MemStore.add
(Iterable<Cell> cells, MemStoreSizing memstoreSizing) Write the updatesboolean
CellFlatMap.CellFlatMapCollection.addAll
(Collection<? extends Cell> collection) boolean
CellSet.addAll
(Collection<? extends Cell> c) protected void
HRegion.BatchOperation.applyFamilyMapToMemStore
(Map<byte[], List<Cell>> familyMap, MemStoreSizing memstoreAccounting) Atomically apply the given map of family->edits to the memstore.private void
HRegion.applyToMemStore
(HStore store, List<Cell> cells, boolean delta, MemStoreSizing memstoreAccounting) void
HRegion.checkTimestamps
(Map<byte[], List<Cell>> familyMap, long now) Check the collection of families for valid timestampsprotected Cell
AbstractMemStore.getNextRow
(Cell key, NavigableSet<Cell> set) private void
HRegion.MutationBatchOperation.mergeFamilyMaps
(Map<byte[], List<Cell>> familyMap, Map<byte[], List<Cell>> toBeMerged) (package private) void
HRegion.metricsUpdateForGet
(List<Cell> results, long before) private ScannerContext.NextState
StoreScanner.needToReturn
(List<Cell> outResult) If the top cell won't be flushed into disk, the new top cell may be changed after #reopenAfterFlush.default boolean
Grab the next row's worth of values.boolean
InternalScanner.next
(List<Cell> result, ScannerContext scannerContext) Grab the next row's worth of values.boolean
KeyValueHeap.next
(List<Cell> result, ScannerContext scannerContext) Gets the next row of keys from the top-most scanner.boolean
MobStoreScanner.next
(List<Cell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.boolean
boolean
RegionScannerImpl.next
(List<Cell> outResults, ScannerContext scannerContext) boolean
ReversedMobStoreScanner.next
(List<Cell> outResult, ScannerContext ctx) Firstly reads the cells from the HBase.boolean
StoreScanner.next
(List<Cell> outResult, ScannerContext scannerContext) Get the next row of values from this Store.private boolean
RegionScannerImpl.nextInternal
(List<Cell> results, ScannerContext scannerContext) boolean
Grab the next row's worth of values.boolean
RegionScanner.nextRaw
(List<Cell> result, ScannerContext scannerContext) Grab the next row's worth of values.boolean
boolean
RegionScannerImpl.nextRaw
(List<Cell> outResults, ScannerContext scannerContext) private boolean
RegionScannerImpl.populateFromJoinedHeap
(List<Cell> results, ScannerContext scannerContext) Returns true if more cells exist after this batch, false if scanner is doneprivate boolean
RegionScannerImpl.populateResult
(List<Cell> results, KeyValueHeap heap, ScannerContext scannerContext, Cell currentRowCell) Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is reached, or remainingResultSize (if not -1) is reacedvoid
boolean
Supports Coprocessor 'bypass'.private void
HRegion.prepareDeleteTimestamps
(Mutation mutation, Map<byte[], List<Cell>> familyMap, byte[] byteNow) Set up correct timestamps in the KVs in Delete object.void
void
private static Cell
HRegion.MutationBatchOperation.reckonDelta
(Cell delta, Cell currentCell, byte[] columnFamily, long now, Mutation mutation, Function<Cell, byte[]> supplier) HRegion.MutationBatchOperation.reckonDeltas
(Mutation mutation, List<Cell> results, long now) HRegion.MutationBatchOperation.reckonDeltasByStore
(HStore store, Mutation mutation, long now, List<Cell> deltas, List<Cell> results) Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed column family/Store.private void
HRegion.recordMutationWithoutWal
(Map<byte[], List<Cell>> familyMap) Update LongAdders for number of puts without wal and the size of possible data loss.private void
HRegion.rewriteCellTags
(Map<byte[], List<Cell>> familyMap, Mutation m) Possibly rewrite incoming cell tags.private static void
HRegion.updateCellTimestamps
(Iterable<List<Cell>> cellItr, byte[] now) Replace any cell timestamps set toHConstants.LATEST_TIMESTAMP
provided current timestamp.private void
HRegion.updateSequenceId
(Iterable<List<Cell>> cellItr, long sequenceId) void
AbstractMemStore.upsert
(Iterable<Cell> cells, long readpoint, MemStoreSizing memstoreSizing) void
HStore.upsert
(Iterable<Cell> cells, long readpoint, MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.void
MemStore.upsert
(Iterable<Cell> cells, long readpoint, MemStoreSizing memstoreSizing) Update or insert the specified cells.ModifierConstructorDescriptionCellArrayMap
(Comparator<? super Cell> comparator, Cell[] b, int min, int max, boolean descending) CellFlatMapEntry
(Cell cell) ModifierConstructorDescriptionCellArrayMap
(Comparator<? super Cell> comparator, Cell[] b, int min, int max, boolean descending) CellChunkMap
(Comparator<? super Cell> comparator, Chunk[] chunks, int min, int max, boolean descending) C-tor for creating CellChunkMap from existing Chunk array, which must be ordered (decreasingly or increasingly according to parameter "descending")CellFlatMap
(Comparator<? super Cell> comparator, int min, int max, boolean d) (package private)
CellSet
(NavigableMap<Cell, Cell> m) (package private)
CellSet
(NavigableMap<Cell, Cell> m) (package private)
CellSet
(NavigableMap<Cell, Cell> m, int numUniqueKeys) (package private)
CellSet
(NavigableMap<Cell, Cell> m, int numUniqueKeys) -
Uses of Cell in org.apache.hadoop.hbase.regionserver.handler
ModifierConstructorDescriptionParallelSeekHandler
(KeyValueScanner scanner, Cell keyValue, long readPoint, CountDownLatch latch) -
Uses of Cell in org.apache.hadoop.hbase.regionserver.querymatcher
Modifier and TypeFieldDescriptionprivate Cell
ScanWildcardColumnTracker.columnCell
private Cell
UserScanQueryMatcher.curColCell
protected Cell
ScanQueryMatcher.currentRow
Row the query is onprotected Cell
ScanDeleteTracker.deleteCell
protected final Cell
ScanQueryMatcher.startKey
Key to seek to in memstore and StoreFilesModifier and TypeMethodDescriptionprivate static Cell
UserScanQueryMatcher.createStartKey
(Scan scan, ScanInfo scanInfo) protected static Cell
ScanQueryMatcher.createStartKeyFromRow
(byte[] startRow, ScanInfo scanInfo) ScanQueryMatcher.currentRow()
Returns a cell represent the current rowScanQueryMatcher.getKeyForNextColumn
(Cell cell) CompactionScanQueryMatcher.getNextKeyHint
(Cell cell) abstract Cell
ScanQueryMatcher.getNextKeyHint
(Cell cell) Delegate toFilter.getNextCellHint(Cell)
.UserScanQueryMatcher.getNextKeyHint
(Cell cell) ScanQueryMatcher.getStartKey()
Returns the start keyModifier and TypeMethodDescriptionvoid
Add the specified cell to the list of deletes to check against for this row operation.void
void
Add the specified Cell to the list of deletes to check against for this row operation.void
NewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete
(Cell cell) ColumnTracker.checkColumn
(Cell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.ExplicitColumnTracker.checkColumn
(Cell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.NewVersionBehaviorTracker.checkColumn
(Cell cell, byte type) ScanWildcardColumnTracker.checkColumn
(Cell 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, Cell cell) ColumnTracker.checkVersions
(Cell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.ExplicitColumnTracker.checkVersions
(Cell cell, long timestamp, byte type, boolean ignoreCount) NewVersionBehaviorTracker.checkVersions
(Cell cell, long timestamp, byte type, boolean ignoreCount) ScanWildcardColumnTracker.checkVersions
(Cell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.int
ScanQueryMatcher.compareKeyForNextColumn
(Cell nextIndexed, Cell currentCell) int
ScanQueryMatcher.compareKeyForNextRow
(Cell nextIndexed, Cell currentCell) default void
ColumnTracker.doneWithColumn
(Cell cell) This method is used to inform the column tracker that we are done with this column.void
ExplicitColumnTracker.doneWithColumn
(Cell cell) ScanQueryMatcher.getKeyForNextColumn
(Cell cell) CompactionScanQueryMatcher.getNextKeyHint
(Cell cell) abstract Cell
ScanQueryMatcher.getNextKeyHint
(Cell cell) Delegate toFilter.getNextCellHint(Cell)
.UserScanQueryMatcher.getNextKeyHint
(Cell cell) ColumnTracker.getNextRowOrNextColumn
(Cell cell) Retrieve the MatchCode for the next row or columnExplicitColumnTracker.getNextRowOrNextColumn
(Cell cell) NewVersionBehaviorTracker.getNextRowOrNextColumn
(Cell cell) ScanWildcardColumnTracker.getNextRowOrNextColumn
(Cell cell) private static boolean
ScanQueryMatcher.isCellTTLExpired
(Cell cell, long oldestTimestamp, long now) Returns true if the cell is expiredprivate boolean
NewVersionBehaviorTracker.isColumnQualifierChanged
(Cell cell) Check if the specified cell buffer has been deleted by a previously seen delete.This method is not idempotent, we will save some info to judge VERSION_MASKED.Check if the specified Cell buffer has been deleted by a previously seen delete.abstract ScanQueryMatcher.MatchCode
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)protected final ScanQueryMatcher.MatchCode
UserScanQueryMatcher.matchColumn
(Cell cell, long timestamp, byte typeByte) private final ScanQueryMatcher.MatchCode
UserScanQueryMatcher.mergeFilterResponse
(Cell cell, ScanQueryMatcher.MatchCode matchCode, Filter.ReturnCode filterResponse) Call this when scan has filter.boolean
CompactionScanQueryMatcher.moreRowsMayExistAfter
(Cell cell) abstract boolean
ScanQueryMatcher.moreRowsMayExistAfter
(Cell cell) boolean
UserScanQueryMatcher.moreRowsMayExistAfter
(Cell cell) protected final ScanQueryMatcher.MatchCode
Check before the delete logic.protected long
Reset the map if it is different with the last Cell.private void
void
ScanQueryMatcher.setToNewRow
(Cell currentRow) Set the row when there is change in rowprotected final void
CompactionScanQueryMatcher.trackDelete
(Cell cell) protected final ScanQueryMatcher.MatchCode
DropDeletesCompactionScanQueryMatcher.tryDropDelete
(Cell cell) ModifierConstructorDescriptionprotected
ScanQueryMatcher
(Cell startKey, ScanInfo scanInfo, ColumnTracker columns, long oldestUnexpiredTS, long now) -
Uses of Cell in org.apache.hadoop.hbase.regionserver.throttle
-
Uses of Cell in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprotected Cell
SecureWALCellCodec.EncryptedKvDecoder.parseCell()
protected Cell
WALCellCodec.CompressedKvDecoder.parseCell()
Modifier and TypeMethodDescriptionvoid
void
void
private void
WALCellCodec.CompressedKvEncoder.writeCompressedValue
(OutputStream out, Cell cell) Modifier and TypeMethodDescription(package private) static Set<byte[]>
FSWALEntry.collectFamilies
(List<Cell> cells) static void
WALUtil.filterCells
(WALEdit edit, Function<Cell, Cell> mapper) static void
WALUtil.filterCells
(WALEdit edit, Function<Cell, Cell> mapper) -
Uses of Cell in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionBulkLoadCellFilter.filterCell
(Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.NamespaceTableCfWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) ScopeWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) WALCellFilter.filterCell
(WAL.Entry entry, Cell cell) Applies the filter, possibly returning a different Cell instance.Modifier and TypeMethodDescriptionprivate void
BulkLoadCellFilter.filterCell
(Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.NamespaceTableCfWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) ScopeWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) WALCellFilter.filterCell
(WAL.Entry entry, Cell cell) Applies the filter, possibly returning a different Cell instance. -
Uses of Cell in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate Cell
SerialReplicationSourceWALReader.firstCellInEntryBeforeFiltering
Modifier and TypeMethodDescriptionboolean
private boolean
ReplicationSink.isNewRowOrType
(Cell previousCell, Cell cell) Returns True if we have crossed over onto a new row or typeprivate Put
ReplicationSink.processReplicationMarkerEntry
(Cell cell) void
SerialReplicationChecker.waitUntilCanPush
(WAL.Entry entry, Cell firstCellInEdit) -
Uses of Cell in org.apache.hadoop.hbase.rest
Modifier and TypeFieldDescriptionprivate Cell
RowResultGenerator.cache
private Cell
ScannerResultGenerator.cache
-
Uses of Cell in org.apache.hadoop.hbase.rest.model
-
Uses of Cell in org.apache.hadoop.hbase.security.access
Modifier and TypeMethodDescriptionprivate Cell
AccessController.createNewCellWithTags
(Mutation mutation, Cell oldCell, Cell newCell) Modifier and TypeMethodDescriptionAccessController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Modifier and TypeMethodDescriptionboolean
AuthManager.authorizeCell
(User user, TableName table, Cell cell, Permission.Action action) Check if user has given action privilige in cell scope.private Cell
AccessController.createNewCellWithTags
(Mutation mutation, Cell oldCell, Cell newCell) AccessControlFilter.filterCell
(Cell cell) boolean
AccessControlFilter.filterRowKey
(Cell cell) static List<Permission>
PermissionStorage.getCellPermissionsForUser
(User user, Cell cell) private static Pair<String,
Permission> PermissionStorage.parsePermissionRecord
(byte[] entryName, Cell kv, byte[] cf, byte[] cq, boolean filterPerms, String filterUser) Modifier and TypeMethodDescriptionprivate static void
AccessController.addCellPermissions
(byte[] perms, Map<byte[], List<Cell>> familyMap) AccessController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) void
AccessController.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result) private void
AccessController.updateACL
(RegionCoprocessorEnvironment e, Map<byte[], List<Cell>> familyMap) Writes all table ACLs for the tables in the given Map up into ZooKeeper znodes. -
Uses of Cell in org.apache.hadoop.hbase.security.visibility
Modifier and TypeMethodDescriptionprivate Cell
VisibilityController.createNewCellWithTags
(Mutation mutation, Cell newCell) Modifier and TypeMethodDescriptionDefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths()
VisibilityController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Modifier and TypeMethodDescriptionvoid
void
void
VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode.addVersionDelete
(Cell cell) VisibilityController.checkForReservedVisibilityTagPresence
(Cell cell, Pair<Boolean, Tag> pair) Checks whether cell contains any tag with type as VISIBILITY_TAG_TYPE.private Cell
VisibilityController.createNewCellWithTags
(Mutation mutation, Cell newCell) boolean
Evaluates whether the passed cell passes Scan/Get Authorization.static Byte
Extracts and partitions the visibility tags and nonVisibility Tagsprivate boolean
VisibilityScanDeleteTracker.extractDeleteCellVisTags
(Cell delCell, KeyValue.Type type) static Byte
VisibilityUtils.extractVisibilityTags
(Cell cell, List<Tag> tags) Extract the visibility tags of the given Cell into the given ListVisibilityController.DeleteVersionVisibilityExpressionFilter.filterCell
(Cell cell) VisibilityLabelFilter.filterCell
(Cell cell) boolean
VisibilityController.DeleteVersionVisibilityExpressionFilter.filterRowKey
(Cell cell) boolean
VisibilityLabelFilter.filterRowKey
(Cell cell) static boolean
VisibilityUtils.isVisibilityTagsPresent
(Cell cell) void
VisibilityController.prePrepareTimeStampForDeleteVersion
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) private boolean
VisibilityNewVersionBehaivorTracker.tagMatched
(Cell put, VisibilityNewVersionBehaivorTracker.TagInfo delInfo) Modifier and TypeMethodDescriptionDefaultVisibilityLabelServiceImpl.extractLabelsAndAuths
(List<List<Cell>> labelDetails) VisibilityController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postAppendBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) void
VisibilityController.preGetOp
(ObserverContext<RegionCoprocessorEnvironment> e, Get get, List<Cell> results) -
Uses of Cell in org.apache.hadoop.hbase.thrift
Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift.generated.TCell>
ThriftUtilities.cellFromHBase
(Cell in) This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell object.static List<org.apache.hadoop.hbase.thrift.generated.TCell>
ThriftUtilities.cellFromHBase
(Cell[] in) This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array. -
Uses of Cell in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic Cell
ThriftUtilities.toCell
(ExtendedCellBuilder cellBuilder, byte[] row, org.apache.hadoop.hbase.thrift2.generated.TColumnValue columnValue) -
Uses of Cell 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 Cell
MapReduceExtendedCell.cell
private Cell
CollectionBackedScanner.current
Modifier and TypeMethodDescriptionBloomContext.getLastCell()
BloomFilterWriter.getPrevCell()
Returns the previous cell written by this writerprivate Cell
RowPrefixFixedLengthBloomContext.getRowPrefixCell
(Cell cell) CollectionBackedScanner.next()
CollectionBackedScanner.peek()
Modifier and TypeMethodDescriptionvoid
static int
Bytes.binarySearch
(byte[][] arr, Cell key, org.apache.hadoop.io.RawComparator<Cell> comparator) Deprecated.since 2.0.0 and will be removed in 3.0.0.static int
Bytes.binarySearch
(Cell[] arr, Cell key, CellComparator comparator) Binary search for keys in indexes.boolean
Check if the specified key is contained in the bloom filter.static boolean
BloomFilterUtil.contains
(Cell cell, ByteBuff bloomBuf, int bloomOffset, int bloomSize, Hash hash, int hashCount, BloomType type) private Cell
RowPrefixFixedLengthBloomContext.getRowPrefixCell
(Cell cell) protected abstract boolean
Returns true if the cell is a new key as per the bloom typeprotected boolean
protected boolean
boolean
private void
BloomContext.sanityCheck
(Cell cell) boolean
void
BloomContext.writeBloom
(Cell cell) Bloom information from the cell is retrievedvoid
RowPrefixFixedLengthBloomContext.writeBloom
(Cell cell) Modifier and TypeMethodDescriptionstatic int
Bytes.binarySearch
(byte[][] arr, Cell key, org.apache.hadoop.io.RawComparator<Cell> comparator) Deprecated.since 2.0.0 and will be removed in 3.0.0.ModifierConstructorDescriptionCellHashKey
(Cell cell) CollectionBackedScanner
(CellComparator comparator, Cell... array) MapReduceExtendedCell
(Cell cell) RowBloomHashKey
(Cell cell) RowColBloomHashKey
(Cell cell) ModifierConstructorDescriptionCollectionBackedScanner
(List<Cell> list) CollectionBackedScanner
(List<Cell> list, CellComparator comparator) CollectionBackedScanner
(SortedSet<Cell> set, CellComparator comparator) -
Uses of Cell in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionprivate WALEdit
static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
WALEdit.getBulkLoadDescriptor
(Cell cell) Deserialized and returns a BulkLoadDescriptor from the passed in Cellstatic org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor
WALEdit.getCompaction
(Cell kv) Deserialized and returns a CompactionDescriptor is the KeyValue contains one.static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor
WALEdit.getFlushDescriptor
(Cell cell) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor
WALEdit.getRegionEventDescriptor
(Cell cell) static boolean
WALEdit.isCompactionMarker
(Cell cell) Returns true if the given cell is a serializedWALProtos.CompactionDescriptor
static boolean
WALEdit.isMetaEditFamily
(Cell cell) Replaying WALs can read Cell-at-a-time so need this method in those cases.WALPrettyPrinter.toStringMap
(Cell cell) WALPrettyPrinter.toStringMap
(Cell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues)