Uses of Interface
org.apache.hadoop.hbase.Cell
Package
Description
Provides HBase Client
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.
-
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.ExtendedCell
Extension toCell
with server side required functions.interface
org.apache.hadoop.hbase.RawCell
An extended version of Cell that allows CPs manipulate Tags.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.ByteBufferExtendedCell
This class is a server side extension to theCell
interface.class
org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
This is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).class
org.apache.hadoop.hbase.ByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.IndividualBytesFieldCell
class
org.apache.hadoop.hbase.KeyValue
An HBase Key/Value.static class
org.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly used in places where we need to compare two cells.class
org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0class
org.apache.hadoop.hbase.NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0class
org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.class
org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
This Cell is an implementation ofByteBufferExtendedCell
where the data resides in off heap/ on heap ByteBufferclass
org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
CellBuilder.build()
static org.apache.hadoop.hbase.Cell
CellUtil.cloneIfNecessary
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.Cell
RawCell.createCell
(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.org.apache.hadoop.hbase.Cell
CellScanner.current()
Returns the current Cell which may be mutableModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.Cell>
HBaseTestingUtility.getFromStoreFile
(org.apache.hadoop.hbase.regionserver.HStore store, byte[] row, NavigableSet<byte[]> columns) Deprecated.Do a small get/scan against one store.static List<org.apache.hadoop.hbase.Cell>
HBaseTestingUtility.getFromStoreFile
(org.apache.hadoop.hbase.regionserver.HStore store, org.apache.hadoop.hbase.client.Get get) Deprecated.Do a small get/scan against one store.Comparator<org.apache.hadoop.hbase.Cell>
CellComparator.getSimpleComparator()
Return a dumbed-down, fast comparator for hbase2 base-type, theByteBufferKeyValue
.Comparator<org.apache.hadoop.hbase.Cell>
CellComparatorImpl.getSimpleComparator()
Modifier and TypeMethodDescriptionstatic void
PerformanceEvaluationCommons.assertKey
(byte[] expected, org.apache.hadoop.hbase.Cell c) static byte[]
CellUtil.cloneFamily
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.Cell
CellUtil.cloneIfNecessary
(org.apache.hadoop.hbase.Cell cell) static byte[]
CellUtil.cloneQualifier
(org.apache.hadoop.hbase.Cell cell) static byte[]
CellUtil.cloneRow
(org.apache.hadoop.hbase.Cell cell) get individual arrays for testsstatic byte[]
CellUtil.cloneValue
(org.apache.hadoop.hbase.Cell cell) int
CellComparator.compare
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares two cells.int
CellComparator.compare
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell, boolean ignoreSequenceid) Compare cells.final int
CellComparatorImpl.compare
(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) int
CellComparatorImpl.compare
(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r, boolean ignoreSequenceid) int
MetaCellComparator.compare
(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b, boolean ignoreSequenceid) final int
CellComparatorImpl.compareColumns
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the family and qualifier part of the cellstatic final int
CellUtil.compareColumns
(org.apache.hadoop.hbase.Cell left, byte[] right, int rfoffset, int rflength, int rqoffset, int rqlength) Compares the cell's column (family and qualifier) with the given byte[]int
CellComparator.compareFamilies
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the families of the two cellsprotected int
CellComparatorImpl.compareFamilies
(org.apache.hadoop.hbase.Cell left, int leftFamLen, org.apache.hadoop.hbase.Cell right, int rightFamLen) This method will be overridden when we compare cells inner store to bypass family comparing.final int
CellComparatorImpl.compareFamilies
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compare the families of left and right cellstatic final int
CellUtil.compareFamilies
(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) Compares the cell's family with the given byte[]protected int
InnerStoreCellComparator.compareFamilies
(org.apache.hadoop.hbase.Cell left, int leftFamilyLength, org.apache.hadoop.hbase.Cell right, int rightFamilyLength) static int
PrivateCellUtil.compareFamily
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's column family against given comparatorstatic final int
PrivateCellUtil.compareKeyIgnoresMvcc
(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares only the key portion of a cell.static int
PrivateCellUtil.compareQualifier
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's qualifier against given comparatorint
CellComparator.compareQualifiers
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the qualifiers of the two cellsfinal int
CellComparatorImpl.compareQualifiers
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compare the qualifiers part of the left and right cells.static final int
CellUtil.compareQualifiers
(org.apache.hadoop.hbase.Cell left, byte[] right, int rOffset, int rLength) Compares the cell's qualifier with the given byte[]static int
PrivateCellUtil.compareRow
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's row against given comparatordefault int
CellComparator.compareRows
(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) Lexicographically compare two rowsint
CellComparator.compareRows
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares the rows of two cells.int
CellComparatorImpl.compareRows
(org.apache.hadoop.hbase.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.int
CellComparatorImpl.compareRows
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the rows of the left and right cell.int
MetaCellComparator.compareRows
(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) int
MetaCellComparator.compareRows
(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) int
MetaCellComparator.compareRows
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) int
CellComparator.compareTimestamps
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Compares cell's timestamps in DESCENDING order.int
CellComparatorImpl.compareTimestamps
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static int
PrivateCellUtil.compareValue
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's value against given comparatorint
CellComparator.compareWithoutRow
(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the two cells excluding the row part.final int
CellComparatorImpl.compareWithoutRow
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static void
PrivateCellUtil.compressFamily
(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static void
PrivateCellUtil.compressQualifier
(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static void
PrivateCellUtil.compressRow
(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static int
CellUtil.copyFamilyTo
(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the family to the given byte[]static int
CellUtil.copyFamilyTo
(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the family to the given bytebufferstatic int
CellUtil.copyQualifierTo
(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the qualifier to the given byte[]static int
CellUtil.copyQualifierTo
(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the qualifier to the given bytebufferstatic byte[]
CellUtil.copyRow
(org.apache.hadoop.hbase.Cell cell) Copies the row to a new byte[]static int
CellUtil.copyRowTo
(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the row to the given byte[]static int
CellUtil.copyRowTo
(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the row to the given bytebufferstatic int
CellUtil.copyValueTo
(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the value to the given byte[]static int
CellUtil.copyValueTo
(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the value to the given bytebufferstatic org.apache.hadoop.hbase.Cell
RawCell.createCell
(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.CellScanner
CellUtil.createCellScanner
(org.apache.hadoop.hbase.Cell[] cellArray) Returns CellScanner interface overcellArray
static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnNextRow
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRow
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(org.apache.hadoop.hbase.Cell cell, byte[] qArray, int qoffest, int qlength) Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowColTS
(org.apache.hadoop.hbase.Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createFirstOnRowFamily
(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen) static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createLastOnRow
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.createLastOnRowCol
(org.apache.hadoop.hbase.Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static org.apache.hadoop.hbase.ExtendedCell
PrivateCellUtil.ensureExtendedCell
(org.apache.hadoop.hbase.Cell cell) In fact, in HBase, allCell
s areExtendedCell
s.static boolean
CellUtil.equals
(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) equalsstatic int
PrivateCellUtil.estimatedSerializedSizeOf
(org.apache.hadoop.hbase.Cell cell) Estimate based on keyvalue's serialization format in the RPC layer.static int
PrivateCellUtil.estimatedSerializedSizeOfKey
(org.apache.hadoop.hbase.Cell cell) Calculates the serialized key size.static org.apache.hadoop.hbase.util.ByteRange
PrivateCellUtil.fillFamilyRange
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRange
PrivateCellUtil.fillQualifierRange
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRange
PrivateCellUtil.fillRowRange
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) ByteRangestatic org.apache.hadoop.hbase.util.ByteRange
PrivateCellUtil.fillValueRange
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static String
CellUtil.getCellKeyAsString
(org.apache.hadoop.hbase.Cell cell) Returns The Key portion of the passedcell
as a String.static String
CellUtil.getCellKeyAsString
(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcell
as a String.static List<org.apache.hadoop.hbase.client.RegionInfo>
CatalogFamilyFormat.getMergeRegions
(org.apache.hadoop.hbase.Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells
.CatalogFamilyFormat.getMergeRegionsWithName
(org.apache.hadoop.hbase.Cell[] cells) Returns Deserialized values of <qualifier,regioninfo> pairs taken from column values that match the regex 'info:merge.*' in array ofcells
.static byte
PrivateCellUtil.getQualifierByte
(org.apache.hadoop.hbase.Cell cell, int index) static int
PrivateCellUtil.getRowAsInt
(org.apache.hadoop.hbase.Cell cell) Converts the rowkey bytes of the given cell into an int valuestatic byte
PrivateCellUtil.getRowByte
(org.apache.hadoop.hbase.Cell cell, int index) miscstatic long
PrivateCellUtil.getSequenceId
(org.apache.hadoop.hbase.Cell c) static byte
PrivateCellUtil.getTypeByte
(org.apache.hadoop.hbase.Cell c) static BigDecimal
PrivateCellUtil.getValueAsBigDecimal
(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a BigDecimalstatic double
PrivateCellUtil.getValueAsDouble
(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a double valuestatic int
PrivateCellUtil.getValueAsInt
(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a int valuestatic long
PrivateCellUtil.getValueAsLong
(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a long valuestatic ByteBuffer
PrivateCellUtil.getValueBufferShallowCopy
(org.apache.hadoop.hbase.Cell cell) static boolean
CatalogFamilyFormat.hasMergeRegions
(org.apache.hadoop.hbase.Cell[] cells) Returns True if any merge regions present incells
; i.e.static boolean
CellUtil.isDelete
(org.apache.hadoop.hbase.Cell cell) Return true if a delete type, aKeyValue.Type.Delete
or a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumn
KeyValue type.static boolean
CatalogFamilyFormat.isMergeQualifierPrefix
(org.apache.hadoop.hbase.Cell cell) Returns True if the column incell
matches the regex 'info:merge.*'.static boolean
CellUtil.isPut
(org.apache.hadoop.hbase.Cell cell) Returns True if this cell is a Put.static int
KeyValueUtil.keyLength
(org.apache.hadoop.hbase.Cell cell) Returns number of bytes this cell's key part would have been used if serialized as inKeyValue
.static boolean
CellUtil.matchingColumn
(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) static boolean
CellUtil.matchingColumn
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static boolean
PrivateCellUtil.matchingColumn
(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) static boolean
CellUtil.matchingColumnFamilyAndQualifierPrefix
(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) Returns True if matching column family and the qualifier starts withqual
static boolean
CellUtil.matchingFamily
(org.apache.hadoop.hbase.Cell left, byte[] buf) static boolean
CellUtil.matchingFamily
(org.apache.hadoop.hbase.Cell left, byte lfamlength, org.apache.hadoop.hbase.Cell right, byte rfamlength) static boolean
CellUtil.matchingFamily
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static boolean
PrivateCellUtil.matchingFamily
(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingQualifier
(org.apache.hadoop.hbase.Cell left, byte[] buf) Finds if the qualifier part of the cell and the KV serialized byte[] are equal.static boolean
CellUtil.matchingQualifier
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static boolean
PrivateCellUtil.matchingQualifier
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingRowColumn
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitystatic boolean
CellUtil.matchingRowColumnBytes
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitystatic boolean
CellUtil.matchingRows
(org.apache.hadoop.hbase.Cell left, byte[] buf) static boolean
CellUtil.matchingRows
(org.apache.hadoop.hbase.Cell left, short lrowlength, org.apache.hadoop.hbase.Cell right, short rrowlength) Compares the row of two keyvalues for equalitystatic boolean
CellUtil.matchingRows
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row of two keyvalues for equalitystatic boolean
PrivateCellUtil.matchingRows
(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingTags
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Since 3.0.0, will be removed in 4.0.0.static boolean
CellUtil.matchingTimestamp
(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) static boolean
CellUtil.matchingValue
(org.apache.hadoop.hbase.Cell left, byte[] buf) static boolean
CellUtil.matchingValue
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static boolean
CellUtil.matchingValue
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength) static boolean
PrivateCellUtil.matchingValue
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength) static boolean
PrivateCellUtil.qualifierStartsWith
(org.apache.hadoop.hbase.Cell left, byte[] startsWith) Finds if the start of the qualifier part of the Cell matchesbuf
static void
PrivateCellUtil.setSequenceId
(org.apache.hadoop.hbase.Cell cell, long seqId) Sets the given seqId to the cell.static void
CellUtil.setTimestamp
(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset) Sets the given timestamp to the cell.static void
CellUtil.setTimestamp
(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell.static void
PrivateCellUtil.setTimestamp
(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell.static void
PrivateCellUtil.setTimestamp
(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell.static String
CellUtil.toString
(org.apache.hadoop.hbase.Cell cell, boolean verbose) Returns a string representation of the cellstatic boolean
PrivateCellUtil.updateLatestStamp
(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP
.static void
PrivateCellUtil.writeFamily
(OutputStream out, org.apache.hadoop.hbase.Cell cell, byte flength) Writes the family from the given cell to the output streamstatic void
PrivateCellUtil.writeQualifier
(OutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength) Writes the qualifier from the given cell to the output streamstatic void
PrivateCellUtil.writeQualifierSkippingBytes
(DataOutputStream out, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.Cell cell, short rlength) Writes the row from the given cell to the output streamstatic void
PrivateCellUtil.writeRowKeyExcludingCommon
(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out) Write rowkey excluding the common part.static void
PrivateCellUtil.writeRowSkippingBytes
(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength, int commonPrefix) Writes the row from the given cell to the output stream excluding the common prefixModifier and TypeMethodDescriptionstatic void
HBaseTestingUtility.assertKVListsEqual
(String additionalMsg, List<? extends org.apache.hadoop.hbase.Cell> expected, List<? extends org.apache.hadoop.hbase.Cell> actual) Deprecated.static void
CellUtil.cloneIfNecessary
(ArrayList<org.apache.hadoop.hbase.Cell> cells) static boolean
KeyValueTestUtil.containsIgnoreMvccVersion
(Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection1, Collection<? extends org.apache.hadoop.hbase.Cell> kvCollection2) Checks whether KeyValues from kvCollection2 are contained in kvCollection1.static org.apache.hadoop.hbase.CellScanner
CellUtil.createCellScanner
(Iterable<org.apache.hadoop.hbase.Cell> cellIterable) Returns CellScanner interface overcellIterable
static org.apache.hadoop.hbase.CellScanner
CellUtil.createCellScanner
(Iterator<org.apache.hadoop.hbase.Cell> cells) Returns CellScanner interface overcellIterable
or null ifcells
is nullstatic org.apache.hadoop.hbase.CellScanner
CellUtil.createCellScanner
(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Flatten the map of cells out under the CellScannerstatic String
CellUtil.getCellKeyAsString
(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcell
as a String. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.client
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
Result.getColumnLatestCell
(byte[] family, byte[] qualifier) The Cell for the most recent timestamp for a given column.org.apache.hadoop.hbase.Cell
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.org.apache.hadoop.hbase.Cell[]
Result.rawCells()
Return the array of Cells backing this Result instance.Modifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.Cell>
Mutation.get
(byte[] family, byte[] qualifier) Returns a list of all KeyValue objects with matching column family and qualifier.List<org.apache.hadoop.hbase.Cell>
Result.getColumnCells
(byte[] family, byte[] qualifier) Return the Cells for the specific column.NavigableMap<byte[],
List<org.apache.hadoop.hbase.Cell>> Mutation.getFamilyCellMap()
Method for retrieving the put's familyMapList<org.apache.hadoop.hbase.Cell>
Result.listCells()
Create a sorted list of the Cell's in this result.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.Append
Append.add
(org.apache.hadoop.hbase.Cell cell) Add column and value to this Append operation.org.apache.hadoop.hbase.client.Delete
Delete.add
(org.apache.hadoop.hbase.Cell cell) Add an existing delete marker to this Delete object.org.apache.hadoop.hbase.client.Increment
Increment.add
(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this operation.org.apache.hadoop.hbase.client.Put
Put.add
(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this Put operation.static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells) Instantiate a Result with the specified array of KeyValues.static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale) static org.apache.hadoop.hbase.client.Result
Result.create
(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.Result
Result.create
(List<? extends org.apache.hadoop.hbase.Cell> cells) Instantiate a Result with the specified List of KeyValues.static org.apache.hadoop.hbase.client.Result
static org.apache.hadoop.hbase.client.Result
static org.apache.hadoop.hbase.client.Result
Result.create
(List<? extends org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) ModifierConstructorDescriptionAppend
(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Append with user defined data.Delete
(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Delete with user defined data.Increment
(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Increment with user defined data.protected
Mutation
(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the mutation with user defined data.Put
(byte[] row, long ts, NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> familyMap) Construct the Put with user defined data. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.Cell
RegionObserver.postMutationBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.Modifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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 List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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 List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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
ColumnInterpreter.getValue
(byte[] colFamily, byte[] colQualifier, org.apache.hadoop.hbase.Cell c) Returns value of type Tdefault org.apache.hadoop.hbase.Cell
RegionObserver.postMutationBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.coprocessor.RegionObserver.MutationType opType, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell oldCell, org.apache.hadoop.hbase.Cell newCell) Deprecated.since 2.2.0 and will be removedin 4.0.0.default boolean
RegionObserver.postScannerFilterRow
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell cell, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Deprecated.Since hbase-2.0.0.Modifier and TypeMethodDescriptiondefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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 List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postAppendBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result) Called after the client performs a Getdefault List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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.default List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionObserver.postIncrementBeforeWAL
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> ctx, org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.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.default void
RegionObserver.preGetOp
(org.apache.hadoop.hbase.coprocessor.ObserverContext<? extends org.apache.hadoop.hbase.coprocessor.RegionCoprocessorEnvironment> c, org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> result) Called before the client performs a Get -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.filter
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.Cell
PrefixFilter.forwardNextCellHint
protected org.apache.hadoop.hbase.Cell
PrefixFilter.reversedNextCellHint
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
ColumnPaginationFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ColumnPrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ColumnRangeFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.Cell
Filter.getNextCellHint
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.Cell
FilterBase.getNextCellHint
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.Cell
FilterList.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterListWithAND.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterListWithOR.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterWrapper.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FuzzyRowFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
MultipleColumnPrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
MultiRowRangeFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.Cell
PrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
TimestampsFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.Cell
Filter.transformCell
(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.Cell
FilterBase.transformCell
(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.Cell
FilterList.transformCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.Cell
FilterListBase.transformCell
(org.apache.hadoop.hbase.Cell c) For FilterList, we can consider a filter list as a node in a tree.org.apache.hadoop.hbase.Cell
FilterWrapper.transformCell
(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.Cell
KeyOnlyFilter.transformCell
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
SkipFilter.transformCell
(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.Cell
WhileMatchFilter.transformCell
(org.apache.hadoop.hbase.Cell v) Modifier and TypeMethodDescriptionprotected int
FilterListBase.compareCell
(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) protected boolean
CompareFilter.compareFamily
(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected boolean
CompareFilter.compareQualifier
(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected boolean
CompareFilter.compareRow
(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected boolean
CompareFilter.compareValue
(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnCountGetFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnPaginationFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnPrefixFilter.filterCell
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnRangeFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnValueFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
DependentColumnFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FamilyFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
Filter.filterCell
(org.apache.hadoop.hbase.Cell c) A way to filter based on the column family, column qualifier and/or the column value.org.apache.hadoop.hbase.filter.Filter.ReturnCode
FilterAllFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FilterList.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FilterListWithAND.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FilterListWithOR.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FilterWrapper.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FirstKeyOnlyFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
FuzzyRowFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
InclusiveStopFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
KeyOnlyFilter.filterCell
(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCode
MultipleColumnPrefixFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
MultiRowRangeFilter.filterCell
(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCode
PageFilter.filterCell
(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCode
PrefixFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
QualifierFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
RandomRowFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
RowFilter.filterCell
(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.filter.Filter.ReturnCode
SingleColumnValueFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
SkipFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
TimestampsFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ValueFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
WhileMatchFilter.filterCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCode
ColumnPrefixFilter.filterColumn
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCode
MultipleColumnPrefixFilter.filterColumn
(org.apache.hadoop.hbase.Cell cell) boolean
ColumnCountGetFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
ColumnPaginationFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
ColumnPrefixFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
ColumnRangeFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
ColumnValueFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
CompareFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) abstract boolean
Filter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) Filters a row based on the row key.boolean
FilterAllFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
FilterBase.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
FilterList.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
FilterListWithAND.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
FilterListWithOR.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
FilterWrapper.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
FirstKeyOnlyFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
InclusiveStopFilter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
KeyOnlyFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
MultipleColumnPrefixFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
MultiRowRangeFilter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
PageFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
PrefixFilter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
RandomRowFilter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
RowFilter.filterRowKey
(org.apache.hadoop.hbase.Cell firstRowCell) boolean
SingleColumnValueFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
SkipFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
TimestampsFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) boolean
WhileMatchFilter.filterRowKey
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ColumnPaginationFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ColumnPrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ColumnRangeFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.Cell
Filter.getNextCellHint
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.Cell
FilterBase.getNextCellHint
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.Cell
FilterList.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterListWithAND.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterListWithOR.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FilterWrapper.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
FuzzyRowFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.Cell
MultipleColumnPrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
MultiRowRangeFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.Cell
PrefixFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
TimestampsFilter.getNextCellHint
(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.Cell
Filter.transformCell
(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.Cell
FilterBase.transformCell
(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.org.apache.hadoop.hbase.Cell
FilterList.transformCell
(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.Cell
FilterListBase.transformCell
(org.apache.hadoop.hbase.Cell c) For FilterList, we can consider a filter list as a node in a tree.org.apache.hadoop.hbase.Cell
FilterWrapper.transformCell
(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.Cell
KeyOnlyFilter.transformCell
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
SkipFilter.transformCell
(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.Cell
WhileMatchFilter.transformCell
(org.apache.hadoop.hbase.Cell v) Modifier and TypeMethodDescriptionvoid
DependentColumnFilter.filterRowCells
(List<org.apache.hadoop.hbase.Cell> kvs) abstract void
Filter.filterRowCells
(List<org.apache.hadoop.hbase.Cell> kvs) Chance to alter the list of Cells to be submitted.void
FilterBase.filterRowCells
(List<org.apache.hadoop.hbase.Cell> ignored) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterList.filterRowCells
(List<org.apache.hadoop.hbase.Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterListBase.filterRowCells
(List<org.apache.hadoop.hbase.Cell> cells) Filters that never filter by modifying the returned List of Cells can inherit this implementation that does nothing.void
FilterWrapper.filterRowCells
(List<org.apache.hadoop.hbase.Cell> kvs) void
SingleColumnValueExcludeFilter.filterRowCells
(List<org.apache.hadoop.hbase.Cell> kvs) org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCode
FilterWrapper.filterRowCellsWithRet
(List<org.apache.hadoop.hbase.Cell> kvs) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.hfile
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
HFileWriterImpl.getLastCell()
org.apache.hadoop.hbase.Cell
CompoundBloomFilterWriter.getPrevCell()
Modifier and TypeMethodDescriptionprotected int
HFileReaderImpl.HFileScannerImpl.blockSeek
(org.apache.hadoop.hbase.Cell key, boolean seekBefore) 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
HFileWriterImpl.checkKey
(org.apache.hadoop.hbase.Cell cell) Checks that the given Cell's key does not violate the key order.boolean
CompoundBloomFilter.contains
(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) int
HFileIndexBlockEncoder.EncodedSeeker.rootBlockContainingKey
(org.apache.hadoop.hbase.Cell key) int
NoOpIndexBlockEncoder.NoOpEncodedSeeker.rootBlockContainingKey
(org.apache.hadoop.hbase.Cell key) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mapreduce
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.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) org.apache.hadoop.hbase.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, String visExpression) Deprecated.since 0.98.9org.apache.hadoop.hbase.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, List<org.apache.hadoop.hbase.Tag> tags) Modifier and TypeMethodDescriptionorg.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,
org.apache.hadoop.hbase.Cell> HFileInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordWriter<org.apache.hadoop.hbase.io.ImmutableBytesWritable,
org.apache.hadoop.hbase.Cell> HFileOutputFormat2.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) Modifier and TypeMethodDescriptionprotected void
Import.Importer.addPutToKv
(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv) org.apache.hadoop.hbase.KeyValue
CellSerialization.CellDeserializer.deserialize
(org.apache.hadoop.hbase.Cell ignore) protected boolean
WALPlayer.WALMapper.filter
(org.apache.hadoop.mapreduce.Mapper<org.apache.hadoop.hbase.wal.WALKey, org.apache.hadoop.hbase.wal.WALEdit, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.client.Mutation>.org.apache.hadoop.mapreduce.Mapper.Context context, org.apache.hadoop.hbase.Cell cell) int
Import.CellWritableComparablePartitioner.getPartition
(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable key, org.apache.hadoop.hbase.Cell value, int numPartitions) void
CellSerialization.CellSerializer.serialize
(org.apache.hadoop.hbase.Cell kv) Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializer
CellSerialization.getDeserializer
(Class<org.apache.hadoop.hbase.Cell> t) org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializer
CellSerialization.getSerializer
(Class<org.apache.hadoop.hbase.Cell> c) protected void
CellSortReducer.reduce
(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) protected void
Import.CellReducer.reduce
(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable row, Iterable<org.apache.hadoop.hbase.Cell> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable, org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.io.ImmutableBytesWritable, org.apache.hadoop.hbase.Cell>.org.apache.hadoop.mapreduce.Reducer.Context context) ModifierConstructorDescriptionCellWritableComparable
(org.apache.hadoop.hbase.Cell kv) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mob
Modifier and TypeMethodDescriptionstatic String
MobUtils.getMobFileName
(org.apache.hadoop.hbase.Cell cell) Gets the mob file name from the mob ref cell.static int
MobUtils.getMobValueLength
(org.apache.hadoop.hbase.Cell cell) Gets the mob value length from the mob ref cell.static boolean
MobUtils.hasValidMobRefCellValue
(org.apache.hadoop.hbase.Cell cell) Indicates whether the current mob ref cell has a valid value. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.quotas
Modifier and TypeMethodDescriptionprotected static String
QuotaTableUtil.extractSnapshotNameFromSizeCell
(org.apache.hadoop.hbase.Cell c) Modifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addScanResultCells
(List<org.apache.hadoop.hbase.Cell> cells) void
OperationQuota.addScanResultCells
(List<org.apache.hadoop.hbase.Cell> cells) Add a scan result in the form of cells.static long
QuotaUtil.calculateCellsSize
(List<org.apache.hadoop.hbase.Cell> cells) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.CellArrayMap<T extends org.apache.hadoop.hbase.Cell>
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.class
org.apache.hadoop.hbase.regionserver.CellChunkMap<T extends org.apache.hadoop.hbase.Cell>
CellChunkMap is an array of serialized representations of Cell (pointing to Chunks with full Cell data) and can be allocated both off-heap and on-heap.class
org.apache.hadoop.hbase.regionserver.CellFlatMap<T extends org.apache.hadoop.hbase.Cell>
CellFlatMap stores a constant number of elements and is immutable after creation stage.class
org.apache.hadoop.hbase.regionserver.CellSet<T extends org.apache.hadoop.hbase.Cell>
ASet
ofCell
s, where an add will overwrite the entry if already exists in the set.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offsetclass
org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tagsModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
CellSet.get
(org.apache.hadoop.hbase.Cell kv) Modifier and TypeMethodDescriptionList<org.apache.hadoop.hbase.Cell>
HRegion.get
(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor) List<org.apache.hadoop.hbase.Cell>
Region.get
(org.apache.hadoop.hbase.client.Get get, boolean withCoprocessor) Do a get based on the get parameter.List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) Modifier and TypeMethodDescriptionprotected boolean
CompactingMemStore.checkAndAddToActiveSize
(org.apache.hadoop.hbase.regionserver.MutableSegment currActive, org.apache.hadoop.hbase.Cell cellToAdd, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Check whether anything need to be done based on the current active set size.protected void
ReversedStoreScanner.checkScanOrder
(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) protected void
StoreScanner.checkScanOrder
(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) Check whether scan as expected orderint
CompositeImmutableSegment.compare
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) int
KeyValueHeap.KVScannerComparator.compare
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares two KeyValueint
Segment.compare
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) int
CompositeImmutableSegment.compareRows
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) int
Segment.compareRows
(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) org.apache.hadoop.hbase.Cell
CellSet.get
(org.apache.hadoop.hbase.Cell kv) protected long
Segment.heapSizeChange
(org.apache.hadoop.hbase.Cell cell, boolean allocated) protected long
Segment.offHeapSizeChange
(org.apache.hadoop.hbase.Cell cell, boolean allocated) boolean
RegionCoprocessorHost.postScannerFilterRow
(org.apache.hadoop.hbase.regionserver.InternalScanner s, org.apache.hadoop.hbase.Cell curRowCell) This will be called by the scan flow when the current scanned row is being filtered out by the filter.boolean
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion
(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Supports Coprocessor 'bypass'.protected void
StripeMultiFileWriter.sanityCheckLeft
(byte[] left, org.apache.hadoop.hbase.Cell cell) Subclasses can call this method to make sure the first KV is within multi-writer range.protected void
StripeMultiFileWriter.sanityCheckRight
(byte[] right, org.apache.hadoop.hbase.Cell cell) Subclasses can call this method to make sure the last KV is within multi-writer range.NavigableSet<T>
CellSet.subSet
(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive) Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) Updates the candidate list for finding row key before.Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore
(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods.Modifier and TypeMethodDescriptionvoid
Check the collection of families for valid timestampsList<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postAppendBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) void
RegionCoprocessorHost.postGet
(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell,
org.apache.hadoop.hbase.Cell>> RegionCoprocessorHost.postIncrementBeforeWAL
(org.apache.hadoop.hbase.client.Mutation mutation, List<org.apache.hadoop.hbase.util.Pair<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell>> cellPairs) boolean
RegionCoprocessorHost.preGet
(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) Supports Coprocessor 'bypass'.ModifierConstructorDescriptionCellArrayMap
(Comparator<? super T> comparator, T[] b, int min, int max, boolean descending) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.throttle
-
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionstatic void
WALUtil.filterCells
(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell> mapper) static void
WALUtil.filterCells
(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell> mapper) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.replication
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
NamespaceTableCfWALEntryFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ScopeWALEntryFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
WALCellFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) Applies the filter, possibly returning a different Cell instance.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
NamespaceTableCfWALEntryFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
ScopeWALEntryFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.Cell
WALCellFilter.filterCell
(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) Applies the filter, possibly returning a different Cell instance. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.rest
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
RowResultGenerator.next()
org.apache.hadoop.hbase.Cell
ScannerResultGenerator.next()
Modifier and TypeMethodDescriptionabstract void
ResultGenerator.putBack
(org.apache.hadoop.hbase.Cell kv) void
RowResultGenerator.putBack
(org.apache.hadoop.hbase.Cell kv) void
ScannerResultGenerator.putBack
(org.apache.hadoop.hbase.Cell kv) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Cursor
ProtobufUtil.toCursor
(org.apache.hadoop.hbase.Cell cell) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.thrift
Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift.generated.TCell>
ThriftUtilities.cellFromHBase
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.Cell[] in) This utility method creates a list of Thrift TCell "struct" based on an Hbase Cell array. -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.util
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.util.MapReduceExtendedCell
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Cell
BloomContext.getLastCell()
org.apache.hadoop.hbase.Cell
BloomFilterWriter.getPrevCell()
Returns the previous cell written by this writerModifier and TypeMethodDescriptionvoid
BloomFilterChunk.add
(org.apache.hadoop.hbase.Cell cell) static int
Bytes.binarySearch
(org.apache.hadoop.hbase.Cell[] arr, org.apache.hadoop.hbase.Cell key, CellComparator comparator) Binary search for keys in indexes.boolean
BloomFilter.contains
(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) Check if the specified key is contained in the bloom filter.static boolean
BloomFilterUtil.contains
(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.nio.ByteBuff bloomBuf, int bloomOffset, int bloomSize, org.apache.hadoop.hbase.util.Hash hash, int hashCount, org.apache.hadoop.hbase.regionserver.BloomType type) ModifierConstructorDescriptionCellHashKey
(org.apache.hadoop.hbase.Cell cell) RowBloomHashKey
(org.apache.hadoop.hbase.Cell cell) RowColBloomHashKey
(org.apache.hadoop.hbase.Cell cell) -
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.wal.WALEdit
WALEdit.add
(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.wal.WALEdit
WALEdit.add
(org.apache.hadoop.hbase.Cell cell, byte[] family) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor
WALEdit.getBulkLoadDescriptor
(org.apache.hadoop.hbase.Cell cell) Deserialized and returns a BulkLoadDescriptor from the passed in Cellstatic org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor
WALEdit.getCompaction
(org.apache.hadoop.hbase.Cell kv) Deserialized and returns a CompactionDescriptor is the KeyValue contains one.static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor
WALEdit.getFlushDescriptor
(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptor
WALEdit.getRegionEventDescriptor
(org.apache.hadoop.hbase.Cell cell) static boolean
WALEdit.isCompactionMarker
(org.apache.hadoop.hbase.Cell cell) Returns true if the given cell is a serializedWALProtos.CompactionDescriptor
static boolean
WALEdit.isMetaEditFamily
(org.apache.hadoop.hbase.Cell cell) Replaying WALs can read Cell-at-a-time so need this method in those cases.