|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Cell | |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.codec | |
org.apache.hadoop.hbase.io | |
org.apache.hadoop.hbase.io.encoding |
Uses of Cell in org.apache.hadoop.hbase |
---|
Classes in org.apache.hadoop.hbase that implement Cell | |
---|---|
class |
KeyValue
An HBase Key/Value. |
class |
NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0 |
Methods in org.apache.hadoop.hbase that return Cell | |
---|---|
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()
|
Methods in org.apache.hadoop.hbase with parameters of type Cell | |
---|---|
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 |
CellComparator.compare(Cell a,
Cell b)
|
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 |
static int |
CellComparator.compareFamilies(Cell left,
Cell right)
|
static int |
CellComparator.compareQualifiers(Cell left,
Cell right)
|
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.compareRows(Cell left,
Cell right)
Do not use comparing rows from hbase:meta. |
static int |
CellComparator.compareStatic(Cell a,
Cell b)
|
static int |
CellComparator.compareStatic(Cell a,
Cell b,
boolean onlyKey)
|
static int |
CellComparator.compareTimestamps(Cell left,
Cell right)
Compares cell's timestamps in DESCENDING order. |
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.createFirstOnRowColTS(Cell kv,
long ts)
Creates the first KV with the row/family/qualifier of this KV and the given timestamp. |
static KeyValue |
KeyValueUtil.createLastOnRow(Cell kv)
Creates a keyValue for the specified keyvalue larger than or equal to all other possible KeyValues that have the same row, family, qualifer. |
static KeyValue |
KeyValueUtil.createLastOnRowCol(Cell kv)
Similar to KeyValueUtil.createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int)
but creates the last key on the row/column of this KV (the value part of
the returned KV is always empty). |
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 int |
CellComparator.hashCodeIgnoreMvcc(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.isDeleteColumnOrFamily(Cell cell)
|
static boolean |
CellUtil.isDeleteColumns(Cell cell)
|
static boolean |
CellUtil.isDeleteColumnVersion(Cell cell)
|
static boolean |
CellUtil.isDeleteFamily(Cell cell)
|
static boolean |
CellUtil.isDeleteFamilyVersion(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.matchingTimestamp(Cell a,
Cell b)
|
static boolean |
CellUtil.matchingValue(Cell left,
byte[] buf)
|
static boolean |
CellUtil.matchingValue(Cell left,
Cell right)
|
Method parameters in org.apache.hadoop.hbase with type arguments of type Cell | |
---|---|
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)
|
Constructors in org.apache.hadoop.hbase with parameters of type Cell | |
---|---|
KeyValue(Cell c)
|
Uses of Cell in org.apache.hadoop.hbase.codec |
---|
Methods in org.apache.hadoop.hbase.codec that return Cell | |
---|---|
Cell |
BaseDecoder.current()
|
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell()
|
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell()
|
protected abstract Cell |
BaseDecoder.parseCell()
Extract a Cell. |
Methods in org.apache.hadoop.hbase.codec with parameters of type Cell | |
---|---|
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell)
|
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell)
|
abstract void |
BaseEncoder.write(Cell cell)
|
Uses of Cell in org.apache.hadoop.hbase.io |
---|
Methods in org.apache.hadoop.hbase.io with parameters of type Cell | |
---|---|
void |
CellOutputStream.write(Cell cell)
Implementation must copy the entire state of the Cell. |
Uses of Cell in org.apache.hadoop.hbase.io.encoding |
---|
Methods in org.apache.hadoop.hbase.io.encoding that return types with arguments of type Cell | |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value. |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |