Uses of Interface
org.apache.hadoop.hbase.Cell
Packages that use 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
Subinterfaces of org.apache.hadoop.hbase.Cell in in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.ExtendedCellExtension toCellwith server side required functions.interfaceorg.apache.hadoop.hbase.RawCellAn extended version of Cell that allows CPs manipulate Tags.Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ByteBufferExtendedCellThis class is a server side extension to theCellinterface.classorg.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValueThis is a key only Cell implementation which is identical toKeyValue.KeyOnlyKeyValuewith respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).classorg.apache.hadoop.hbase.ByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.IndividualBytesFieldCellclassorg.apache.hadoop.hbase.KeyValueAn HBase Key/Value.static classorg.apache.hadoop.hbase.KeyValue.KeyOnlyKeyValueA 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.classorg.apache.hadoop.hbase.NoTagsByteBufferKeyValueAn extension of the ByteBufferKeyValue where the tags length is always 0classorg.apache.hadoop.hbase.NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0classorg.apache.hadoop.hbase.SizeCachedByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached.classorg.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValueThis Cell is an implementation ofByteBufferExtendedCellwhere the data resides in off heap/ on heap ByteBufferclassorg.apache.hadoop.hbase.SizeCachedNoTagsKeyValueThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellBuilder.build()static org.apache.hadoop.hbase.CellCellUtil.cloneIfNecessary(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] value) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] family, byte[] qualifier) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, byte[] tags, long memstoreTS) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, byte type, byte[] value, long memstoreTS) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] row, byte[] family, byte[] qualifier, long timestamp, org.apache.hadoop.hbase.KeyValue.Type type, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(byte[] rowArray, int rowOffset, int rowLength, byte[] familyArray, int familyOffset, int familyLength, byte[] qualifierArray, int qualifierOffset, int qualifierLength) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellPrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.CellPrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellRawCell.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.CellPrivateCellUtil.createFirstDeleteFamilyCellOnRow(byte[] row, byte[] fam) Create a Delete Family Cell for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.static org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnNextRow(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnRow(byte[] row) static org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnRow(byte[] row, byte[] family, byte[] col) static org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength) static org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnRow(byte[] row, int roffset, short rlength, byte[] family, int foffset, byte flength, byte[] col, int coffset, int clength) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.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.CellPrivateCellUtil.createFirstOnRowFamily(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen) static org.apache.hadoop.hbase.CellPrivateCellUtil.createLastOnRow(byte[] row) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.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.CellPrivateCellUtil.createNextOnRowCol(org.apache.hadoop.hbase.Cell cell) Return a new cell is located following input cell.org.apache.hadoop.hbase.CellCellScanner.current()Returns the current Cell which may be mutablestatic org.apache.hadoop.hbase.CellPrivateCellUtil.deepClone(org.apache.hadoop.hbase.Cell cell) Deep clones the given cell if the cell supports deep cloningMethods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionComparator<org.apache.hadoop.hbase.Cell>CellComparator.getSimpleComparator()Return a dumbed-down, fast comparator for hbase2 base-type, theByteBufferKeyValue.Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic intKeyValueUtil.appendKeyTo(org.apache.hadoop.hbase.Cell cell, byte[] output, int offset) static intKeyValueUtil.appendKeyTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset) static intKeyValueUtil.appendTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset, boolean withTags) Copy the Cell content into the passed buf in KeyValue serialization format.static intKeyValueUtil.appendToByteArray(org.apache.hadoop.hbase.Cell cell, byte[] output, int offset, boolean withTags) copy key and valuestatic List<org.apache.hadoop.hbase.Tag>TagUtil.carryForwardTags(List<org.apache.hadoop.hbase.Tag> tagsOrNull, org.apache.hadoop.hbase.Cell cell) Add totagsOrNullany Tagscellis carrying or null if none.static List<org.apache.hadoop.hbase.Tag>TagUtil.carryForwardTags(org.apache.hadoop.hbase.Cell cell) Returns A List<Tag> of any Tags found incellelse null.static byte[]CellUtil.cloneFamily(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellCellUtil.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.cloneTags(org.apache.hadoop.hbase.Cell cell) Deprecated.As of HBase-2.0.static byte[]PrivateCellUtil.cloneTags(org.apache.hadoop.hbase.Cell cell) static byte[]CellUtil.cloneValue(org.apache.hadoop.hbase.Cell cell) intCellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares two cells.intCellComparator.compare(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell, boolean ignoreSequenceid) Compare cells.final intCellComparatorImpl.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) intCellComparatorImpl.compare(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r, boolean ignoreSequenceid) static final intCellUtil.compare(CellComparator comparator, org.apache.hadoop.hbase.Cell left, byte[] key, int offset, int length) Deprecated.As of HBase-2.0.intKeyValue.KVComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compares the Key of a cell -- with fields being more significant in this order: rowkey, colfam/qual, timestamp, type, mvccintKeyValue.MetaComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compare key portion of aKeyValuefor keys inhbase:metatable.intMetaCellComparator.compare(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b, boolean ignoreSequenceid) static final intPrivateCellUtil.compare(CellComparator comparator, org.apache.hadoop.hbase.Cell left, byte[] key, int offset, int length) Used when a cell needs to be compared with a key byte[] such as cases of finding the index from the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this method cannot be used.final intCellComparatorImpl.compareColumns(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the family and qualifier part of the cellstatic final intCellUtil.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[]intCellComparator.compareFamilies(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the families of the two cellsprotected intCellComparatorImpl.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 intCellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compare the families of left and right cellstatic final intCellUtil.compareFamilies(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) Compares the cell's family with the given byte[]protected intInnerStoreCellComparator.compareFamilies(org.apache.hadoop.hbase.Cell left, int leftFamilyLength, org.apache.hadoop.hbase.Cell right, int rightFamilyLength) static intPrivateCellUtil.compareFamily(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's column family against given comparatorintKeyValue.KVComparator.compareKey(org.apache.hadoop.hbase.Cell cell, byte[] row, int roff, int rlen, byte[] fam, int foff, int flen, byte[] col, int coff, int clen, long ts, byte type) Deprecated.static final intPrivateCellUtil.compareKeyBasedOnColHint(CellComparator comparator, org.apache.hadoop.hbase.Cell nextIndexedCell, org.apache.hadoop.hbase.Cell currentCell, int foff, int flen, byte[] colHint, int coff, int clen, long ts, byte type) Used to compare two cells based on the column hint provided.static final intPrivateCellUtil.compareKeyIgnoresMvcc(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares only the key portion of a cell.intKeyValue.KVComparator.compareOnlyKeyPortion(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.intKeyValue.MetaComparator.compareOnlyKeyPortion(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.static intPrivateCellUtil.compareQualifier(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's qualifier against given comparatorintCellComparator.compareQualifiers(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the qualifiers of the two cellsfinal intCellComparatorImpl.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 intCellUtil.compareQualifiers(org.apache.hadoop.hbase.Cell left, byte[] right, int rOffset, int rLength) Compares the cell's qualifier with the given byte[]static intPrivateCellUtil.compareRow(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's row against given comparatorprotected intKeyValue.KVComparator.compareRowKey(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compares the only the user specified portion of a Key.protected intKeyValue.MetaComparator.compareRowKey(org.apache.hadoop.hbase.Cell l, org.apache.hadoop.hbase.Cell r) Deprecated.Override the row key comparison to parse and compare the meta row key parts.default intCellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) Lexicographically compare two rowsintCellComparator.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.intCellComparator.compareRows(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexographically compares the rows of two cells.intCellComparatorImpl.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.intCellComparatorImpl.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the rows of the left and right cell.intKeyValue.KVComparator.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compares the rows of a cellintMetaCellComparator.compareRows(ByteBuffer row, org.apache.hadoop.hbase.Cell cell) intMetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, byte[] right, int roffset, int rlength) intMetaCellComparator.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intCellComparator.compareTimestamps(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Compares cell's timestamps in DESCENDING order.intCellComparatorImpl.compareTimestamps(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intKeyValue.KVComparator.compareTimestamps(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.static intPrivateCellUtil.compareValue(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator) Compare cell's value against given comparatorintCellComparator.compareWithoutRow(org.apache.hadoop.hbase.Cell leftCell, org.apache.hadoop.hbase.Cell rightCell) Lexicographically compares the two cells excluding the row part.final intCellComparatorImpl.compareWithoutRow(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static voidPrivateCellUtil.compressFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static voidPrivateCellUtil.compressQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static voidPrivateCellUtil.compressRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.util.Dictionary dict) static voidPrivateCellUtil.compressTags(OutputStream out, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.TagCompressionContext tagCompressionContext) Compresses the tags to the given outputstream using the TagcompressionContextstatic byte[]TagUtil.concatTags(byte[] tags, org.apache.hadoop.hbase.Cell cell) static intCellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the family to the given byte[]static intCellUtil.copyFamilyTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the family to the given bytebufferstatic ByteBufferKeyValueUtil.copyKeyToNewByteBuffer(org.apache.hadoop.hbase.Cell cell) The position will be set to the beginning of the new ByteBufferstatic intCellUtil.copyQualifierTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the qualifier to the given byte[]static intCellUtil.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 intCellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the row to the given byte[]static intCellUtil.copyRowTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the row to the given bytebufferstatic intPrivateCellUtil.copyTagsTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic intPrivateCellUtil.copyTagsTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the tags info into the tag portion of the cellstatic intCellUtil.copyTagTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Deprecated.As of HBase-2.0.static intCellUtil.copyTagTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Deprecated.As of HBase-2.0.static byte[]KeyValueUtil.copyToNewByteArray(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.KeyValueKeyValueUtil.copyToNewKeyValue(org.apache.hadoop.hbase.Cell cell) copy the cell to create a new keyvaluestatic intCellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, byte[] destination, int destinationOffset) Copies the value to the given byte[]static intCellUtil.copyValueTo(org.apache.hadoop.hbase.Cell cell, ByteBuffer destination, int destinationOffset) Copies the value to the given bytebufferstatic org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, List<org.apache.hadoop.hbase.Tag> tags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static org.apache.hadoop.hbase.CellPrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] tags) Returns A new cell which is having the extra tags also added to it.static org.apache.hadoop.hbase.CellPrivateCellUtil.createCell(org.apache.hadoop.hbase.Cell cell, byte[] value, byte[] tags) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellRawCell.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.CellScannerCellUtil.createCellScanner(org.apache.hadoop.hbase.Cell[] cellArray) Returns CellScanner interface overcellArraystatic org.apache.hadoop.hbase.CellPrivateCellUtil.createFirstOnNextRow(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.createFirstOnRowCol(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.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.CellPrivateCellUtil.createFirstOnRowFamily(org.apache.hadoop.hbase.Cell cell, byte[] fArray, int foff, int flen) static org.apache.hadoop.hbase.CellPrivateCellUtil.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.CellPrivateCellUtil.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.CellPrivateCellUtil.createNextOnRowCol(org.apache.hadoop.hbase.Cell cell) Return a new cell is located following input cell.static org.apache.hadoop.hbase.CellPrivateCellUtil.deepClone(org.apache.hadoop.hbase.Cell cell) Deep clones the given cell if the cell supports deep cloningstatic org.apache.hadoop.hbase.KeyValueKeyValueUtil.ensureKeyValue(org.apache.hadoop.hbase.Cell cell) Deprecated.without any replacement.static booleanCellUtil.equals(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) equalsstatic booleanCellUtil.equalsIgnoreMvccVersion(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) Deprecated.As of HBase-2.0.static booleanPrivateCellUtil.equalsIgnoreMvccVersion(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) special case for Cell.equalsstatic longCellUtil.estimatedHeapSizeOf(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static intCellUtil.estimatedSerializedSizeOf(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static intPrivateCellUtil.estimatedSerializedSizeOf(org.apache.hadoop.hbase.Cell cell) Estimate based on keyvalue's serialization format in the RPC layer.static intCellUtil.estimatedSerializedSizeOfKey(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static intPrivateCellUtil.estimatedSerializedSizeOfKey(org.apache.hadoop.hbase.Cell cell) Calculates the serialized key size.static org.apache.hadoop.hbase.util.ByteRangeCellUtil.fillFamilyRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) Deprecated.As of HBase-2.0.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillFamilyRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRangeCellUtil.fillQualifierRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) Deprecated.As of HBase-2.0.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillQualifierRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRangeCellUtil.fillRowRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) Deprecated.As of HBase-2.0.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillRowRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) ByteRangestatic org.apache.hadoop.hbase.util.ByteRangeCellUtil.fillTagRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) Deprecated.As of HBase-2.0.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillTagRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static org.apache.hadoop.hbase.util.ByteRangeCellUtil.fillValueRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) Deprecated.As of HBase-2.0.static org.apache.hadoop.hbase.util.ByteRangePrivateCellUtil.fillValueRange(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.util.ByteRange range) static intCellUtil.findCommonPrefixInFlatKey(org.apache.hadoop.hbase.Cell c1, org.apache.hadoop.hbase.Cell c2, boolean bypassFamilyCheck, boolean withTsType) Deprecated.As of HBase-2.0.static intPrivateCellUtil.findCommonPrefixInFlatKey(org.apache.hadoop.hbase.Cell c1, org.apache.hadoop.hbase.Cell c2, boolean bypassFamilyCheck, boolean withTsType) Find length of common prefix in keys of the cells, considering key as byte[] if serialized inKeyValue.static StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell) Return the key portion of the passedcellas a String.static StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcellas a String.static byte[]CellUtil.getCellKeySerializedAsKeyValueKey(org.apache.hadoop.hbase.Cell cell) Deprecated.As of HBase-2.0.static byte[]PrivateCellUtil.getCellKeySerializedAsKeyValueKey(org.apache.hadoop.hbase.Cell cell) This method exists just to encapsulate how we serialize keys.static List<org.apache.hadoop.hbase.client.RegionInfo>MetaTableAccessor.getMergeRegions(org.apache.hadoop.hbase.Cell[] cells) Returns Deserialized regioninfo values taken from column values that match the regex 'info:merge.*' in array ofcells.MetaTableAccessor.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 ByteBufferCellUtil.getQualifierBufferShallowCopy(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static bytePrivateCellUtil.getQualifierByte(org.apache.hadoop.hbase.Cell cell, int index) static intPrivateCellUtil.getRowAsInt(org.apache.hadoop.hbase.Cell cell) Converts the rowkey bytes of the given cell into an int valuestatic byteCellUtil.getRowByte(org.apache.hadoop.hbase.Cell cell, int index) Deprecated.static bytePrivateCellUtil.getRowByte(org.apache.hadoop.hbase.Cell cell, int index) miscstatic intKeyValueUtil.getSerializedSize(org.apache.hadoop.hbase.Cell cell, boolean withTags) static org.apache.hadoop.hbase.TagCellUtil.getTag(org.apache.hadoop.hbase.Cell cell, byte type) Deprecated.As of 2.0.0 and will be removed in HBase-3.0.0 UseRawCell.getTag(byte)static Optional<org.apache.hadoop.hbase.Tag>PrivateCellUtil.getTag(org.apache.hadoop.hbase.Cell cell, byte type) Retrieve Cell's first tag, matching the passed in typestatic byte[]CellUtil.getTagArray(org.apache.hadoop.hbase.Cell cell) Deprecated.As of HBase-2.0.static List<org.apache.hadoop.hbase.Tag>CellUtil.getTags(org.apache.hadoop.hbase.Cell cell) Deprecated.As of 2.0.0 and will be removed in 3.0.0static List<org.apache.hadoop.hbase.Tag>PrivateCellUtil.getTags(org.apache.hadoop.hbase.Cell cell) Return tags in the given Cell as a Liststatic BigDecimalPrivateCellUtil.getValueAsBigDecimal(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a BigDecimalstatic doublePrivateCellUtil.getValueAsDouble(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a double valuestatic intPrivateCellUtil.getValueAsInt(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a int valuestatic longPrivateCellUtil.getValueAsLong(org.apache.hadoop.hbase.Cell cell) Converts the value bytes of the given cell into a long valuestatic ByteBufferCellUtil.getValueBufferShallowCopy(org.apache.hadoop.hbase.Cell cell) Deprecated.As of HBase-2.0.static ByteBufferPrivateCellUtil.getValueBufferShallowCopy(org.apache.hadoop.hbase.Cell cell) static booleanMetaTableAccessor.hasMergeRegions(org.apache.hadoop.hbase.Cell[] cells) Returns True if any merge regions present incells; i.e.static booleanCellUtil.isDelete(org.apache.hadoop.hbase.Cell cell) Return true if a delete type, aKeyValue.Type.Deleteor a {KeyValue.Type#DeleteFamily} or aKeyValue.Type.DeleteColumnKeyValue type.static booleanCellUtil.isDeleteColumnOrFamily(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteColumnOrFamily(org.apache.hadoop.hbase.Cell cell) Returns True if this cell is a delete family or column type.static booleanCellUtil.isDeleteColumns(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteColumns(org.apache.hadoop.hbase.Cell cell) static booleanCellUtil.isDeleteColumnVersion(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteColumnVersion(org.apache.hadoop.hbase.Cell cell) static booleanCellUtil.isDeleteFamily(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteFamily(org.apache.hadoop.hbase.Cell cell) static booleanCellUtil.isDeleteFamilyVersion(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteFamilyVersion(org.apache.hadoop.hbase.Cell cell) static booleanCellUtil.isDeleteType(org.apache.hadoop.hbase.Cell cell) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanPrivateCellUtil.isDeleteType(org.apache.hadoop.hbase.Cell cell) Returns True if this cell is aKeyValue.Type.Deletetype.static booleanCellUtil.isPut(org.apache.hadoop.hbase.Cell cell) Returns True if this cell is a Put.static intKeyValueUtil.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 booleanCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) static booleanCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingColumn(org.apache.hadoop.hbase.Cell left, byte[] fam, int foffset, int flength, byte[] qual, int qoffset, int qlength) static booleanCellUtil.matchingColumnFamilyAndQualifierPrefix(org.apache.hadoop.hbase.Cell left, byte[] fam, byte[] qual) Returns True if matching column family and the qualifier starts withqualstatic booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte lfamlength, org.apache.hadoop.hbase.Cell right, byte rfamlength) static booleanCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingFamily(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static booleanCellUtil.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 booleanCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingQualifier(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.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 booleanCellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, byte[] buf) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingRow(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static booleanCellUtil.matchingRowColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitybooleanKeyValue.KVComparator.matchingRowColumn(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compares the row and column of two keyvalues for equalitystatic booleanCellUtil.matchingRowColumnBytes(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row and column of two keyvalues for equalitystatic booleanCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.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 booleanCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares the row of two keyvalues for equalitybooleanKeyValue.KVComparator.matchingRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Deprecated.Compares the row of two keyvalues for equalitystatic booleanPrivateCellUtil.matchingRows(org.apache.hadoop.hbase.Cell left, byte[] buf, int offset, int length) static booleanCellUtil.matchingTags(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingTags(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int llength, int rlength) static booleanCellUtil.matchingTimestamp(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) static booleanCellUtil.matchingType(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) Deprecated.As of HBase-2.0.static booleanPrivateCellUtil.matchingType(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) static booleanCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, byte[] buf) static booleanCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) static booleanPrivateCellUtil.matchingValue(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right, int lvlength, int rvlength) static intKeyValueUtil.oswrite(org.apache.hadoop.hbase.Cell cell, OutputStream out, boolean withTags) static booleanPrivateCellUtil.qualifierStartsWith(org.apache.hadoop.hbase.Cell left, byte[] startsWith) Finds if the start of the qualifier part of the Cell matchesbufstatic voidCellUtil.setSequenceId(org.apache.hadoop.hbase.Cell cell, long seqId) Deprecated.As of HBase-2.0.static voidPrivateCellUtil.setSequenceId(org.apache.hadoop.hbase.Cell cell, long seqId) Sets the given seqId to the cell.static voidCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset) Deprecated.As of HBase-2.0.static voidCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts) Deprecated.As of HBase-2.0.static voidPrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell.static voidPrivateCellUtil.setTimestamp(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell.static Iterator<org.apache.hadoop.hbase.Tag>PrivateCellUtil.tagsIterator(org.apache.hadoop.hbase.Cell cell) Utility method to iterate through the tags in the given cell.static org.apache.hadoop.hbase.KeyValueKeyValueUtil.toNewKeyCell(org.apache.hadoop.hbase.Cell cell) Copies the key to a new KeyValuestatic StringCellUtil.toString(org.apache.hadoop.hbase.Cell cell, boolean verbose) Returns a string representation of the cellstatic booleanCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, byte[] ts, int tsOffset) Deprecated.As of HBase-2.0.static booleanCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, long ts) Deprecated.As of HBase-2.0.static booleanPrivateCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, byte[] ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP.static booleanPrivateCellUtil.updateLatestStamp(org.apache.hadoop.hbase.Cell cell, long ts) Sets the given timestamp to the cell iff current timestamp isHConstants.LATEST_TIMESTAMP.static intPrivateCellUtil.writeCell(org.apache.hadoop.hbase.Cell cell, OutputStream out, boolean withTags) Writes the cell to the given OutputStreamstatic voidPrivateCellUtil.writeCellToBuffer(org.apache.hadoop.hbase.Cell cell, ByteBuffer buf, int offset) Writes a cell to the buffer at the given offsetstatic voidPrivateCellUtil.writeFamily(OutputStream out, org.apache.hadoop.hbase.Cell cell, byte flength) Writes the family from the given cell to the output streamstatic voidCellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, DataOutputStream out) Deprecated.As of HBase-2.0.static voidPrivateCellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, DataOutput out) Writes the Cell's key part as it would have serialized in a KeyValue.static intPrivateCellUtil.writeFlatKey(org.apache.hadoop.hbase.Cell cell, OutputStream out) static voidPrivateCellUtil.writeQualifier(OutputStream out, org.apache.hadoop.hbase.Cell cell, int qlength) Writes the qualifier from the given cell to the output streamstatic voidPrivateCellUtil.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 voidPrivateCellUtil.writeRow(OutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength) Writes the row from the given cell to the output streamstatic voidCellUtil.writeRowKeyExcludingCommon(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out) Deprecated.As of HBase-2.0.static voidPrivateCellUtil.writeRowKeyExcludingCommon(org.apache.hadoop.hbase.Cell cell, short rLen, int commonPrefix, DataOutputStream out) Write rowkey excluding the common part.static voidCellUtil.writeRowSkippingBytes(DataOutputStream out, org.apache.hadoop.hbase.Cell cell, short rlength, int commonPrefix) Deprecated.As of 2.0.static voidPrivateCellUtil.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 prefixstatic voidPrivateCellUtil.writeTags(OutputStream out, org.apache.hadoop.hbase.Cell cell, int tagsLength) Writes the tag from the given cell to the output streamstatic voidPrivateCellUtil.writeValue(OutputStream out, org.apache.hadoop.hbase.Cell cell, int vlength) Writes the value from the given cell to the output streamMethod parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic voidCellUtil.cloneIfNecessary(ArrayList<org.apache.hadoop.hbase.Cell> cells) static booleanKeyValueTestUtil.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.CellScannerCellUtil.createCellScanner(Iterable<org.apache.hadoop.hbase.Cell> cellIterable) Returns CellScanner interface overcellIterablestatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(Iterator<org.apache.hadoop.hbase.Cell> cells) Returns CellScanner interface overcellIterableor null ifcellsis nullstatic org.apache.hadoop.hbase.CellScannerCellUtil.createCellScanner(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Flatten the map of cells out under the CellScannerstatic List<org.apache.hadoop.hbase.KeyValue>KeyValueUtil.ensureKeyValues(List<org.apache.hadoop.hbase.Cell> cells) Deprecated.static StringCellUtil.getCellKeyAsString(org.apache.hadoop.hbase.Cell cell, Function<org.apache.hadoop.hbase.Cell, String> rowConverter) Return the Key portion of the passedcellas a String.Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionKeyValue(org.apache.hadoop.hbase.Cell c)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client with type parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected NavigableMap<byte[],List<org.apache.hadoop.hbase.Cell>> Mutation.familyMapMethods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellResult.current()org.apache.hadoop.hbase.CellResult.getColumnLatestCell(byte[] family, byte[] qualifier) The Cell for the most recent timestamp for a given column.org.apache.hadoop.hbase.CellResult.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.Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier 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.Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.client.AppendAppend.add(org.apache.hadoop.hbase.Cell cell) Add column and value to this Append operation.org.apache.hadoop.hbase.client.DeleteDelete.add(org.apache.hadoop.hbase.Cell cell) Add an existing delete marker to this Delete object.org.apache.hadoop.hbase.client.IncrementIncrement.add(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this operation.org.apache.hadoop.hbase.client.PutPut.add(org.apache.hadoop.hbase.Cell cell) Add the specified KeyValue to this Put operation.org.apache.hadoop.hbase.client.DeleteDelete.addDeleteMarker(org.apache.hadoop.hbase.Cell kv) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.protected intResult.binarySearch(org.apache.hadoop.hbase.Cell[] kvs, byte[] family, byte[] qualifier) protected intResult.binarySearch(org.apache.hadoop.hbase.Cell[] kvs, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength) Searches for the latest value for the specified column.static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells) Instantiate a Result with the specified array of KeyValues.static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale) static org.apache.hadoop.hbase.client.ResultResult.create(org.apache.hadoop.hbase.Cell[] cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) Method parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.client.ResultResult.create(List<org.apache.hadoop.hbase.Cell> cells) Instantiate a Result with the specified List of KeyValues.static org.apache.hadoop.hbase.client.Resultstatic org.apache.hadoop.hbase.client.Resultstatic org.apache.hadoop.hbase.client.ResultResult.create(List<org.apache.hadoop.hbase.Cell> cells, Boolean exists, boolean stale, boolean mayHaveMoreCellsInRow) org.apache.hadoop.hbase.client.AppendAppend.setFamilyCellMap(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.DeleteDelete.setFamilyCellMap(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.IncrementIncrement.setFamilyCellMap(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.MutationMutation.setFamilyCellMap(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.client.PutPut.setFamilyCellMap(NavigableMap<byte[], List<org.apache.hadoop.hbase.Cell>> map) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionAppend(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.protectedMutation(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.codec
Fields in org.apache.hadoop.hbase.codec declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellKeyValueCodec.ByteBuffKeyValueDecoder.currentMethods in org.apache.hadoop.hbase.codec that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.CellKeyValueCodec.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len) protected org.apache.hadoop.hbase.CellKeyValueCodec.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len) protected org.apache.hadoop.hbase.CellKeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(byte[] buf, int offset, int len) protected org.apache.hadoop.hbase.CellKeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb, int pos, int len) org.apache.hadoop.hbase.CellBaseDecoder.current()org.apache.hadoop.hbase.CellKeyValueCodec.ByteBuffKeyValueDecoder.current()protected abstract org.apache.hadoop.hbase.CellBaseDecoder.parseCell()Extract a Cell.protected org.apache.hadoop.hbase.CellKeyValueCodec.KeyValueDecoder.parseCell()protected org.apache.hadoop.hbase.CellKeyValueCodecWithTags.KeyValueDecoder.parseCell()Methods in org.apache.hadoop.hbase.codec with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionabstract voidBaseEncoder.write(org.apache.hadoop.hbase.Cell cell) voidKeyValueCodec.KeyValueEncoder.write(org.apache.hadoop.hbase.Cell cell) voidKeyValueCodecWithTags.KeyValueEncoder.write(org.apache.hadoop.hbase.Cell cell)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptiondefault org.apache.hadoop.hbase.CellRegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<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.Methods in org.apache.hadoop.hbase.coprocessor that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier 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<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<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<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<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.Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionabstract TColumnInterpreter.getValue(byte[] colFamily, byte[] colQualifier, org.apache.hadoop.hbase.Cell c) Returns value of type Tdefault org.apache.hadoop.hbase.CellRegionObserver.postMutationBeforeWAL(org.apache.hadoop.hbase.coprocessor.ObserverContext<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 booleanRegionObserver.postScannerFilterRow(org.apache.hadoop.hbase.coprocessor.ObserverContext<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 voidRegionObserver.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.coprocessor.ObserverContext<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.Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type org.apache.hadoop.hbase.Cell in inModifier 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<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<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 voidRegionObserver.postGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<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<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<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 voidRegionObserver.preGetOp(org.apache.hadoop.hbase.coprocessor.ObserverContext<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
Methods in org.apache.hadoop.hbase.filter that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellFilter.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.CellFilterBase.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.CellFilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellMultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.CellTimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.CellFilter.transformCell(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed KeyValue.org.apache.hadoop.hbase.CellFilterBase.transformCell(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed KeyValue.org.apache.hadoop.hbase.CellFilterList.transformCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.CellFilterListBase.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.CellFilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellKeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellSkipFilter.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellWhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v) Methods in org.apache.hadoop.hbase.filter with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected intFilterListBase.compareCell(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) protected booleanCompareFilter.compareFamily(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareFamily(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) Deprecated.Since 2.0.0.protected booleanCompareFilter.compareQualifier(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareQualifier(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) Deprecated.Since 2.0.0.protected booleanCompareFilter.compareRow(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareRow(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) Deprecated.Since 2.0.0.protected booleanCompareFilter.compareValue(org.apache.hadoop.hbase.CompareOperator op, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) protected booleanCompareFilter.compareValue(org.apache.hadoop.hbase.filter.CompareFilter.CompareOp compareOp, org.apache.hadoop.hbase.filter.ByteArrayComparable comparator, org.apache.hadoop.hbase.Cell cell) Deprecated.Since 2.0.0.org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnCountGetFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPaginationFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnRangeFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeDependentColumnFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFamilyFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilter.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.ReturnCodeFilterList.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterListWithAND.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterListWithOR.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterWrapper.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFirstKeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFirstKeyValueMatchingQualifiersFilter.filterCell(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFuzzyRowFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeInclusiveStopFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeKeyOnlyFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultipleColumnPrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultiRowRangeFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodePageFilter.filterCell(org.apache.hadoop.hbase.Cell ignored) org.apache.hadoop.hbase.filter.Filter.ReturnCodePrefixFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeQualifierFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeRandomRowFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeRowFilter.filterCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.filter.Filter.ReturnCodeSingleColumnValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeSkipFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeTimestampsFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeValueFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeWhileMatchFilter.filterCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultipleColumnPrefixFilter.filterColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnCountGetFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPaginationFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnPrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeColumnRangeFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeDependentColumnFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFamilyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterList.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterListBase.filterKeyValue(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.filter.Filter.ReturnCodeFilterWrapper.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFirstKeyOnlyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFirstKeyValueMatchingQualifiersFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeFuzzyRowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeInclusiveStopFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeKeyOnlyFilter.filterKeyValue(org.apache.hadoop.hbase.Cell ignored) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultipleColumnPrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeMultiRowRangeFilter.filterKeyValue(org.apache.hadoop.hbase.Cell ignored) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodePageFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodePrefixFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeQualifierFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeRandomRowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeRowFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeSingleColumnValueFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeSkipFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeTimestampsFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeValueFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.org.apache.hadoop.hbase.filter.Filter.ReturnCodeWhileMatchFilter.filterKeyValue(org.apache.hadoop.hbase.Cell c) Deprecated.booleanColumnCountGetFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnPaginationFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanCompareFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) abstract booleanFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) Filters a row based on the row key.booleanFilterBase.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanFilterList.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterListWithAND.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterListWithOR.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanFilterWrapper.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanFirstKeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanInclusiveStopFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanKeyOnlyFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanMultipleColumnPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanMultiRowRangeFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanPageFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanPrefixFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanRandomRowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanRowFilter.filterRowKey(org.apache.hadoop.hbase.Cell firstRowCell) booleanSingleColumnValueFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanSkipFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanTimestampsFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) booleanWhileMatchFilter.filterRowKey(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPaginationFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellColumnRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellFilter.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.CellFilterBase.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.CellFilterList.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithAND.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterListWithOR.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFilterWrapper.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellFuzzyRowFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) org.apache.hadoop.hbase.CellMultipleColumnPrefixFilter.getNextCellHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMultiRowRangeFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentKV) org.apache.hadoop.hbase.CellTimestampsFilter.getNextCellHint(org.apache.hadoop.hbase.Cell currentCell) Pick the next cell that the scanner should seek to.abstract org.apache.hadoop.hbase.CellFilter.transformCell(org.apache.hadoop.hbase.Cell v) Give the filter a chance to transform the passed KeyValue.org.apache.hadoop.hbase.CellFilterBase.transformCell(org.apache.hadoop.hbase.Cell v) By default no transformation takes place Give the filter a chance to transform the passed KeyValue.org.apache.hadoop.hbase.CellFilterList.transformCell(org.apache.hadoop.hbase.Cell c) org.apache.hadoop.hbase.CellFilterListBase.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.CellFilterWrapper.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellKeyOnlyFilter.transformCell(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellSkipFilter.transformCell(org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellWhileMatchFilter.transformCell(org.apache.hadoop.hbase.Cell v) Method parameters in org.apache.hadoop.hbase.filter with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidDependentColumnFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) abstract voidFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) Chance to alter the list of Cells to be submitted.voidFilterBase.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.voidFilterList.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.voidFilterListBase.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.voidFilterWrapper.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) voidSingleColumnValueExcludeFilter.filterRowCells(List<org.apache.hadoop.hbase.Cell> kvs) org.apache.hadoop.hbase.filter.FilterWrapper.FilterRowRetCodeFilterWrapper.filterRowCellsWithRet(List<org.apache.hadoop.hbase.Cell> kvs)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io
Methods in org.apache.hadoop.hbase.io that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.Cell>HalfStoreFileReader.getFirstKey()Optional<org.apache.hadoop.hbase.Cell>HalfStoreFileReader.getLastKey()Optional<org.apache.hadoop.hbase.Cell>HalfStoreFileReader.midKey()Methods in org.apache.hadoop.hbase.io with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidCellOutputStream.write(org.apache.hadoop.hbase.Cell cell) Implementation must copy the entire state of the Cell. - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.encoding
Fields in org.apache.hadoop.hbase.io.encoding declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellEncodingState.prevCellThe previous Cell the encoder encoded.Methods in org.apache.hadoop.hbase.io.encoding that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected org.apache.hadoop.hbase.CellAbstractDataBlockEncoder.createFirstKeyCell(ByteBuffer key, int keyLength) org.apache.hadoop.hbase.CellDataBlockEncoder.EncodedSeeker.getCell()Returns the Cell at the current position.org.apache.hadoop.hbase.CellRowIndexSeekerV1.getCell()org.apache.hadoop.hbase.CellCopyKeyDataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.CellDataBlockEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) Return first key in block as a cell.org.apache.hadoop.hbase.CellDiffKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.CellFastDiffDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.CellPrefixKeyDeltaEncoder.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.CellRowIndexCodecV1.getFirstKeyCellInBlock(org.apache.hadoop.hbase.nio.ByteBuff block) org.apache.hadoop.hbase.CellDataBlockEncoder.EncodedSeeker.getKey()From the current position creates a cell using the key part of the current bufferorg.apache.hadoop.hbase.CellRowIndexSeekerV1.getKey()Methods in org.apache.hadoop.hbase.io.encoding that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionIterator<org.apache.hadoop.hbase.Cell>EncodedDataBlock.getIterator(int headerSize) Provides access to compressed value.Methods in org.apache.hadoop.hbase.io.encoding with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected booleanRowIndexEncoderV1.checkRow(org.apache.hadoop.hbase.Cell cell) intDataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key) Compare the given key against the current keyintRowIndexSeekerV1.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key) voidDataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.voidRowIndexCodecV1.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) intCopyKeyDataBlockEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intDiffKeyDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intFastDiffDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intPrefixKeyDeltaEncoder.internalEncode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockDefaultEncodingContext encodingContext, DataOutputStream out) intDataBlockEncoder.EncodedSeeker.seekToKeyInBlock(org.apache.hadoop.hbase.Cell key, boolean seekBefore) Moves the seeker position within the current block to: the last key that that is less than or equal to the given key ifseekBeforeis false the last key that is strictly less than the given key ifseekBeforeis true.intRowIndexSeekerV1.seekToKeyInBlock(org.apache.hadoop.hbase.Cell seekCell, boolean seekBefore) intNoneEncoder.write(org.apache.hadoop.hbase.Cell cell) voidRowIndexEncoderV1.write(org.apache.hadoop.hbase.Cell cell)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.io.hfile
Fields in org.apache.hadoop.hbase.io.hfile declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellHFileWriterImpl.firstCellInBlockFirst cell in a block.protected org.apache.hadoop.hbase.CellHFileWriterImpl.lastCellThe Cell previously appended.protected org.apache.hadoop.hbase.CellHFileReaderImpl.HFileScannerImpl.nextIndexedKeyThe next indexed key is to keep track of the indexed key of the next data block.Methods in org.apache.hadoop.hbase.io.hfile that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellHFileReaderImpl.EncodedScanner.getCell()org.apache.hadoop.hbase.CellHFileReaderImpl.HFileScannerImpl.getCell()org.apache.hadoop.hbase.CellHFileScanner.getCell()Returns Instance ofCell.protected org.apache.hadoop.hbase.CellHFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) protected org.apache.hadoop.hbase.CellHFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(org.apache.hadoop.hbase.io.hfile.HFileBlock curBlock) org.apache.hadoop.hbase.CellHFileReaderImpl.EncodedScanner.getKey()org.apache.hadoop.hbase.CellHFileReaderImpl.HFileScannerImpl.getKey()org.apache.hadoop.hbase.CellHFileScanner.getKey()Gets the current key in the form of a cell.org.apache.hadoop.hbase.CellHFileWriterImpl.getLastCell()org.apache.hadoop.hbase.CellHFileInfo.getLastKeyCell()static org.apache.hadoop.hbase.CellHFileWriterImpl.getMidpoint(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Try to return a Cell that falls betweenleftandrightbut that is shorter; i.e.org.apache.hadoop.hbase.CellBlockWithScanInfo.getNextIndexedKey()org.apache.hadoop.hbase.CellHFileReaderImpl.HFileScannerImpl.getNextIndexedKey()org.apache.hadoop.hbase.CellHFileScanner.getNextIndexedKey()Returns the next key in the index (the key to seek to the next block)org.apache.hadoop.hbase.CellCompoundBloomFilterWriter.getPrevCell()org.apache.hadoop.hbase.CellHFileIndexBlockEncoder.EncodedSeeker.getRootBlockKey(int i) org.apache.hadoop.hbase.CellNoOpIndexBlockEncoder.NoOpEncodedSeeker.getRootBlockKey(int i) org.apache.hadoop.hbase.CellHFileIndexBlockEncoder.EncodedSeeker.midkey(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) org.apache.hadoop.hbase.CellNoOpIndexBlockEncoder.NoOpEncodedSeeker.midkey(org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) Methods in org.apache.hadoop.hbase.io.hfile that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionOptional<org.apache.hadoop.hbase.Cell>HFile.Reader.getFirstKey()Optional<org.apache.hadoop.hbase.Cell>HFileReaderImpl.getFirstKey()Optional<org.apache.hadoop.hbase.Cell>HFile.Reader.getLastKey()Optional<org.apache.hadoop.hbase.Cell>HFileReaderImpl.getLastKey()Optional<org.apache.hadoop.hbase.Cell>HFile.Reader.midKey()Optional<org.apache.hadoop.hbase.Cell>HFileReaderImpl.midKey()Methods in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidCompoundBloomFilterWriter.append(org.apache.hadoop.hbase.Cell cell) voidHFileWriterImpl.append(org.apache.hadoop.hbase.Cell cell) Add key/value to file.protected intHFileReaderImpl.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 booleanHFileWriterImpl.checkKey(org.apache.hadoop.hbase.Cell cell) Checks that the given Cell's key does not violate the key order.intHFileReaderImpl.EncodedScanner.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key) intHFileReaderImpl.HFileScannerImpl.compareKey(CellComparator comparator, org.apache.hadoop.hbase.Cell key) booleanCompoundBloomFilter.contains(org.apache.hadoop.hbase.Cell keyCell, org.apache.hadoop.hbase.nio.ByteBuff bloom, org.apache.hadoop.hbase.regionserver.BloomType type) voidHFileDataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) Encodes a KeyValue.voidHFileDataBlockEncoderImpl.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) voidNoOpDataBlockEncoder.encode(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.io.encoding.HFileBlockEncodingContext encodingCtx, DataOutputStream out) static org.apache.hadoop.hbase.CellHFileWriterImpl.getMidpoint(CellComparator comparator, org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Try to return a Cell that falls betweenleftandrightbut that is shorter; i.e.protected intHFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.Cell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.Cell key, boolean seekBefore) protected intHFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey(org.apache.hadoop.hbase.io.hfile.HFileBlock seekToBlock, org.apache.hadoop.hbase.Cell nextIndexedKey, boolean rewind, org.apache.hadoop.hbase.Cell key, boolean seekBefore) org.apache.hadoop.hbase.io.hfile.BlockWithScanInfoHFileIndexBlockEncoder.EncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.Cell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) org.apache.hadoop.hbase.io.hfile.BlockWithScanInfoNoOpIndexBlockEncoder.NoOpEncodedSeeker.loadDataBlockWithScanInfo(org.apache.hadoop.hbase.Cell key, org.apache.hadoop.hbase.io.hfile.HFileBlock currentBlock, boolean cacheBlocks, boolean pread, boolean isCompaction, org.apache.hadoop.hbase.io.encoding.DataBlockEncoding expectedDataBlockEncoding, org.apache.hadoop.hbase.io.hfile.HFile.CachingBlockReader cachingBlockReader) intHFileReaderImpl.HFileScannerImpl.reseekTo(org.apache.hadoop.hbase.Cell key) intHFileScanner.reseekTo(org.apache.hadoop.hbase.Cell cell) Reseek to or just before the passedcell.intHFileIndexBlockEncoder.EncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key) intNoOpIndexBlockEncoder.NoOpEncodedSeeker.rootBlockContainingKey(org.apache.hadoop.hbase.Cell key) booleanHFileReaderImpl.HFileScannerImpl.seekBefore(org.apache.hadoop.hbase.Cell key) booleanHFileScanner.seekBefore(org.apache.hadoop.hbase.Cell cell) Consider the cell stream of all the cells in the file,c[0] ..intHFileReaderImpl.HFileScannerImpl.seekTo(org.apache.hadoop.hbase.Cell key) intHFileReaderImpl.HFileScannerImpl.seekTo(org.apache.hadoop.hbase.Cell key, boolean rewind) An internal API function.intHFileScanner.seekTo(org.apache.hadoop.hbase.Cell cell) SeekTo or just before the passedcell.Constructors in org.apache.hadoop.hbase.io.hfile with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionBlockWithScanInfo(org.apache.hadoop.hbase.io.hfile.HFileBlock hFileBlock, org.apache.hadoop.hbase.Cell nextIndexedKey)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mapreduce
Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellCreator.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.CellCellCreator.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.CellCellCreator.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) static org.apache.hadoop.hbase.CellImport.filterKv(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.Cell c) Attempt to filter out the keyvalueMethods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier 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) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected voidImport.Importer.addPutToKv(org.apache.hadoop.hbase.client.Put put, org.apache.hadoop.hbase.Cell kv) org.apache.hadoop.hbase.KeyValueCellSerialization.CellDeserializer.deserialize(org.apache.hadoop.hbase.Cell ignore) protected booleanWALPlayer.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) static org.apache.hadoop.hbase.CellImport.filterKv(org.apache.hadoop.hbase.filter.Filter filter, org.apache.hadoop.hbase.Cell c) Attempt to filter out the keyvalueintImport.CellWritableComparablePartitioner.getPartition(org.apache.hadoop.hbase.mapreduce.Import.CellWritableComparable key, org.apache.hadoop.hbase.Cell value, int numPartitions) voidCellSerialization.CellSerializer.serialize(org.apache.hadoop.hbase.Cell kv) Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.mapreduce.CellSerialization.CellDeserializerCellSerialization.getDeserializer(Class<org.apache.hadoop.hbase.Cell> t) org.apache.hadoop.hbase.mapreduce.CellSerialization.CellSerializerCellSerialization.getSerializer(Class<org.apache.hadoop.hbase.Cell> c) protected voidCellSortReducer.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 voidImport.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) Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellWritableComparable(org.apache.hadoop.hbase.Cell kv)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.CellMobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, byte[] refCellTags) static org.apache.hadoop.hbase.CellMobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag) Creates a mob reference KeyValue.org.apache.hadoop.hbase.CellMobCell.getCell()Methods in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.CellMobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, byte[] refCellTags) static org.apache.hadoop.hbase.CellMobUtils.createMobRefCell(org.apache.hadoop.hbase.Cell cell, byte[] fileName, org.apache.hadoop.hbase.Tag tableNameTag) Creates a mob reference KeyValue.static StringMobUtils.getMobFileName(org.apache.hadoop.hbase.Cell cell) Gets the mob file name from the mob ref cell.static intMobUtils.getMobValueLength(org.apache.hadoop.hbase.Cell cell) Gets the mob value length from the mob ref cell.static Optional<org.apache.hadoop.hbase.TableName>MobUtils.getTableName(org.apache.hadoop.hbase.Cell cell) Get the table name from when this cell was written into a mob hfile as a TableName.MobUtils.getTableNameString(org.apache.hadoop.hbase.Cell cell) Gets the table name from when this cell was written into a mob hfile as a string.static booleanMobUtils.hasValidMobRefCellValue(org.apache.hadoop.hbase.Cell cell) Indicates whether the current mob ref cell has a valid value.static booleanMobUtils.isMobReferenceCell(org.apache.hadoop.hbase.Cell cell) Whether the current cell is a mob reference cell.org.apache.hadoop.hbase.mob.MobCellMobFile.readCell(org.apache.hadoop.hbase.Cell search, boolean cacheMobBlocks) Reads a cell from the mob file.org.apache.hadoop.hbase.mob.MobCellMobFile.readCell(org.apache.hadoop.hbase.Cell search, boolean cacheMobBlocks, long readPt) Reads a cell from the mob file.Constructors in org.apache.hadoop.hbase.mob with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionMobCell(org.apache.hadoop.hbase.Cell cell) MobCell(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.StoreFileScanner sfScanner)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.quotas
Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected static StringQuotaTableUtil.extractSnapshotNameFromSizeCell(org.apache.hadoop.hbase.Cell c)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver
Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offsetclassorg.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValueByteBuffer based cell which has the chunkid at the 0th offset and with no tagsFields in org.apache.hadoop.hbase.regionserver declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellSegmentScanner.currentstatic final org.apache.hadoop.hbase.CellKeyValueScanner.NO_NEXT_INDEXED_KEYThe byte array represents for NO_NEXT_INDEXED_KEY; The actual value is irrelevant because this is always compared by reference.Fields in org.apache.hadoop.hbase.regionserver with type parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected Iterator<org.apache.hadoop.hbase.Cell>SegmentScanner.iterMethods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellCellSet.ceiling(org.apache.hadoop.hbase.Cell e) org.apache.hadoop.hbase.CellCellFlatMap.ceilingKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellImmutableMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.CellMemStoreLABImpl.copyCellInto(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellCellSet.first()org.apache.hadoop.hbase.CellCellFlatMap.firstKey()org.apache.hadoop.hbase.CellCellSet.floor(org.apache.hadoop.hbase.Cell e) org.apache.hadoop.hbase.CellCellFlatMap.floorKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellImmutableMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) The process of merging assumes all cells are allocated on mslab.org.apache.hadoop.hbase.CellMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.CellMemStoreLABImpl.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.org.apache.hadoop.hbase.CellCellFlatMap.get(Object o) org.apache.hadoop.hbase.CellCellSet.get(org.apache.hadoop.hbase.Cell kv) protected org.apache.hadoop.hbase.CellCellArrayMap.getCell(int i) protected org.apache.hadoop.hbase.CellCellChunkMap.getCell(int i) protected abstract org.apache.hadoop.hbase.CellCellFlatMap.getCell(int i) protected org.apache.hadoop.hbase.CellAbstractMemStore.getLowest(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) org.apache.hadoop.hbase.CellKeyValueHeap.getNextIndexedKey()org.apache.hadoop.hbase.CellKeyValueScanner.getNextIndexedKey()org.apache.hadoop.hbase.CellNonLazyKeyValueScanner.getNextIndexedKey()org.apache.hadoop.hbase.CellSegmentScanner.getNextIndexedKey()org.apache.hadoop.hbase.CellStoreFileScanner.getNextIndexedKey()org.apache.hadoop.hbase.CellStoreScanner.getNextIndexedKey()protected org.apache.hadoop.hbase.CellAbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set) org.apache.hadoop.hbase.CellCellSet.higher(org.apache.hadoop.hbase.Cell e) org.apache.hadoop.hbase.CellCellFlatMap.higherKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCellSet.last()org.apache.hadoop.hbase.CellCompositeImmutableSegment.last()org.apache.hadoop.hbase.CellSegment.last()org.apache.hadoop.hbase.CellCellFlatMap.lastKey()org.apache.hadoop.hbase.CellCellSet.lower(org.apache.hadoop.hbase.Cell e) org.apache.hadoop.hbase.CellCellFlatMap.lowerKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCompositeImmutableSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returnedorg.apache.hadoop.hbase.CellSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.org.apache.hadoop.hbase.CellKeyValueHeap.next()org.apache.hadoop.hbase.CellKeyValueScanner.next()Return the next Cell in this scanner, iterating the scannerorg.apache.hadoop.hbase.CellMemStoreCompactorSegmentsIterator.next()org.apache.hadoop.hbase.CellMemStoreMergerSegmentsIterator.next()org.apache.hadoop.hbase.CellReversedKeyValueHeap.next()org.apache.hadoop.hbase.CellSegmentScanner.next()Return the next Cell in this scanner, iterating the scannerorg.apache.hadoop.hbase.CellSnapshotSegmentScanner.next()org.apache.hadoop.hbase.CellStoreFileScanner.next()org.apache.hadoop.hbase.CellKeyValueHeap.peek()org.apache.hadoop.hbase.CellKeyValueScanner.peek()Look at the next Cell in this scanner, but do not iterate scanner.org.apache.hadoop.hbase.CellSegmentScanner.peek()Look at the next Cell in this scanner, but do not iterate the scannerorg.apache.hadoop.hbase.CellSnapshotSegmentScanner.peek()org.apache.hadoop.hbase.CellStoreFileScanner.peek()org.apache.hadoop.hbase.CellStoreScanner.peek()org.apache.hadoop.hbase.CellCellSet.pollFirst()org.apache.hadoop.hbase.CellCellSet.pollLast()org.apache.hadoop.hbase.CellCellFlatMap.put(org.apache.hadoop.hbase.Cell k, org.apache.hadoop.hbase.Cell v) org.apache.hadoop.hbase.CellCellFlatMap.remove(Object o) Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionMap.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k) Comparator<? super org.apache.hadoop.hbase.Cell>CellFlatMap.comparator()Comparator<? super org.apache.hadoop.hbase.Cell>CellSet.comparator()Iterator<org.apache.hadoop.hbase.Cell>CellSet.descendingIterator()NavigableSet<org.apache.hadoop.hbase.Cell>CellFlatMap.descendingKeySet()NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.descendingMap()NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.descendingMap()NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.descendingSet()CellFlatMap.entrySet()CellFlatMap.entrySet()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.firstEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.firstEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k) List<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.Optional<org.apache.hadoop.hbase.Cell>HStoreFile.getFirstKey()Optional<org.apache.hadoop.hbase.Cell>StoreFile.getFirstKey()Get the first key in this store file.Optional<org.apache.hadoop.hbase.Cell>StoreFileReader.getFirstKey()protected Iterator<org.apache.hadoop.hbase.Cell>SegmentScanner.getIterator(org.apache.hadoop.hbase.Cell cell) Optional<org.apache.hadoop.hbase.Cell>HStoreFile.getLastKey()Optional<org.apache.hadoop.hbase.Cell>StoreFile.getLastKey()Get the last key in this store file.Optional<org.apache.hadoop.hbase.Cell>StoreFileReader.getLastKey()NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.headSet(org.apache.hadoop.hbase.Cell toElement) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.headSet(org.apache.hadoop.hbase.Cell toElement, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CompositeImmutableSegment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow) SortedSet<org.apache.hadoop.hbase.Cell>Segment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k) Iterator<org.apache.hadoop.hbase.Cell>CellSet.iterator()Iterator<org.apache.hadoop.hbase.Cell>CompositeImmutableSegment.iterator()Iterator<org.apache.hadoop.hbase.Cell>Segment.iterator()NavigableSet<org.apache.hadoop.hbase.Cell>CellFlatMap.keySet()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.lastEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.lastEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k) Optional<org.apache.hadoop.hbase.Cell>StoreFileReader.midKey()NavigableSet<org.apache.hadoop.hbase.Cell>CellFlatMap.navigableKeySet()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.pollFirstEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.pollFirstEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.pollLastEntry()Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.pollLastEntry()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) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, org.apache.hadoop.hbase.Cell toElement) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement, boolean inclusive) protected SortedSet<org.apache.hadoop.hbase.Cell>CompositeImmutableSegment.tailSet(org.apache.hadoop.hbase.Cell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<org.apache.hadoop.hbase.Cell>Segment.tailSet(org.apache.hadoop.hbase.Cell firstCell) Returns a subset of the segment cell set, which starts with the given cellCollection<org.apache.hadoop.hbase.Cell>CellFlatMap.values()Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidAbstractMemStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) booleanCellSet.add(org.apache.hadoop.hbase.Cell e) voidHStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds a value to the memstorevoidMemStore.add(org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Write an updatevoidMutableSegment.add(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Adds the given cell into the segmentvoidCellSink.append(org.apache.hadoop.hbase.Cell cell) Append the given cellvoidDateTieredMultiFileWriter.append(org.apache.hadoop.hbase.Cell cell) voidStoreFileWriter.append(org.apache.hadoop.hbase.Cell cell) voidStripeMultiFileWriter.BoundaryMultiWriter.append(org.apache.hadoop.hbase.Cell cell) voidStripeMultiFileWriter.SizeMultiWriter.append(org.apache.hadoop.hbase.Cell cell) booleanKeyValueScanner.backwardSeek(org.apache.hadoop.hbase.Cell key) Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValuebooleanNonReversedNonLazyKeyValueScanner.backwardSeek(org.apache.hadoop.hbase.Cell key) booleanReversedKeyValueHeap.backwardSeek(org.apache.hadoop.hbase.Cell seekKey) booleanReversedStoreScanner.backwardSeek(org.apache.hadoop.hbase.Cell key) booleanSegmentScanner.backwardSeek(org.apache.hadoop.hbase.Cell key) Seek the scanner at or before the row of specified Cell, it firstly tries to seek the scanner at or after the specified Cell, return if peek KeyValue of scanner has the same row with specified Cell, otherwise seek the scanner at the first Cell of the row which is the previous row of specified KeyValuebooleanStoreFileScanner.backwardSeek(org.apache.hadoop.hbase.Cell key) org.apache.hadoop.hbase.CellCellSet.ceiling(org.apache.hadoop.hbase.Cell e) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.ceilingEntry(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCellFlatMap.ceilingKey(org.apache.hadoop.hbase.Cell k) protected booleanCompactingMemStore.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 voidReversedStoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) protected voidStoreScanner.checkScanOrder(org.apache.hadoop.hbase.Cell prevKV, org.apache.hadoop.hbase.Cell kv, CellComparator comparator) Check whether scan as expected orderintCompositeImmutableSegment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intKeyValueHeap.KVScannerComparator.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) Compares two KeyValueintSegment.compare(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intCompositeImmutableSegment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) intSegment.compareRows(org.apache.hadoop.hbase.Cell left, org.apache.hadoop.hbase.Cell right) org.apache.hadoop.hbase.CellImmutableMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellMemStoreLAB.copyCellInto(org.apache.hadoop.hbase.Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.CellMemStoreLABImpl.copyCellInto(org.apache.hadoop.hbase.Cell cell) protected voidAbstractMemStore.doAdd(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) static booleanNonLazyKeyValueScanner.doRealSeek(org.apache.hadoop.hbase.regionserver.KeyValueScanner scanner, org.apache.hadoop.hbase.Cell kv, boolean forward) org.apache.hadoop.hbase.CellCellSet.floor(org.apache.hadoop.hbase.Cell e) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.floorEntry(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCellFlatMap.floorKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellImmutableMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) The process of merging assumes all cells are allocated on mslab.org.apache.hadoop.hbase.CellMemStoreLAB.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) Allocates slice in this LAB and copy the passed Cell into this area.org.apache.hadoop.hbase.CellMemStoreLABImpl.forceCopyOfBigCellInto(org.apache.hadoop.hbase.Cell cell) When a cell's size is too big (bigger than maxAlloc), copyCellInto does not allocate it on MSLAB.org.apache.hadoop.hbase.CellCellSet.get(org.apache.hadoop.hbase.Cell kv) protected Iterator<org.apache.hadoop.hbase.Cell>SegmentScanner.getIterator(org.apache.hadoop.hbase.Cell cell) protected org.apache.hadoop.hbase.CellAbstractMemStore.getLowest(org.apache.hadoop.hbase.Cell a, org.apache.hadoop.hbase.Cell b) protected org.apache.hadoop.hbase.CellAbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.headMap(org.apache.hadoop.hbase.Cell toKey, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.headSet(org.apache.hadoop.hbase.Cell toElement) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.headSet(org.apache.hadoop.hbase.Cell toElement, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CompositeImmutableSegment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow) SortedSet<org.apache.hadoop.hbase.Cell>Segment.headSet(org.apache.hadoop.hbase.Cell firstKeyOnRow) protected longSegment.heapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated) org.apache.hadoop.hbase.CellCellSet.higher(org.apache.hadoop.hbase.Cell e) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.higherEntry(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCellFlatMap.higherKey(org.apache.hadoop.hbase.Cell k) voidTimeRangeTracker.includeTimestamp(org.apache.hadoop.hbase.Cell cell) Update the current TimestampRange to include the timestamp fromcell.protected voidCompositeImmutableSegment.internalAdd(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.internalAdd(org.apache.hadoop.hbase.Cell cell, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) org.apache.hadoop.hbase.CellCellSet.lower(org.apache.hadoop.hbase.Cell e) Map.Entry<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.lowerEntry(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCellFlatMap.lowerKey(org.apache.hadoop.hbase.Cell k) org.apache.hadoop.hbase.CellCompositeImmutableSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returnedorg.apache.hadoop.hbase.CellSegment.maybeCloneWithAllocator(org.apache.hadoop.hbase.Cell cell, boolean forceCloneOfBigCell) If the segment has a memory allocator the cell is being cloned to this space, and returned; otherwise the given cell is returned When a cell's size is too big (bigger than maxAlloc), it is not allocated on MSLAB.protected longSegment.offHeapSizeChange(org.apache.hadoop.hbase.Cell cell, boolean allocated) booleanStoreFileReader.passesGeneralRowColBloomFilter(org.apache.hadoop.hbase.Cell cell) A method for checking Bloom filters.booleanRegionCoprocessorHost.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.booleanRegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(org.apache.hadoop.hbase.client.Mutation mutation, org.apache.hadoop.hbase.Cell kv, byte[] byteNow, org.apache.hadoop.hbase.client.Get get) Deprecated.In hbase-2.0.0.protected abstract booleanAbstractMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the updateprotected booleanCompactingMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Issue any synchronization and test needed before applying the update For compacting memstore this means checking the update can increase the size without overflowprotected booleanDefaultMemStore.preUpdate(org.apache.hadoop.hbase.regionserver.MutableSegment currentActive, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) org.apache.hadoop.hbase.CellCellFlatMap.put(org.apache.hadoop.hbase.Cell k, org.apache.hadoop.hbase.Cell v) booleanKeyValueHeap.requestSeek(org.apache.hadoop.hbase.Cell key, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.Cell)(orKeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.booleanKeyValueScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom) Similar toKeyValueScanner.seek(org.apache.hadoop.hbase.Cell)(orKeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)if forward is true) but only does a seek operation after checking that it is really necessary for the row/column combination specified by the kv parameter.booleanNonLazyKeyValueScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom) booleanReversedKeyValueHeap.requestSeek(org.apache.hadoop.hbase.Cell key, boolean forward, boolean useBloom) booleanSegmentScanner.requestSeek(org.apache.hadoop.hbase.Cell c, boolean forward, boolean useBloom) booleanStoreFileScanner.requestSeek(org.apache.hadoop.hbase.Cell kv, boolean forward, boolean useBloom) Pretend we have done a seek but don't do it yet, if possible.booleanKeyValueHeap.reseek(org.apache.hadoop.hbase.Cell seekKey) This function is identical to theKeyValueHeap.seek(Cell)function except that scanner.seek(seekKey) is changed to scanner.reseek(seekKey).booleanKeyValueScanner.reseek(org.apache.hadoop.hbase.Cell key) Reseek the scanner at or after the specified KeyValue.booleanReversedKeyValueHeap.reseek(org.apache.hadoop.hbase.Cell seekKey) booleanReversedStoreScanner.reseek(org.apache.hadoop.hbase.Cell kv) booleanSegmentScanner.reseek(org.apache.hadoop.hbase.Cell cell) Reseek the scanner at or after the specified KeyValue.booleanSnapshotSegmentScanner.reseek(org.apache.hadoop.hbase.Cell seekCell) booleanStoreFileScanner.reseek(org.apache.hadoop.hbase.Cell key) booleanStoreScanner.reseek(org.apache.hadoop.hbase.Cell kv) org.apache.hadoop.hbase.mob.MobCellHMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks) Reads the cell from the mob file, and the read point does not count.org.apache.hadoop.hbase.mob.MobCellHMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file with readEmptyValueOnMobCellMissorg.apache.hadoop.hbase.mob.MobCellHMobStore.resolve(org.apache.hadoop.hbase.Cell reference, boolean cacheBlocks, long readPt, boolean readEmptyValueOnMobCellMiss) Reads the cell from the mob file.protected voidHRegion.restoreEdit(org.apache.hadoop.hbase.regionserver.HStore s, org.apache.hadoop.hbase.Cell cell, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreAccounting) Used by testsprotected voidStripeMultiFileWriter.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 voidStripeMultiFileWriter.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.booleanKeyValueHeap.seek(org.apache.hadoop.hbase.Cell seekKey) Seeks all scanners at or below the specified seek key.booleanKeyValueScanner.seek(org.apache.hadoop.hbase.Cell key) Seek the scanner at or after the specified KeyValue.booleanReversedKeyValueHeap.seek(org.apache.hadoop.hbase.Cell seekKey) booleanReversedStoreScanner.seek(org.apache.hadoop.hbase.Cell key) booleanSegmentScanner.seek(org.apache.hadoop.hbase.Cell cell) Seek the scanner at or after the specified Cell.booleanSnapshotSegmentScanner.seek(org.apache.hadoop.hbase.Cell seekCell) booleanStoreFileScanner.seek(org.apache.hadoop.hbase.Cell key) booleanStoreScanner.seek(org.apache.hadoop.hbase.Cell key) protected booleanReversedStoreScanner.seekAsDirection(org.apache.hadoop.hbase.Cell kv) Do a backwardSeek in a reversed StoreScanner(scan backward)protected booleanStoreScanner.seekAsDirection(org.apache.hadoop.hbase.Cell kv) Do a reseek in a normal StoreScanner(scan forward)static booleanStoreFileScanner.seekAtOrAfter(org.apache.hadoop.hbase.io.hfile.HFileScanner s, org.apache.hadoop.hbase.Cell k) Returns false if not found or if k is after the end.protected voidReversedStoreScanner.seekScanners(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.Cell seekKey, boolean isLazy, boolean isParallelSeek) protected voidStoreScanner.seekScanners(List<? extends org.apache.hadoop.hbase.regionserver.KeyValueScanner> scanners, org.apache.hadoop.hbase.Cell seekKey, boolean isLazy, boolean isParallelSeek) Seek the specified scanners with the given keyprotected booleanReversedStoreScanner.seekToNextRow(org.apache.hadoop.hbase.Cell kv) protected booleanStoreScanner.seekToNextRow(org.apache.hadoop.hbase.Cell c) booleanKeyValueScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key) Seek the scanner at the first Cell of the row which is the previous row of specified keybooleanNonReversedNonLazyKeyValueScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key) booleanReversedKeyValueHeap.seekToPreviousRow(org.apache.hadoop.hbase.Cell seekKey) booleanReversedStoreScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell key) booleanSegmentScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell cell) Seek the scanner at the first Cell of the row which is the previous row of specified keybooleanStoreFileScanner.seekToPreviousRow(org.apache.hadoop.hbase.Cell originalKey) protected voidStoreFileScanner.setCurrentCell(org.apache.hadoop.hbase.Cell newVal) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell fromKey, boolean fromInclusive, org.apache.hadoop.hbase.Cell toKey, boolean toInclusive) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.subMap(org.apache.hadoop.hbase.Cell k1, org.apache.hadoop.hbase.Cell k2) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, boolean fromInclusive, org.apache.hadoop.hbase.Cell toElement, boolean toInclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.subSet(org.apache.hadoop.hbase.Cell fromElement, org.apache.hadoop.hbase.Cell toElement) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell k) NavigableMap<org.apache.hadoop.hbase.Cell,org.apache.hadoop.hbase.Cell> CellFlatMap.tailMap(org.apache.hadoop.hbase.Cell fromKey, boolean inclusive) SortedSet<org.apache.hadoop.hbase.Cell>CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement) NavigableSet<org.apache.hadoop.hbase.Cell>CellSet.tailSet(org.apache.hadoop.hbase.Cell fromElement, boolean inclusive) protected SortedSet<org.apache.hadoop.hbase.Cell>CompositeImmutableSegment.tailSet(org.apache.hadoop.hbase.Cell firstCell) Returns a subset of the segment cell set, which starts with the given cellprotected SortedSet<org.apache.hadoop.hbase.Cell>Segment.tailSet(org.apache.hadoop.hbase.Cell firstCell) Returns a subset of the segment cell set, which starts with the given cellvoidStoreFileWriter.trackTimestamps(org.apache.hadoop.hbase.Cell cell) Record the earlest Put timestamp.protected booleanStoreScanner.trySkipToNextColumn(org.apache.hadoop.hbase.Cell cell) SeeStoreScanner.trySkipToNextRow(Cell)protected booleanStoreScanner.trySkipToNextRow(org.apache.hadoop.hbase.Cell cell) See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).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.protected voidCompositeImmutableSegment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, boolean mslabUsed, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing, boolean sizeAddedPreOperation) protected voidSegment.updateMetaInfo(org.apache.hadoop.hbase.Cell cellToAdd, boolean succ, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) voidMutableSegment.upsert(org.apache.hadoop.hbase.Cell cell, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memStoreSizing, boolean sizeAddedPreOperation) Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidAbstractMemStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) voidHStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds the specified value to the memstorevoidMemStore.add(Iterable<org.apache.hadoop.hbase.Cell> cells, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Write the updatesbooleanCellSet.addAll(Collection<? extends org.apache.hadoop.hbase.Cell> c) voidCheck the collection of families for valid timestampsprotected org.apache.hadoop.hbase.CellAbstractMemStore.getNextRow(org.apache.hadoop.hbase.Cell key, NavigableSet<org.apache.hadoop.hbase.Cell> set) default booleanInternalScanner.next(List<org.apache.hadoop.hbase.Cell> result) Grab the next row's worth of values.booleanInternalScanner.next(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Grab the next row's worth of values.booleanKeyValueHeap.next(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Gets the next row of keys from the top-most scanner.booleanMobStoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx) Firstly reads the cells from the HBase.booleanReversedMobStoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext ctx) Firstly reads the cells from the HBase.booleanStoreScanner.next(List<org.apache.hadoop.hbase.Cell> outResult, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Get the next row of values from this Store.booleanRegionScanner.nextRaw(List<org.apache.hadoop.hbase.Cell> result) Grab the next row's worth of values.booleanRegionScanner.nextRaw(List<org.apache.hadoop.hbase.Cell> result, org.apache.hadoop.hbase.regionserver.ScannerContext scannerContext) Grab the next row's worth of values.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) voidRegionCoprocessorHost.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) booleanRegionCoprocessorHost.preGet(org.apache.hadoop.hbase.client.Get get, List<org.apache.hadoop.hbase.Cell> results) Supports Coprocessor 'bypass'.voidCellFlatMap.putAll(Map<? extends org.apache.hadoop.hbase.Cell, ? extends org.apache.hadoop.hbase.Cell> map) voidCellFlatMap.putAll(Map<? extends org.apache.hadoop.hbase.Cell, ? extends org.apache.hadoop.hbase.Cell> map) voidAbstractMemStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) voidHStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Adds or replaces the specified KeyValues.voidMemStore.upsert(Iterable<org.apache.hadoop.hbase.Cell> cells, long readpoint, org.apache.hadoop.hbase.regionserver.MemStoreSizing memstoreSizing) Update or insert the specified cells.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellArrayMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.Cell[] b, int min, int max, boolean descending) Constructor parameters in org.apache.hadoop.hbase.regionserver with type arguments of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellArrayMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.Cell[] b, int min, int max, boolean descending) CellChunkMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, org.apache.hadoop.hbase.regionserver.Chunk[] chunks, int min, int max, boolean descending) C-tor for creating CellChunkMap from existing Chunk array, which must be ordered (decreasingly or increasingly according to parameter "descending")CellFlatMap(Comparator<? super org.apache.hadoop.hbase.Cell> comparator, int min, int max, boolean d)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.querymatcher
Fields in org.apache.hadoop.hbase.regionserver.querymatcher declared as org.apache.hadoop.hbase.Cell in inModifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.CellScanQueryMatcher.currentRowRow the query is onprotected org.apache.hadoop.hbase.CellScanDeleteTracker.deleteCellprotected final org.apache.hadoop.hbase.CellScanQueryMatcher.startKeyKey to seek to in memstore and StoreFilesMethods in org.apache.hadoop.hbase.regionserver.querymatcher that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionprotected static org.apache.hadoop.hbase.CellScanQueryMatcher.createStartKeyFromRow(byte[] startRow, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo) org.apache.hadoop.hbase.CellScanQueryMatcher.currentRow()Returns a cell represent the current roworg.apache.hadoop.hbase.CellScanQueryMatcher.getKeyForNextColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellCompactionScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) Delegate toFilter.getNextCellHint(Cell).org.apache.hadoop.hbase.CellUserScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScanQueryMatcher.getStartKey()Returns the start keyMethods in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidDeleteTracker.add(org.apache.hadoop.hbase.Cell cell) Add the specified cell to the list of deletes to check against for this row operation.voidNewVersionBehaviorTracker.add(org.apache.hadoop.hbase.Cell cell) voidScanDeleteTracker.add(org.apache.hadoop.hbase.Cell cell) Add the specified Cell to the list of deletes to check against for this row operation.voidNewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeExplicitColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeNewVersionBehaviorTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanWildcardColumnTracker.checkColumn(org.apache.hadoop.hbase.Cell cell, byte type) Checks if the column is present in the list of requested columns by returning the match code instance.protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanQueryMatcher.checkDeleted(org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker deletes, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeExplicitColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeNewVersionBehaviorTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanWildcardColumnTracker.checkVersions(org.apache.hadoop.hbase.Cell cell, long timestamp, byte type, boolean ignoreCount) Keeps track of the number of versions for the columns asked for.intScanQueryMatcher.compareKeyForNextColumn(org.apache.hadoop.hbase.Cell nextIndexed, org.apache.hadoop.hbase.Cell currentCell) intScanQueryMatcher.compareKeyForNextRow(org.apache.hadoop.hbase.Cell nextIndexed, org.apache.hadoop.hbase.Cell currentCell) default voidColumnTracker.doneWithColumn(org.apache.hadoop.hbase.Cell cell) This method is used to inform the column tracker that we are done with this column.voidExplicitColumnTracker.doneWithColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScanQueryMatcher.getKeyForNextColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellCompactionScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.CellScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) Delegate toFilter.getNextCellHint(Cell).org.apache.hadoop.hbase.CellUserScanQueryMatcher.getNextKeyHint(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell) Retrieve the MatchCode for the next row or columnorg.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeExplicitColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeNewVersionBehaviorTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanWildcardColumnTracker.getNextRowOrNextColumn(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResultDeleteTracker.isDeleted(org.apache.hadoop.hbase.Cell cell) Check if the specified cell buffer has been deleted by a previously seen delete.org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResultNewVersionBehaviorTracker.isDeleted(org.apache.hadoop.hbase.Cell cell) This method is not idempotent, we will save some info to judge VERSION_MASKED.org.apache.hadoop.hbase.regionserver.querymatcher.DeleteTracker.DeleteResultScanDeleteTracker.isDeleted(org.apache.hadoop.hbase.Cell cell) Check if the specified Cell buffer has been deleted by a previously seen delete.org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeIncludeAllCompactionQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeMajorCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeMinorCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeNormalUserScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeRawScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) abstract org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) Determines if the caller should do one of several things: seek/skip to the next row (MatchCode.SEEK_NEXT_ROW) seek/skip to the next column (MatchCode.SEEK_NEXT_COL) include the current KeyValue (MatchCode.INCLUDE) ignore the current KeyValue (MatchCode.SKIP) got to the next row (MatchCode.DONE)org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeStripeCompactionScanQueryMatcher.match(org.apache.hadoop.hbase.Cell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeUserScanQueryMatcher.matchColumn(org.apache.hadoop.hbase.Cell cell, long timestamp, byte typeByte) booleanCompactionScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell) abstract booleanScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell) booleanUserScanQueryMatcher.moreRowsMayExistAfter(org.apache.hadoop.hbase.Cell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeScanQueryMatcher.preCheck(org.apache.hadoop.hbase.Cell cell) Check before the delete logic.protected longNewVersionBehaviorTracker.prepare(org.apache.hadoop.hbase.Cell cell) Reset the map if it is different with the last Cell.voidScanQueryMatcher.setToNewRow(org.apache.hadoop.hbase.Cell currentRow) Set the row when there is change in rowprotected final voidCompactionScanQueryMatcher.trackDelete(org.apache.hadoop.hbase.Cell cell) protected final org.apache.hadoop.hbase.regionserver.querymatcher.ScanQueryMatcher.MatchCodeDropDeletesCompactionScanQueryMatcher.tryDropDelete(org.apache.hadoop.hbase.Cell cell) Constructors in org.apache.hadoop.hbase.regionserver.querymatcher with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionprotectedScanQueryMatcher(org.apache.hadoop.hbase.Cell startKey, org.apache.hadoop.hbase.regionserver.ScanInfo scanInfo, org.apache.hadoop.hbase.regionserver.querymatcher.ColumnTracker columns, long oldestUnexpiredTS, long now)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.throttle
Method parameters in org.apache.hadoop.hbase.regionserver.throttle with type arguments of type org.apache.hadoop.hbase.Cell in in - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.regionserver.wal
Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidWALCellCodec.EnsureKvEncoder.write(org.apache.hadoop.hbase.Cell cell) Method parameters in org.apache.hadoop.hbase.regionserver.wal with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic voidWALUtil.filterCells(org.apache.hadoop.hbase.wal.WALEdit edit, Function<org.apache.hadoop.hbase.Cell, org.apache.hadoop.hbase.Cell> mapper) static voidWALUtil.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
Methods in org.apache.hadoop.hbase.replication that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellBulkLoadCellFilter.filterCell(org.apache.hadoop.hbase.Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.org.apache.hadoop.hbase.CellNamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellWALCellFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) Applies the filter, possibly returning a different Cell instance.Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellBulkLoadCellFilter.filterCell(org.apache.hadoop.hbase.Cell cell, org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate) Filters the bulk load cell using the supplied predicate.org.apache.hadoop.hbase.CellNamespaceTableCfWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellScopeWALEntryFilter.filterCell(org.apache.hadoop.hbase.wal.WAL.Entry entry, org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.CellWALCellFilter.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
Methods in org.apache.hadoop.hbase.rest that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellRowResultGenerator.next()org.apache.hadoop.hbase.CellScannerResultGenerator.next()Methods in org.apache.hadoop.hbase.rest with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionabstract voidResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv) voidRowResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv) voidScannerResultGenerator.putBack(org.apache.hadoop.hbase.Cell kv)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.shaded.protobuf
Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.CellProtobufUtil.toCell(org.apache.hadoop.hbase.ExtendedCellBuilder cellBuilder, org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.Cell cell, boolean decodeTags) Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.CellProtos.CellProtobufUtil.toCell(org.apache.hadoop.hbase.Cell kv, boolean encodeTags) static org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.CursorProtobufUtil.toCursor(org.apache.hadoop.hbase.Cell cell)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.thrift
Methods in org.apache.hadoop.hbase.thrift with parameters of type org.apache.hadoop.hbase.Cell in inModifier 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
Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.Cell in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.util.MapReduceExtendedCellA wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.CellBloomContext.getLastCell()org.apache.hadoop.hbase.CellBloomFilterWriter.getPrevCell()Returns the previous cell written by this writerorg.apache.hadoop.hbase.CellCollectionBackedScanner.next()org.apache.hadoop.hbase.CellCollectionBackedScanner.peek()Methods in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionvoidBloomFilterChunk.add(org.apache.hadoop.hbase.Cell cell) static intBytes.binarySearch(byte[][] arr, org.apache.hadoop.hbase.Cell key, org.apache.hadoop.io.RawComparator<org.apache.hadoop.hbase.Cell> comparator) Deprecated.since 2.0.0 and will be removed in 3.0.0.static intBytes.binarySearch(org.apache.hadoop.hbase.Cell[] arr, org.apache.hadoop.hbase.Cell key, CellComparator comparator) Binary search for keys in indexes.booleanBloomFilter.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 booleanBloomFilterUtil.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) protected abstract booleanBloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell) Returns true if the cell is a new key as per the bloom typeprotected booleanRowBloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell) protected booleanRowColBloomContext.isNewKey(org.apache.hadoop.hbase.Cell cell) booleanCollectionBackedScanner.reseek(org.apache.hadoop.hbase.Cell seekCell) booleanCollectionBackedScanner.seek(org.apache.hadoop.hbase.Cell seekCell) voidBloomContext.writeBloom(org.apache.hadoop.hbase.Cell cell) Bloom information from the cell is retrievedvoidRowPrefixFixedLengthBloomContext.writeBloom(org.apache.hadoop.hbase.Cell cell) Method parameters in org.apache.hadoop.hbase.util with type arguments of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionstatic intBytes.binarySearch(byte[][] arr, org.apache.hadoop.hbase.Cell key, org.apache.hadoop.io.RawComparator<org.apache.hadoop.hbase.Cell> comparator) Deprecated.since 2.0.0 and will be removed in 3.0.0.Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCellHashKey(org.apache.hadoop.hbase.Cell cell) CollectionBackedScanner(CellComparator comparator, org.apache.hadoop.hbase.Cell... array) MapReduceExtendedCell(org.apache.hadoop.hbase.Cell cell) RowBloomHashKey(org.apache.hadoop.hbase.Cell cell) RowColBloomHashKey(org.apache.hadoop.hbase.Cell cell) Constructor parameters in org.apache.hadoop.hbase.util with type arguments of type org.apache.hadoop.hbase.Cell in inModifierConstructorDescriptionCollectionBackedScanner(List<org.apache.hadoop.hbase.Cell> list) CollectionBackedScanner(List<org.apache.hadoop.hbase.Cell> list, CellComparator comparator) CollectionBackedScanner(SortedSet<org.apache.hadoop.hbase.Cell> set) CollectionBackedScanner(SortedSet<org.apache.hadoop.hbase.Cell> set, CellComparator comparator)  - 
Uses of org.apache.hadoop.hbase.Cell in org.apache.hadoop.hbase.wal
Methods in org.apache.hadoop.hbase.wal that return types with arguments of type org.apache.hadoop.hbase.Cell in inMethods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.Cell in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.wal.WALEditWALEdit.add(org.apache.hadoop.hbase.Cell cell) org.apache.hadoop.hbase.wal.WALEditWALEdit.add(org.apache.hadoop.hbase.Cell cell, byte[] family) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptorWALEdit.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.CompactionDescriptorWALEdit.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.FlushDescriptorWALEdit.getFlushDescriptor(org.apache.hadoop.hbase.Cell cell) static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.RegionEventDescriptorWALEdit.getRegionEventDescriptor(org.apache.hadoop.hbase.Cell cell) static booleanWALEdit.isCompactionMarker(org.apache.hadoop.hbase.Cell cell) Returns true if the given cell is a serializedWALProtos.CompactionDescriptorstatic booleanWALEdit.isMetaEditFamily(org.apache.hadoop.hbase.Cell cell) Replaying WALs can read Cell-at-a-time so need this method in those cases.WALPrettyPrinter.toStringMap(org.apache.hadoop.hbase.Cell cell) WALPrettyPrinter.toStringMap(org.apache.hadoop.hbase.Cell cell, boolean printRowKeyOnly, String rowPrefix, String row, boolean outputValues) Method parameters in org.apache.hadoop.hbase.wal with type arguments of type org.apache.hadoop.hbase.Cell in in