Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.encoding | |
org.apache.hadoop.hbase.util |
Modifier and Type | Interface and Description |
---|---|
interface |
ExtendedCell
Extension to
Cell with server side required functions. |
interface |
RawCell
An extended version of Cell that allows CPs manipulate Tags.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferExtendedCell
This class is a server side extension to the
Cell interface. |
class |
ByteBufferKeyOnlyKeyValue
This is a key only Cell implementation which is identical to
KeyValue.KeyOnlyKeyValue
with respect to key serialization but have its data in the form of Byte buffer (onheap and
offheap). |
class |
ByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in off
heap/ on heap ByteBuffer |
class |
IndividualBytesFieldCell |
class |
KeyValue
An HBase Key/Value.
|
static class |
KeyValue.KeyOnlyKeyValue
A simple form of KeyValue that creates a keyvalue with only the key part of the byte[] Mainly
used in places where we need to compare two cells.
|
class |
NoTagsByteBufferKeyValue
An extension of the ByteBufferKeyValue where the tags length is always 0
|
class |
NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0
|
class |
SizeCachedByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in off
heap/ on heap ByteBuffer |
class |
SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
|
class |
SizeCachedNoTagsByteBufferKeyValue
This Cell is an implementation of
ByteBufferExtendedCell where the data resides in off
heap/ on heap ByteBuffer |
class |
SizeCachedNoTagsKeyValue
This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
|
Modifier and Type | Method and Description |
---|---|
Cell |
CellBuilder.build() |
static Cell |
CellUtil.cloneIfNecessary(Cell cell) |
static Cell |
CellUtil.createCell(byte[] row)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
CellBuilder
instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] value)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
CellBuilder
instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
CellBuilder
instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
CellBuilder
instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
byte[] tags,
long memstoreTS)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
ExtendedCellBuilder instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
long memstoreTS)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
ExtendedCellBuilder instead |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
KeyValue.Type type,
byte[] value,
byte[] tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
ExtendedCellBuilder instead |
static Cell |
CellUtil.createCell(byte[] rowArray,
int rowOffset,
int rowLength,
byte[] familyArray,
int familyOffset,
int familyLength,
byte[] qualifierArray,
int qualifierOffset,
int qualifierLength)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
CellBuilder
instead |
static Cell |
CellUtil.createCell(Cell cell,
byte[] tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
byte[] tags)
Returns A new cell which is having the extra tags also added to it.
|
static Cell |
CellUtil.createCell(Cell cell,
byte[] value,
byte[] tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
byte[] value,
byte[] tags) |
static Cell |
RawCell.createCell(Cell cell,
List<Tag> tags)
Returns A new cell which is having the extra tags also added to it.
|
static Cell |
CellUtil.createCell(Cell cell,
List<Tag> tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
List<Tag> tags)
Returns A new cell which is having the extra tags also added to it.
|
static Cell |
PrivateCellUtil.createFirstDeleteFamilyCellOnRow(byte[] row,
byte[] fam)
Create a Delete Family Cell for the specified row and family that would be smaller than all
other possible Delete Family KeyValues that have the same row and family.
|
static Cell |
PrivateCellUtil.createFirstOnNextRow(Cell cell) |
static Cell |
PrivateCellUtil.createFirstOnRow(byte[] row) |
static Cell |
PrivateCellUtil.createFirstOnRow(byte[] row,
byte[] family,
byte[] col) |
static Cell |
PrivateCellUtil.createFirstOnRow(byte[] row,
int roffset,
short rlength) |
static Cell |
PrivateCellUtil.createFirstOnRow(byte[] row,
int roffset,
short rlength,
byte[] family,
int foffset,
byte flength,
byte[] col,
int coffset,
int clength) |
static Cell |
PrivateCellUtil.createFirstOnRow(Cell cell)
Create a Cell that is smaller than all other possible Cells for the given Cell's row.
|
static Cell |
PrivateCellUtil.createFirstOnRowCol(Cell cell) |
static Cell |
PrivateCellUtil.createFirstOnRowCol(Cell cell,
byte[] qArray,
int qoffest,
int qlength)
Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and
passed qualifier.
|
static Cell |
PrivateCellUtil.createFirstOnRowColTS(Cell cell,
long ts)
Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
|
static Cell |
PrivateCellUtil.createFirstOnRowFamily(Cell cell,
byte[] fArray,
int foff,
int flen) |
static Cell |
PrivateCellUtil.createLastOnRow(byte[] row) |
static Cell |
PrivateCellUtil.createLastOnRow(Cell cell)
Create a Cell that is larger than all other possible Cells for the given Cell's row.
|
static Cell |
PrivateCellUtil.createLastOnRowCol(Cell cell)
Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
|
static Cell |
PrivateCellUtil.createNextOnRowCol(Cell cell)
Return a new cell is located following input cell.
|
Cell |
CellScanner.current()
Returns the current Cell which may be mutable
|
static Cell |
PrivateCellUtil.deepClone(Cell cell)
Deep clones the given cell if the cell supports deep cloning
|
Modifier and Type | Method and Description |
---|---|
Comparator<Cell> |
CellComparator.getSimpleComparator()
Return a dumbed-down, fast comparator for hbase2 base-type, the
ByteBufferKeyValue . |
Modifier and Type | Method and Description |
---|---|
static int |
KeyValueUtil.appendKeyTo(Cell cell,
byte[] output,
int offset) |
static int |
KeyValueUtil.appendKeyTo(Cell cell,
ByteBuffer buf,
int offset) |
static int |
KeyValueUtil.appendTo(Cell cell,
ByteBuffer buf,
int offset,
boolean withTags)
Copy the Cell content into the passed buf in KeyValue serialization format.
|
static int |
KeyValueUtil.appendToByteArray(Cell cell,
byte[] output,
int offset,
boolean withTags)
copy key and value
|
static List<Tag> |
TagUtil.carryForwardTags(Cell cell)
Returns A List<Tag> of any Tags found in
cell else null. |
static List<Tag> |
TagUtil.carryForwardTags(List<Tag> tagsOrNull,
Cell cell)
Add to
tagsOrNull any Tags cell is carrying or null if none. |
static byte[] |
CellUtil.cloneFamily(Cell cell) |
static Cell |
CellUtil.cloneIfNecessary(Cell cell) |
static byte[] |
CellUtil.cloneQualifier(Cell cell) |
static byte[] |
CellUtil.cloneRow(Cell cell)
get individual arrays for tests
|
static byte[] |
CellUtil.cloneTags(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0. Use
RawCell.cloneTags() |
static byte[] |
PrivateCellUtil.cloneTags(Cell cell) |
static byte[] |
CellUtil.cloneValue(Cell cell) |
int |
KeyValue.MetaComparator.compare(Cell left,
Cell right)
Deprecated.
Compare key portion of a
KeyValue for keys in hbase:meta table. |
int |
KeyValue.KVComparator.compare(Cell left,
Cell right)
Deprecated.
Compares the Key of a cell -- with fields being more significant in this order: rowkey,
colfam/qual, timestamp, type, mvcc
|
int |
CellComparatorImpl.compare(Cell a,
Cell b) |
int |
CellComparator.compare(Cell leftCell,
Cell rightCell)
Lexographically compares two cells.
|
int |
MetaCellComparator.compare(Cell a,
Cell b,
boolean ignoreSequenceid) |
int |
CellComparatorImpl.compare(Cell l,
Cell r,
boolean ignoreSequenceid) |
int |
CellComparator.compare(Cell leftCell,
Cell rightCell,
boolean ignoreSequenceid)
Compare cells.
|
static int |
CellUtil.compare(CellComparator comparator,
Cell left,
byte[] key,
int offset,
int length)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static int |
PrivateCellUtil.compare(CellComparator comparator,
Cell left,
byte[] key,
int offset,
int length)
Used when a cell needs to be compared with a key byte[] such as cases of finding the index from
the index block, bloom keys from the bloom blocks This byte[] is expected to be serialized in
the KeyValue serialization format If the KeyValue (Cell's) serialization format changes this
method cannot be used.
|
static int |
CellUtil.compareColumns(Cell left,
byte[] right,
int rfoffset,
int rflength,
int rqoffset,
int rqlength)
Compares the cell's column (family and qualifier) with the given byte[]
|
int |
CellComparatorImpl.compareColumns(Cell left,
Cell right)
Compares the family and qualifier part of the cell
|
static int |
CellUtil.compareFamilies(Cell left,
byte[] right,
int roffset,
int rlength)
Compares the cell's family with the given byte[]
|
int |
CellComparatorImpl.compareFamilies(Cell left,
Cell right)
Compare the families of left and right cell
|
int |
CellComparator.compareFamilies(Cell leftCell,
Cell rightCell)
Lexicographically compares the families of the two cells
|
static int |
PrivateCellUtil.compareFamily(Cell cell,
ByteArrayComparable comparator)
Compare cell's column family against given comparator
|
int |
KeyValue.KVComparator.compareKey(Cell cell,
byte[] row,
int roff,
int rlen,
byte[] fam,
int foff,
int flen,
byte[] col,
int coff,
int clen,
long ts,
byte type)
Deprecated.
|
static int |
PrivateCellUtil.compareKeyBasedOnColHint(CellComparator comparator,
Cell nextIndexedCell,
Cell currentCell,
int foff,
int flen,
byte[] colHint,
int coff,
int clen,
long ts,
byte type)
Used to compare two cells based on the column hint provided.
|
static int |
PrivateCellUtil.compareKeyIgnoresMvcc(CellComparator comparator,
Cell left,
Cell right)
Compares only the key portion of a cell.
|
int |
KeyValue.MetaComparator.compareOnlyKeyPortion(Cell left,
Cell right)
Deprecated.
|
int |
KeyValue.KVComparator.compareOnlyKeyPortion(Cell left,
Cell right)
Deprecated.
|
static int |
PrivateCellUtil.compareQualifier(Cell cell,
ByteArrayComparable comparator)
Compare cell's qualifier against given comparator
|
static int |
CellUtil.compareQualifiers(Cell left,
byte[] right,
int rOffset,
int rLength)
Compares the cell's qualifier with the given byte[]
|
int |
CellComparatorImpl.compareQualifiers(Cell left,
Cell right)
Compare the qualifiers part of the left and right cells.
|
int |
CellComparator.compareQualifiers(Cell leftCell,
Cell rightCell)
Lexicographically compares the qualifiers of the two cells
|
static int |
PrivateCellUtil.compareRow(Cell cell,
ByteArrayComparable comparator)
Compare cell's row against given comparator
|
protected int |
KeyValue.MetaComparator.compareRowKey(Cell l,
Cell r)
Deprecated.
Override the row key comparison to parse and compare the meta row key parts.
|
protected int |
KeyValue.KVComparator.compareRowKey(Cell left,
Cell right)
Deprecated.
Compares the only the user specified portion of a Key.
|
int |
MetaCellComparator.compareRows(ByteBuffer row,
Cell cell) |
default int |
CellComparator.compareRows(ByteBuffer row,
Cell cell)
Lexicographically compare two rows
|
int |
MetaCellComparator.compareRows(Cell left,
byte[] right,
int roffset,
int rlength) |
int |
CellComparatorImpl.compareRows(Cell left,
byte[] right,
int roffset,
int rlength)
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
|
int |
CellComparator.compareRows(Cell cell,
byte[] bytes,
int offset,
int length)
Compares the row part of the cell with a simple plain byte[] like the stopRow in Scan.
|
int |
MetaCellComparator.compareRows(Cell left,
Cell right) |
int |
KeyValue.KVComparator.compareRows(Cell left,
Cell right)
Deprecated.
Compares the rows of a cell
|
int |
CellComparatorImpl.compareRows(Cell left,
Cell right)
Compares the rows of the left and right cell.
|
int |
CellComparator.compareRows(Cell leftCell,
Cell rightCell)
Lexographically compares the rows of two cells.
|
int |
KeyValue.KVComparator.compareTimestamps(Cell left,
Cell right)
Deprecated.
|
int |
CellComparatorImpl.compareTimestamps(Cell left,
Cell right) |
int |
CellComparator.compareTimestamps(Cell leftCell,
Cell rightCell)
Compares cell's timestamps in DESCENDING order.
|
static int |
PrivateCellUtil.compareValue(Cell cell,
ByteArrayComparable comparator)
Compare cell's value against given comparator
|
int |
CellComparatorImpl.compareWithoutRow(Cell left,
Cell right) |
int |
CellComparator.compareWithoutRow(Cell leftCell,
Cell rightCell)
Lexicographically compares the two cells excluding the row part.
|
static void |
PrivateCellUtil.compressFamily(OutputStream out,
Cell cell,
Dictionary dict) |
static void |
PrivateCellUtil.compressQualifier(OutputStream out,
Cell cell,
Dictionary dict) |
static void |
PrivateCellUtil.compressRow(OutputStream out,
Cell cell,
Dictionary dict) |
static void |
PrivateCellUtil.compressTags(OutputStream out,
Cell cell,
TagCompressionContext tagCompressionContext)
Compresses the tags to the given outputstream using the TagcompressionContext
|
static byte[] |
TagUtil.concatTags(byte[] tags,
Cell cell) |
static int |
CellUtil.copyFamilyTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the family to the given byte[]
|
static int |
CellUtil.copyFamilyTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Copies the family to the given bytebuffer
|
static ByteBuffer |
KeyValueUtil.copyKeyToNewByteBuffer(Cell cell)
The position will be set to the beginning of the new ByteBuffer
|
static int |
CellUtil.copyQualifierTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the qualifier to the given byte[]
|
static int |
CellUtil.copyQualifierTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Copies the qualifier to the given bytebuffer
|
static byte[] |
CellUtil.copyRow(Cell cell)
Copies the row to a new byte[]
|
static int |
CellUtil.copyRowTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the row to the given byte[]
|
static int |
CellUtil.copyRowTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Copies the row to the given bytebuffer
|
static int |
PrivateCellUtil.copyTagsTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the tags info into the tag portion of the cell
|
static int |
PrivateCellUtil.copyTagsTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Copies the tags info into the tag portion of the cell
|
static int |
CellUtil.copyTagTo(Cell cell,
byte[] destination,
int destinationOffset)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static int |
CellUtil.copyTagTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Deprecated.
As of HBase-2.0. Will be removed in 3.0.
|
static byte[] |
KeyValueUtil.copyToNewByteArray(Cell cell) |
static KeyValue |
KeyValueUtil.copyToNewKeyValue(Cell cell)
copy the cell to create a new keyvalue
|
static int |
CellUtil.copyValueTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the value to the given byte[]
|
static int |
CellUtil.copyValueTo(Cell cell,
ByteBuffer destination,
int destinationOffset)
Copies the value to the given bytebuffer
|
static Cell |
CellUtil.createCell(Cell cell,
byte[] tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
byte[] tags)
Returns A new cell which is having the extra tags also added to it.
|
static Cell |
CellUtil.createCell(Cell cell,
byte[] value,
byte[] tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
byte[] value,
byte[] tags) |
static Cell |
RawCell.createCell(Cell cell,
List<Tag> tags)
Returns A new cell which is having the extra tags also added to it.
|
static Cell |
CellUtil.createCell(Cell cell,
List<Tag> tags)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static Cell |
PrivateCellUtil.createCell(Cell cell,
List<Tag> tags)
Returns A new cell which is having the extra tags also added to it.
|
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray)
Returns CellScanner interface over
cellArray |
static Cell |
PrivateCellUtil.createFirstOnNextRow(Cell cell) |
static Cell |
PrivateCellUtil.createFirstOnRow(Cell cell)
Create a Cell that is smaller than all other possible Cells for the given Cell's row.
|
static Cell |
PrivateCellUtil.createFirstOnRowCol(Cell cell) |
static Cell |
PrivateCellUtil.createFirstOnRowCol(Cell cell,
byte[] qArray,
int qoffest,
int qlength)
Create a Cell that is smaller than all other possible Cells for the given Cell's rk:cf and
passed qualifier.
|
static Cell |
PrivateCellUtil.createFirstOnRowColTS(Cell cell,
long ts)
Creates the first cell with the row/family/qualifier of this cell and the given timestamp.
|
static Cell |
PrivateCellUtil.createFirstOnRowFamily(Cell cell,
byte[] fArray,
int foff,
int flen) |
static Cell |
PrivateCellUtil.createLastOnRow(Cell cell)
Create a Cell that is larger than all other possible Cells for the given Cell's row.
|
static Cell |
PrivateCellUtil.createLastOnRowCol(Cell cell)
Create a Cell that is larger than all other possible Cells for the given Cell's rk:cf:q.
|
static Cell |
PrivateCellUtil.createNextOnRowCol(Cell cell)
Return a new cell is located following input cell.
|
static Cell |
PrivateCellUtil.deepClone(Cell cell)
Deep clones the given cell if the cell supports deep cloning
|
static KeyValue |
KeyValueUtil.ensureKeyValue(Cell cell)
Deprecated.
without any replacement.
|
static boolean |
CellUtil.equals(Cell a,
Cell b)
equals
|
static boolean |
CellUtil.equalsIgnoreMvccVersion(Cell a,
Cell b)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static boolean |
PrivateCellUtil.equalsIgnoreMvccVersion(Cell a,
Cell b)
special case for Cell.equals
|
static long |
CellUtil.estimatedHeapSizeOf(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
RawCell.getTags() |
static int |
CellUtil.estimatedSerializedSizeOf(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static int |
PrivateCellUtil.estimatedSerializedSizeOf(Cell cell)
Estimate based on keyvalue's serialization format in the RPC layer.
|
static int |
CellUtil.estimatedSerializedSizeOfKey(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static int |
PrivateCellUtil.estimatedSerializedSizeOfKey(Cell cell)
Calculates the serialized key size.
|
static ByteRange |
CellUtil.fillFamilyRange(Cell cell,
ByteRange range)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static ByteRange |
PrivateCellUtil.fillFamilyRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillQualifierRange(Cell cell,
ByteRange range)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static ByteRange |
PrivateCellUtil.fillQualifierRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillRowRange(Cell cell,
ByteRange range)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static ByteRange |
PrivateCellUtil.fillRowRange(Cell cell,
ByteRange range)
ByteRange
|
static ByteRange |
CellUtil.fillTagRange(Cell cell,
ByteRange range)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static ByteRange |
PrivateCellUtil.fillTagRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillValueRange(Cell cell,
ByteRange range)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
|
static ByteRange |
PrivateCellUtil.fillValueRange(Cell cell,
ByteRange range) |
static int |
CellUtil.findCommonPrefixInFlatKey(Cell c1,
Cell c2,
boolean bypassFamilyCheck,
boolean withTsType)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static int |
PrivateCellUtil.findCommonPrefixInFlatKey(Cell c1,
Cell c2,
boolean bypassFamilyCheck,
boolean withTsType)
Find length of common prefix in keys of the cells, considering key as byte[] if serialized in
KeyValue . |
static String |
CellUtil.getCellKeyAsString(Cell cell)
Return the key portion of the passed
cell as a String. |
static String |
CellUtil.getCellKeyAsString(Cell cell,
Function<Cell,String> rowConverter)
Return the Key portion of the passed
cell as a String. |
static byte[] |
CellUtil.getCellKeySerializedAsKeyValueKey(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static byte[] |
PrivateCellUtil.getCellKeySerializedAsKeyValueKey(Cell cell)
This method exists just to encapsulate how we serialize keys.
|
static ByteBuffer |
CellUtil.getQualifierBufferShallowCopy(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static byte |
PrivateCellUtil.getQualifierByte(Cell cell,
int index) |
static int |
PrivateCellUtil.getRowAsInt(Cell cell)
Converts the rowkey bytes of the given cell into an int value
|
static byte |
CellUtil.getRowByte(Cell cell,
int index)
Deprecated.
|
static byte |
PrivateCellUtil.getRowByte(Cell cell,
int index)
misc
|
static int |
KeyValueUtil.getSerializedSize(Cell cell,
boolean withTags) |
static Tag |
CellUtil.getTag(Cell cell,
byte type)
Deprecated.
As of 2.0.0 and will be removed in HBase-3.0.0 Use
RawCell.getTag(byte) |
static Optional<Tag> |
PrivateCellUtil.getTag(Cell cell,
byte type)
Retrieve Cell's first tag, matching the passed in type
|
static byte[] |
CellUtil.getTagArray(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static List<Tag> |
CellUtil.getTags(Cell cell)
Deprecated.
As of 2.0.0 and will be removed in 3.0.0
|
static List<Tag> |
PrivateCellUtil.getTags(Cell cell)
Return tags in the given Cell as a List
|
static BigDecimal |
PrivateCellUtil.getValueAsBigDecimal(Cell cell)
Converts the value bytes of the given cell into a BigDecimal
|
static double |
PrivateCellUtil.getValueAsDouble(Cell cell)
Converts the value bytes of the given cell into a double value
|
static int |
PrivateCellUtil.getValueAsInt(Cell cell)
Converts the value bytes of the given cell into a int value
|
static long |
PrivateCellUtil.getValueAsLong(Cell cell)
Converts the value bytes of the given cell into a long value
|
static ByteBuffer |
CellUtil.getValueBufferShallowCopy(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in 3.0.
|
static ByteBuffer |
PrivateCellUtil.getValueBufferShallowCopy(Cell cell) |
static boolean |
CellUtil.isDelete(Cell cell)
Return true if a delete type, a
KeyValue.Type.Delete or a {KeyValue.Type#DeleteFamily}
or a KeyValue.Type.DeleteColumn KeyValue type. |
static boolean |
CellUtil.isDeleteColumnOrFamily(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteColumnOrFamily(Cell cell)
Returns True if this cell is a delete family or column type.
|
static boolean |
CellUtil.isDeleteColumns(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteColumns(Cell cell) |
static boolean |
CellUtil.isDeleteColumnVersion(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteColumnVersion(Cell cell) |
static boolean |
CellUtil.isDeleteFamily(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteFamily(Cell cell) |
static boolean |
CellUtil.isDeleteFamilyVersion(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteFamilyVersion(Cell cell) |
static boolean |
CellUtil.isDeleteType(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.isDeleteType(Cell cell)
Returns True if this cell is a
KeyValue.Type.Delete type. |
static boolean |
CellUtil.isPut(Cell cell)
Returns True if this cell is a Put.
|
static int |
KeyValueUtil.keyLength(Cell cell)
Returns number of bytes this cell's key part would have been used if serialized as in
KeyValue . |
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
int foffset,
int flength,
byte[] qual,
int qoffset,
int qlength)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.matchingColumn(Cell left,
byte[] fam,
int foffset,
int flength,
byte[] qual,
int qoffset,
int qlength) |
static boolean |
CellUtil.matchingColumn(Cell left,
Cell right) |
static boolean |
CellUtil.matchingColumnFamilyAndQualifierPrefix(Cell left,
byte[] fam,
byte[] qual)
Returns True if matching column family and the qualifier starts with
qual |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf,
int offset,
int length)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.matchingFamily(Cell left,
byte[] buf,
int offset,
int length) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte lfamlength,
Cell right,
byte rfamlength) |
static boolean |
CellUtil.matchingFamily(Cell left,
Cell right) |
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf)
Finds if the qualifier part of the cell and the KV serialized byte[] are equal.
|
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf,
int offset,
int length)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
PrivateCellUtil.matchingQualifier(Cell left,
byte[] buf,
int offset,
int length)
Finds if the qualifier part of the cell and the KV serialized byte[] are equal
|
static boolean |
CellUtil.matchingQualifier(Cell left,
Cell right) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, byte[]) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf,
int offset,
int length)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, Cell) |
static boolean |
CellUtil.matchingRow(Cell left,
Cell right)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, Cell) |
static boolean |
CellUtil.matchingRowColumn(Cell left,
Cell right)
Compares the row and column of two keyvalues for equality
|
boolean |
KeyValue.KVComparator.matchingRowColumn(Cell left,
Cell right)
Deprecated.
Compares the row and column of two keyvalues for equality
|
static boolean |
CellUtil.matchingRowColumnBytes(Cell left,
Cell right)
Compares the row and column of two keyvalues for equality
|
static boolean |
CellUtil.matchingRows(Cell left,
byte[] buf) |
static boolean |
PrivateCellUtil.matchingRows(Cell left,
byte[] buf,
int offset,
int length) |
static boolean |
CellUtil.matchingRows(Cell left,
Cell right)
Compares the row of two keyvalues for equality
|
boolean |
KeyValue.KVComparator.matchingRows(Cell left,
Cell right)
Deprecated.
Compares the row of two keyvalues for equality
|
static boolean |
CellUtil.matchingRows(Cell left,
short lrowlength,
Cell right,
short rrowlength)
Compares the row of two keyvalues for equality
|
static boolean |
CellUtil.matchingTags(Cell left,
Cell right) |
static boolean |
PrivateCellUtil.matchingTags(Cell left,
Cell right,
int llength,
int rlength) |
static boolean |
CellUtil.matchingTimestamp(Cell a,
Cell b) |
static boolean |
CellUtil.matchingType(Cell a,
Cell b)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static boolean |
PrivateCellUtil.matchingType(Cell a,
Cell b) |
static boolean |
CellUtil.matchingValue(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingValue(Cell left,
Cell right) |
static boolean |
PrivateCellUtil.matchingValue(Cell left,
Cell right,
int lvlength,
int rvlength) |
static int |
KeyValueUtil.oswrite(Cell cell,
OutputStream out,
boolean withTags) |
static boolean |
PrivateCellUtil.qualifierStartsWith(Cell left,
byte[] startsWith)
Finds if the start of the qualifier part of the Cell matches
buf |
static void |
CellUtil.setSequenceId(Cell cell,
long seqId)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static void |
PrivateCellUtil.setSequenceId(Cell cell,
long seqId)
Sets the given seqId to the cell.
|
static void |
PrivateCellUtil.setTimestamp(Cell cell,
byte[] ts)
Sets the given timestamp to the cell.
|
static void |
CellUtil.setTimestamp(Cell cell,
byte[] ts,
int tsOffset)
Deprecated.
As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
|
static void |
CellUtil.setTimestamp(Cell cell,
long ts)
Deprecated.
As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
|
static void |
PrivateCellUtil.setTimestamp(Cell cell,
long ts)
Sets the given timestamp to the cell.
|
static Iterator<Tag> |
PrivateCellUtil.tagsIterator(Cell cell)
Utility method to iterate through the tags in the given cell.
|
static KeyValue |
KeyValueUtil.toNewKeyCell(Cell cell)
Copies the key to a new KeyValue
|
static String |
CellUtil.toString(Cell cell,
boolean verbose)
Returns a string representation of the cell
|
static boolean |
PrivateCellUtil.updateLatestStamp(Cell cell,
byte[] ts)
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP . |
static boolean |
CellUtil.updateLatestStamp(Cell cell,
byte[] ts,
int tsOffset)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static boolean |
CellUtil.updateLatestStamp(Cell cell,
long ts)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static boolean |
PrivateCellUtil.updateLatestStamp(Cell cell,
long ts)
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP . |
static int |
PrivateCellUtil.writeCell(Cell cell,
OutputStream out,
boolean withTags)
Writes the cell to the given OutputStream
|
static void |
PrivateCellUtil.writeCellToBuffer(Cell cell,
ByteBuffer buf,
int offset)
Writes a cell to the buffer at the given offset
|
static void |
PrivateCellUtil.writeFamily(OutputStream out,
Cell cell,
byte flength)
Writes the family from the given cell to the output stream
|
static void |
PrivateCellUtil.writeFlatKey(Cell cell,
DataOutput out)
Writes the Cell's key part as it would have serialized in a KeyValue.
|
static void |
CellUtil.writeFlatKey(Cell cell,
DataOutputStream out)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static int |
PrivateCellUtil.writeFlatKey(Cell cell,
OutputStream out) |
static void |
PrivateCellUtil.writeQualifier(OutputStream out,
Cell cell,
int qlength)
Writes the qualifier from the given cell to the output stream
|
static void |
PrivateCellUtil.writeQualifierSkippingBytes(DataOutputStream out,
Cell cell,
int qlength,
int commonPrefix)
Writes the qualifier from the given cell to the output stream excluding the common prefix
|
static void |
PrivateCellUtil.writeRow(OutputStream out,
Cell cell,
short rlength)
Writes the row from the given cell to the output stream
|
static void |
CellUtil.writeRowKeyExcludingCommon(Cell cell,
short rLen,
int commonPrefix,
DataOutputStream out)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static void |
PrivateCellUtil.writeRowKeyExcludingCommon(Cell cell,
short rLen,
int commonPrefix,
DataOutputStream out)
Write rowkey excluding the common part.
|
static void |
CellUtil.writeRowSkippingBytes(DataOutputStream out,
Cell cell,
short rlength,
int commonPrefix)
Deprecated.
As of 2.0. Will be removed in hbase-3.0
|
static void |
PrivateCellUtil.writeRowSkippingBytes(DataOutputStream out,
Cell cell,
short rlength,
int commonPrefix)
Writes the row from the given cell to the output stream excluding the common prefix
|
static void |
PrivateCellUtil.writeTags(OutputStream out,
Cell cell,
int tagsLength)
Writes the tag from the given cell to the output stream
|
static void |
PrivateCellUtil.writeValue(OutputStream out,
Cell cell,
int vlength)
Writes the value from the given cell to the output stream
|
Modifier and Type | Method and Description |
---|---|
static void |
CellUtil.cloneIfNecessary(ArrayList<Cell> cells) |
static boolean |
KeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends Cell> kvCollection1,
Collection<? extends Cell> kvCollection2)
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
|
static boolean |
KeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends Cell> kvCollection1,
Collection<? extends Cell> kvCollection2)
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
|
static CellScanner |
CellUtil.createCellScanner(Iterable<Cell> cellIterable)
Returns CellScanner interface over
cellIterable |
static CellScanner |
CellUtil.createCellScanner(Iterator<Cell> cells)
Returns CellScanner interface over
cellIterable or null if cells is
null |
static CellScanner |
CellUtil.createCellScanner(NavigableMap<byte[],List<Cell>> map)
Flatten the map of cells out under the CellScanner
|
static List<KeyValue> |
KeyValueUtil.ensureKeyValues(List<Cell> cells)
Deprecated.
|
static String |
CellUtil.getCellKeyAsString(Cell cell,
Function<Cell,String> rowConverter)
Return the Key portion of the passed
cell as a String. |
Constructor and Description |
---|
KeyValue(Cell c) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
KeyValueCodec.ByteBuffKeyValueDecoder.current |
Modifier and Type | Method and Description |
---|---|
protected Cell |
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(byte[] buf,
int offset,
int len) |
protected Cell |
KeyValueCodec.ByteBuffKeyValueDecoder.createCell(byte[] buf,
int offset,
int len) |
protected Cell |
KeyValueCodecWithTags.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb,
int pos,
int len) |
protected Cell |
KeyValueCodec.ByteBuffKeyValueDecoder.createCell(ByteBuffer bb,
int pos,
int len) |
Cell |
KeyValueCodec.ByteBuffKeyValueDecoder.current() |
Cell |
BaseDecoder.current() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected abstract Cell |
BaseDecoder.parseCell()
Extract a Cell.
|
Modifier and Type | Method and Description |
---|---|
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell) |
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
abstract void |
BaseEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
void |
CellOutputStream.write(Cell cell)
Implementation must copy the entire state of the Cell.
|
Modifier and Type | Field and Description |
---|---|
protected Cell |
EncodingState.prevCell
The previous Cell the encoder encoded.
|
Modifier and Type | Method and Description |
---|---|
protected Cell |
AbstractDataBlockEncoder.createFirstKeyCell(ByteBuffer key,
int keyLength) |
Cell |
DataBlockEncoder.EncodedSeeker.getCell()
Returns the Cell at the current position.
|
Cell |
RowIndexSeekerV1.getCell() |
Cell |
RowIndexCodecV1.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
FastDiffDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block)
Return first key in block as a cell.
|
Cell |
CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DiffKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DataBlockEncoder.EncodedSeeker.getKey()
From the current position creates a cell using the key part of the current buffer
|
Cell |
RowIndexSeekerV1.getKey() |
Modifier and Type | Method and Description |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value.
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
RowIndexEncoderV1.checkRow(Cell cell) |
int |
DataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator,
Cell key)
Compare the given key against the current key
|
int |
RowIndexSeekerV1.compareKey(CellComparator comparator,
Cell key) |
void |
RowIndexCodecV1.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
void |
DataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
int |
FastDiffDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
PrefixKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
CopyKeyDataBlockEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
DiffKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
DataBlockEncoder.EncodedSeeker.seekToKeyInBlock(Cell key,
boolean seekBefore)
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if
seekBefore
is false
the last key that is strictly less than the given key if
seekBefore is true. |
int |
RowIndexSeekerV1.seekToKeyInBlock(Cell seekCell,
boolean seekBefore) |
int |
NoneEncoder.write(Cell cell) |
void |
RowIndexEncoderV1.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use
Bytes.binarySearch(Cell[], Cell, CellComparator) instead. |
static int |
Bytes.binarySearch(Cell[] arr,
Cell key,
CellComparator comparator)
Binary search for keys in indexes.
|
static int |
Bytes.binarySearch(Cell[] arr,
Cell key,
CellComparator comparator)
Binary search for keys in indexes.
|
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use
Bytes.binarySearch(Cell[], Cell, CellComparator) instead. |
Constructor and Description |
---|
CellHashKey(Cell cell) |
RowBloomHashKey(Cell cell) |
RowColBloomHashKey(Cell cell) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.