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
RawCell.createCell
(Cell cell, List<Tag> tags) Returns A new cell which is having the extra tags also added to it.CellScanner.current()
Returns the current Cell which may be mutableModifier and TypeMethodDescriptionHBaseTestingUtility.getFromStoreFile
(HStore store, byte[] row, NavigableSet<byte[]> columns) Deprecated.Do a small get/scan against one store.HBaseTestingUtility.getFromStoreFile
(HStore store, Get get) Deprecated.Do a small get/scan against one store.CellComparator.getSimpleComparator()
Return a dumbed-down, fast comparator for hbase2 base-type, theByteBufferKeyValue
.CellComparatorImpl.getSimpleComparator()
Modifier and TypeMethodDescriptionstatic void
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[]
CellUtil.cloneValue
(Cell cell) int
Lexographically compares two cells.int
Compare cells.final int
int
int
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[]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 comparatorstatic final int
PrivateCellUtil.compareKeyIgnoresMvcc
(CellComparator comparator, Cell left, Cell right) Compares only the key portion of a cell.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 comparatordefault 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
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) 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) 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 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 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
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
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 ExtendedCell
PrivateCellUtil.createFirstOnNextRow
(Cell cell) static ExtendedCell
PrivateCellUtil.createFirstOnRow
(Cell cell) Create a Cell that is smaller than all other possible Cells for the given Cell's row.static ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(Cell cell) static ExtendedCell
PrivateCellUtil.createFirstOnRowCol
(Cell cell, byte[] qArray, int qoffest, int qlength) Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and passed qualifier.static ExtendedCell
PrivateCellUtil.createFirstOnRowColTS
(Cell cell, long ts) Creates the first cell with the row/family/qualifier of this cell and the given timestamp.static ExtendedCell
PrivateCellUtil.createFirstOnRowFamily
(Cell cell, byte[] fArray, int foff, int flen) static ExtendedCell
PrivateCellUtil.createLastOnRow
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's row.static ExtendedCell
PrivateCellUtil.createLastOnRowCol
(Cell cell) Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.static ExtendedCell
PrivateCellUtil.ensureExtendedCell
(Cell cell) In fact, in HBase, allCell
s areExtendedCell
s.static boolean
equalsstatic int
PrivateCellUtil.estimatedSerializedSizeOf
(Cell cell) Estimate based on keyvalue's serialization format in the RPC layer.static int
PrivateCellUtil.estimatedSerializedSizeOfKey
(Cell cell) Calculates the serialized key size.static ByteRange
PrivateCellUtil.fillFamilyRange
(Cell cell, ByteRange range) static ByteRange
PrivateCellUtil.fillQualifierRange
(Cell cell, ByteRange range) static ByteRange
PrivateCellUtil.fillRowRange
(Cell cell, ByteRange range) ByteRangestatic ByteRange
PrivateCellUtil.fillValueRange
(Cell cell, ByteRange range) static String
CellUtil.getCellKeyAsString
(Cell cell) Returns 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 List<RegionInfo>
CatalogFamilyFormat.getMergeRegions
(Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells
.static Map<String,
RegionInfo> CatalogFamilyFormat.getMergeRegionsWithName
(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
(Cell cell, int index) static int
PrivateCellUtil.getRowAsInt
(Cell cell) Converts the rowkey bytes of the given cell into an int valuestatic byte
PrivateCellUtil.getRowByte
(Cell cell, int index) miscstatic long
PrivateCellUtil.getSequenceId
(Cell c) static byte
PrivateCellUtil.getTypeByte
(Cell c) static 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
PrivateCellUtil.getValueBufferShallowCopy
(Cell cell) static boolean
CatalogFamilyFormat.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
CatalogFamilyFormat.isMergeQualifierPrefix
(Cell cell) Returns True if the column incell
matches the regex 'info:merge.*'.static boolean
Returns True if this cell is a Put.private boolean
HBaseTestingUtility.isTargetTable
(byte[] inRow, Cell c) Deprecated.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) 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 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.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, int offset, int length) static boolean
CellUtil.matchingRowColumn
(Cell left, Cell right) 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 equalitystatic boolean
PrivateCellUtil.matchingRows
(Cell left, byte[] buf, int offset, int length) static boolean
CellUtil.matchingTags
(Cell left, Cell right) Deprecated.Since 3.0.0, will be removed in 4.0.0.static boolean
CellUtil.matchingTimestamp
(Cell a, Cell b) static boolean
CellUtil.matchingValue
(Cell left, byte[] buf) static boolean
CellUtil.matchingValue
(Cell left, Cell right) static boolean
CellUtil.matchingValue
(Cell left, Cell right, int lvlength, int rvlength) static boolean
PrivateCellUtil.matchingValue
(Cell left, Cell right, int lvlength, int rvlength) static boolean
PrivateCellUtil.qualifierStartsWith
(Cell left, byte[] startsWith) Finds if the start of the qualifier part of the Cell matchesbuf
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) Sets the given timestamp to the cell.static void
CellUtil.setTimestamp
(Cell cell, long ts) Sets the given timestamp to the cell.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.static String
Returns a string representation of the cellstatic boolean
PrivateCellUtil.updateLatestStamp
(Cell cell, byte[] ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP
.static void
PrivateCellUtil.writeFamily
(OutputStream out, Cell cell, byte flength) Writes the family from the given cell to the output streamstatic 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
PrivateCellUtil.writeRowKeyExcludingCommon
(Cell cell, short rLen, int commonPrefix, DataOutputStream out) Write rowkey excluding the common part.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 prefixModifier and TypeMethodDescriptionstatic void
HBaseTestingUtility.assertKVListsEqual
(String additionalMsg, List<? extends Cell> expected, List<? extends Cell> actual) Deprecated.static 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 CellScannerstatic String
CellUtil.getCellKeyAsString
(Cell cell, Function<Cell, String> rowConverter) Return the Key portion of the passedcell
as a String. -
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 TypeMethodDescriptionResult.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.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.private int
Result.binarySearch
(Cell[] kvs, byte[] family, byte[] qualifier) private 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.static Result
Instantiate a Result with the specified array of KeyValues.static Result
static Result
Modifier and TypeMethodDescriptionstatic Result
Instantiate a Result with the specified List of KeyValues.static Result
static Result
static Result
Result.create
(List<? extends Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) 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.coprocessor
Modifier and TypeMethodDescriptiondefault Cell
RegionObserver.postMutationBeforeWAL
(ObserverContext<? extends 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<? extends 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<? extends 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<? extends 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<? extends 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<? extends 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<? extends 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<? extends RegionCoprocessorEnvironment> c, Mutation mutation, Cell cell, byte[] byteNow, Get get) Deprecated.Since hbase-2.0.0.Modifier and TypeMethodDescriptionRegionObserver.postAppendBeforeWAL
(ObserverContext<? extends 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<? extends 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<? extends RegionCoprocessorEnvironment> c, Get get, List<Cell> result) Called after the client performs a GetRegionObserver.postIncrementBeforeWAL
(ObserverContext<? extends 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<? extends 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<? extends RegionCoprocessorEnvironment> e, Get get, List<Cell> results) default void
RegionObserver.preGetOp
(ObserverContext<? extends 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.shaded.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType deleteType, Long timestamp) void
ExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
ExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp
(ObserverContext<? extends RegionCoprocessorEnvironment> e, Get get, List<Cell> results) void
WriteHeavyIncrementObserver.preGetOp
(ObserverContext<? extends 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 TypeFieldDescriptionprotected Cell
PrefixFilter.forwardNextCellHint
protected Cell
PrefixFilter.reversedNextCellHint
Modifier and TypeMethodDescriptionprivate Cell
KeyOnlyFilter.createKeyOnlyCell
(ExtendedCell 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) PrefixFilter.getNextCellHint
(Cell cell) 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 Cell.FilterBase.transformCell
(Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.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.compareQualifier
(CompareOperator op, ByteArrayComparable comparator, Cell cell) private static int
ColumnPrefixFilter.compareQualifierPart
(Cell cell, int length, byte[] prefix) protected boolean
CompareFilter.compareRow
(CompareOperator op, ByteArrayComparable comparator, Cell cell) 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) 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.FilterAllFilter.filterCell
(Cell c) FilterList.filterCell
(Cell c) FilterListWithAND.filterCell
(Cell c) FilterListWithOR.filterCell
(Cell c) FilterWrapper.filterCell
(Cell c) FirstKeyOnlyFilter.filterCell
(Cell c) 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) 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
FilterAllFilter.filterRowKey
(Cell cell) 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) PrefixFilter.getNextCellHint
(Cell cell) TimestampsFilter.getNextCellHint
(Cell currentCell) Pick the next cell that the scanner should seek to.(package private) boolean
abstract Cell
Filter.transformCell
(Cell v) Give the filter a chance to transform the passed Cell.FilterBase.transformCell
(Cell v) By default no transformation takes place Give the filter a chance to transform the passed Cell.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.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 TypeMethodDescriptionprivate int
RowIndexSeekerV1.binarySearch
(Cell seekCell, boolean seekBefore) 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 prefixesprivate 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) -
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
HFilePrettyPrinter.KeyValueStatsCollector.prevCell
Modifier and TypeMethodDescriptionHFileWriterImpl.getLastCell()
CompoundBloomFilterWriter.getPrevCell()
abstract Cell
HFileBlockIndex.BlockIndexReader.midkey
(HFile.CachingBlockReader cachingBlockReader) An approximation to theHFile
's mid-key.HFileBlockIndex.ByteArrayKeyBlockIndexReader.midkey
(HFile.CachingBlockReader cachingBlockReader) Modifier and TypeMethodDescription(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
boolean
private boolean
CompoundBloomFilter.containsInternal
(Cell keyCell, ByteBuff bloom, BloomType type) private String
HFileWriterImpl.getLexicalErrorMessage
(Cell cell) (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.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) -
Uses of Cell in org.apache.hadoop.hbase.mapreduce
Modifier and TypeFieldDescriptionprivate 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) 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) HFileInputFormat.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.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) int
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 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.static boolean
MobUtils.hasValidMobRefCellValue
(Cell cell) Indicates whether the current mob ref cell has a valid value. -
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.Modifier and TypeMethodDescriptionvoid
DefaultOperationQuota.addScanResultCells
(List<Cell> cells) void
NoopOperationQuota.addScanResultCells
(List<Cell> cells) void
OperationQuota.addScanResultCells
(List<Cell> cells) Add a scan result in the form of cells.static long
QuotaUtil.calculateCellsSize
(List<Cell> cells) -
Uses of Cell in org.apache.hadoop.hbase.regionserver
Modifier and TypeClassDescriptionclass
CellArrayMap<T extends Cell>
CellArrayMap is a simple array of Cells and cannot be allocated off-heap.class
CellChunkMap<T extends 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
CellFlatMap<T extends Cell>
CellFlatMap stores a constant number of elements and is immutable after creation stage.class
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 T[]
CellArrayMap.block
private Cell
StripeMultiFileWriter.BoundaryMultiWriter.lastCell
private Cell
StripeMultiFileWriter.SizeMultiWriter.lastCell
private Cell
ScannerContext.lastPeekedCell
private Cell
StoreFileScanner.previousRow
Modifier and TypeFieldDescriptionRegionScannerImpl.MOCKED_LIST
A mocked list implementation - discards all updates.Modifier and TypeMethodDescriptionDo a get based on the get parameter.HRegion.getInternal
(Get get, boolean withCoprocessor, long nonceGroup, long nonce) Modifier and TypeMethodDescriptionprotected 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) MobReferenceOnlyFilter.filterCell
(Cell cell) private boolean
RegionScannerImpl.filterRowKey
(Cell current) (package private) static int
Segment.getCellLength
(Cell cell) Get cell length after serialized inKeyValue
private static long
HRegion.MutationBatchOperation.getLongValue
(Cell cell) Returns Get the long out of the passed in Cellprivate HStore
Return HStore instance.protected long
Segment.heapSizeChange
(Cell cell, boolean allocated) private boolean
StripeMultiFileWriter.BoundaryMultiWriter.isCellAfterCurrentWriter
(Cell cell) private static final boolean
private boolean
StoreFileScanner.isStillAtSeekTargetAfterSkippingNewerKvs
(Cell seekKey) 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) boolean
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) Supports Coprocessor 'bypass'.private void
HRegion.replayWALMetaEdit
(Cell cell) Replay the meta edits, i.e, flush marker, compaction marker, bulk load marker, region event marker, etc.protected 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.private boolean
StoreFileScanner.seekToPreviousRowWithoutHint
(Cell originalKey) This variant of theStoreFileScanner#seekToPreviousRow(Cell)
method requires two seeks and one reseek.(package private) void
ScannerContext.setLastPeekedCell
(Cell lastPeekedCell) protected boolean
RegionScannerImpl.shouldStop
(Cell currentRowCell) protected boolean
ReversedRegionScannerImpl.shouldStop
(Cell currentRowCell) 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) Modifier and TypeMethodDescriptionvoid
HRegion.checkTimestamps
(Map<byte[], List<Cell>> familyMap, long now) Check the collection of families for valid timestampsvoid
boolean
Supports Coprocessor 'bypass'.private void
HRegion.recordMutationWithoutWal
(Map<byte[], List<Cell>> familyMap) Update LongAdders for number of puts without wal and the size of possible data loss.ModifierConstructorDescriptionCellArrayMap
(Comparator<? super T> comparator, T[] b, int min, int max, boolean descending) -
Uses of Cell in org.apache.hadoop.hbase.regionserver.regionreplication
Modifier and TypeMethodDescription(package private) Optional<org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor>
RegionReplicationSink.getStartFlushAllDescriptor
(Cell metaCell) -
Uses of Cell in org.apache.hadoop.hbase.regionserver.throttle
-
Uses of Cell in org.apache.hadoop.hbase.regionserver.wal
Modifier and TypeMethodDescriptionprivate void
WALCellCodec.CompressedKvEncoder.writeCompressedValue
(OutputStream out, Cell cell) Modifier and TypeMethodDescriptionstatic 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 TypeMethodDescriptionprivate Cell
ChainWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) 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
private Cell
ChainWALEntryFilter.filterCell
(WAL.Entry entry, Cell cell) 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.private static long
ReplicationBarrierFamilyFormat.getReplicationBarrier
(Cell c) -
Uses of Cell in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate Cell
SerialReplicationSourceWALReader.firstCellInEntryBeforeFiltering
Modifier and TypeMethodDescriptionboolean
private 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<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<? extends 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) 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<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) AccessController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) void
AccessController.preGetOp
(ObserverContext<? extends 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, ExtendedCell newCell) Modifier and TypeMethodDescriptionDefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths()
VisibilityController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) Modifier and TypeMethodDescriptionboolean
Evaluates whether the passed cell passes Scan/Get Authorization.VisibilityController.DeleteVersionVisibilityExpressionFilter.filterCell
(Cell cell) VisibilityLabelFilter.filterCell
(Cell cell) boolean
VisibilityController.DeleteVersionVisibilityExpressionFilter.filterRowKey
(Cell cell) boolean
VisibilityLabelFilter.filterRowKey
(Cell cell) void
VisibilityController.prePrepareTimeStampForDeleteVersion
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation delete, Cell cell, byte[] byteNow, Get get) Modifier and TypeMethodDescriptionDefaultVisibilityLabelServiceImpl.extractLabelsAndAuths
(List<List<Cell>> labelDetails) VisibilityController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postAppendBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) VisibilityController.postIncrementBeforeWAL
(ObserverContext<? extends RegionCoprocessorEnvironment> ctx, Mutation mutation, List<Pair<Cell, Cell>> cellPairs) void
VisibilityController.preGetOp
(ObserverContext<? extends 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.tool
Modifier and TypeMethodDescriptionprivate static StoreFileWriter
BulkLoadHFilesTool.initStoreFileWriter
(org.apache.hadoop.conf.Configuration conf, Cell cell, HFileContext hFileContext, CacheConfig cacheConf, BloomType bloomFilterType, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path outFile, AsyncTableRegionLocator loc) -
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 TypeMethodDescriptionBloomContext.getLastCell()
BloomFilterWriter.getPrevCell()
Returns the previous cell written by this writerModifier and TypeMethodDescriptionvoid
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) ModifierConstructorDescriptionCellHashKey
(Cell cell) RowBloomHashKey
(Cell cell) RowColBloomHashKey
(Cell cell) -
Uses of Cell in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionstatic 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.Modifier and TypeMethodDescriptionvoid
This is just for keeping compatibility for CPs, in HBase you should call the belowWALEdit.addMap(Map)
directly to avoid casting.(package private) void
This is just for keeping compatibility for CPs, in HBase you should call the belowWALEdit.setExtendedCells(ArrayList)
directly to avoid casting.