Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.encoding |
Modifier and Type | Class and Description |
---|---|
class |
KeyValue
An HBase Key/Value.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
byte[] tags,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
KeyValue.Type type,
byte[] value,
byte[] tags) |
Cell |
CellScanner.current() |
Modifier and Type | Method and Description |
---|---|
protected static int |
KeyValueUtil.appendKeyToByteArrayWithoutValue(Cell cell,
byte[] output,
int offset) |
static int |
KeyValueUtil.appendToByteArray(Cell cell,
byte[] output,
int offset)
copy key and value
|
static boolean |
CellComparator.areKeyLengthsEqual(Cell a,
Cell b)
lengths
|
static boolean |
CellComparator.areRowLengthsEqual(Cell a,
Cell b) |
static KeyValue |
KeyValue.cloneAndAddTags(Cell c,
List<Tag> newTags)
Create a new KeyValue by copying existing cell and adding new tags
|
static byte[] |
CellUtil.cloneFamily(Cell cell) |
static byte[] |
CellUtil.cloneQualifier(Cell cell) |
static byte[] |
CellUtil.cloneRow(Cell cell)
get individual arrays for tests
|
static byte[] |
CellUtil.cloneValue(Cell cell) |
int |
KeyValue.KVComparator.compare(Cell left,
Cell right)
Compares the Key of a cell -- with fields being more significant in this order:
rowkey, colfam/qual, timestamp, type, mvcc
|
int |
CellComparator.compare(Cell a,
Cell b) |
protected int |
KeyValue.MetaComparator.compareRowKey(Cell l,
Cell r)
Override the row key comparison to parse and compare the meta row key parts.
|
protected int |
KeyValue.KVComparator.compareRowKey(Cell left,
Cell right)
Compares the only the user specified portion of a Key.
|
static int |
CellComparator.compareStatic(Cell a,
Cell b) |
static int |
CellComparator.compareStatic(Cell a,
Cell b,
boolean onlyKey) |
static int |
CellUtil.copyFamilyTo(Cell cell,
byte[] destination,
int destinationOffset) |
static ByteBuffer |
KeyValueUtil.copyKeyToNewByteBuffer(Cell cell) |
static int |
CellUtil.copyQualifierTo(Cell cell,
byte[] destination,
int destinationOffset) |
static int |
CellUtil.copyRowTo(Cell cell,
byte[] destination,
int destinationOffset)
copyTo
|
static int |
CellUtil.copyTagTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the tags info into the tag portion of the cell
|
static byte[] |
KeyValueUtil.copyToNewByteArray(Cell cell) |
static ByteBuffer |
KeyValueUtil.copyToNewByteBuffer(Cell cell) |
static KeyValue |
KeyValueUtil.copyToNewKeyValue(Cell cell)
copy key only
|
static int |
CellUtil.copyValueTo(Cell cell,
byte[] destination,
int destinationOffset) |
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray) |
static KeyValue |
KeyValueUtil.createFirstKeyInIncrementedRow(Cell in)
Increment the row bytes and clear the other fields
|
static KeyValue |
KeyValueUtil.createFirstKeyInNextRow(Cell in)
Append single byte 0x00 to the end of the input row key
|
static KeyValue |
KeyValueUtil.ensureKeyValue(Cell cell) |
static boolean |
CellComparator.equals(Cell a,
Cell b)
equals
|
static boolean |
CellComparator.equalsFamily(Cell a,
Cell b) |
static boolean |
CellComparator.equalsIgnoreMvccVersion(Cell a,
Cell b)
special case for KeyValue.equals
|
static boolean |
CellComparator.equalsQualifier(Cell a,
Cell b) |
static boolean |
CellComparator.equalsRow(Cell a,
Cell b) |
static boolean |
CellComparator.equalsTimestamp(Cell a,
Cell b) |
static boolean |
CellComparator.equalsType(Cell a,
Cell b) |
static int |
CellUtil.estimatedSizeOf(Cell cell) |
static ByteRange |
CellUtil.fillFamilyRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillQualifierRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillRowRange(Cell cell,
ByteRange range)
ByteRange
|
static ByteRange |
CellUtil.fillTagRange(Cell cell,
ByteRange range) |
static ByteBuffer |
CellUtil.getQualifierBufferShallowCopy(Cell cell) |
static byte |
CellUtil.getRowByte(Cell cell,
int index)
misc
|
static byte[] |
CellUtil.getTagArray(Cell cell)
Returns tag value in a new byte array.
|
static ByteBuffer |
CellUtil.getValueBufferShallowCopy(Cell cell) |
static int |
CellComparator.hashCode(Cell cell)
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
|
static boolean |
CellUtil.isDelete(Cell cell) |
static boolean |
CellUtil.isDeleteColumns(Cell cell) |
static boolean |
CellUtil.isDeleteColumnVersion(Cell cell) |
static boolean |
CellUtil.isDeleteFamily(Cell cell) |
static int |
KeyValueUtil.keyLength(Cell cell) |
static int |
KeyValueUtil.length(Cell cell)
length
|
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
CellUtil.matchingColumn(Cell left,
Cell right) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingFamily(Cell left,
Cell right) |
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingQualifier(Cell left,
Cell right) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingRow(Cell left,
Cell right) |
static boolean |
CellUtil.matchingValue(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingValue(Cell left,
Cell right) |
Modifier and Type | Method and Description |
---|---|
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) |
static CellScanner |
CellUtil.createCellScanner(Iterator<Cell> cells) |
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) |
Constructor and Description |
---|
KeyValue(Cell c) |
Modifier and Type | Method and Description |
---|---|
Cell |
BaseDecoder.current() |
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
protected abstract Cell |
BaseDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
abstract void |
BaseEncoder.write(Cell cell) |
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
void |
KeyValueCodecWithTags.KeyValueEncoder.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 | Method and Description |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value.
|
Copyright © 2015 The Apache Software Foundation. All Rights Reserved.