Modifier and Type | Interface and Description |
---|---|
interface |
ExtendedCell
Extension to
Cell with server side required functions. |
interface |
RawCell
An extended version of cell that gives more power to CPs
|
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 |
SizeCachedKeyValue
This class is an extension to KeyValue where rowLen and keyLen are cached.
|
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.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) |
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 |
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) |
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) |
Cell |
CellScanner.current() |
static Cell |
PrivateCellUtil.deepClone(Cell cell)
Deep clones the given cell if the cell supports deep cloning
|
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) |
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 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 |
CellComparatorImpl.compare(Cell a,
Cell b) |
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 |
CellComparator.compare(Cell leftCell,
Cell rightCell)
Lexographically compares two cells.
|
int |
CellComparatorImpl.compare(Cell a,
Cell b,
boolean ignoreSequenceid) |
int |
CellComparatorImpl.MetaCellComparator.compare(Cell a,
Cell b,
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)
Lexographically 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)
Lexographically 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 |
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 |
CellComparatorImpl.MetaCellComparator.compareRows(Cell left,
byte[] right,
int roffset,
int rlength) |
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 |
CellComparatorImpl.compareRows(Cell left,
Cell right)
Compares the rows of the left and right cell.
|
int |
CellComparatorImpl.MetaCellComparator.compareRows(Cell left,
Cell right) |
int |
KeyValue.KVComparator.compareRows(Cell left,
Cell right)
Deprecated.
|
int |
CellComparator.compareRows(Cell leftCell,
Cell rightCell)
Lexographically compares the rows of two cells.
|
int |
CellComparatorImpl.compareTimestamps(Cell left,
Cell right) |
int |
KeyValue.KVComparator.compareTimestamps(Cell left,
Cell right)
Deprecated.
|
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)
Lexographically 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) |
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 |
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) |
static CellScanner |
CellUtil.createCellScanner(Cell[] 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) |
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 long |
PrivateCellUtil.estimatedSizeOfCell(Cell cell)
This is an estimate of the heap space occupied by a cell.
|
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) |
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) |
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) |
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) |
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) |
static boolean |
CellUtil.isPut(Cell cell) |
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 int |
KeyValueUtil.length(Cell cell)
Returns number of bytes this cell 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.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,
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
#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) |
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.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 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 removed in HBase-3.0
|
static void |
CellUtil.setTimestamp(Cell cell,
long ts)
Deprecated.
As of HBase-2.0. Will be removed 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)
Util 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 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)
Deprecated.
|
Constructor and Description |
---|
KeyValue(Cell c) |
Modifier and Type | Field and Description |
---|---|
protected NavigableMap<byte[],List<Cell>> |
Mutation.familyMap |
Modifier and Type | Method and Description |
---|---|
Cell |
Result.current() |
Cell |
Result.getColumnLatestCell(byte[] family,
byte[] qualifier)
The Cell for the most recent timestamp for a given column.
|
Cell |
Result.getColumnLatestCell(byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
The Cell for the most recent timestamp for a given column.
|
Cell[] |
Result.rawCells()
Return the array of Cells backing this Result instance.
|
Modifier and Type | Method and Description |
---|---|
List<Cell> |
Mutation.get(byte[] family,
byte[] qualifier)
Returns a list of all KeyValue objects with matching column family and qualifier.
|
List<Cell> |
Result.getColumnCells(byte[] family,
byte[] qualifier)
Return the Cells for the specific column.
|
NavigableMap<byte[],List<Cell>> |
Mutation.getFamilyCellMap()
Method for retrieving the put's familyMap
|
List<Cell> |
Result.listCells()
Create a sorted list of the Cell's in this result.
|
Modifier and Type | Method and Description |
---|---|
Increment |
Increment.add(Cell cell)
Add the specified KeyValue to this operation.
|
Append |
Append.add(Cell cell)
Add column and value to this Append operation.
|
Delete |
Delete.add(Cell cell)
Add an existing delete marker to this Delete object.
|
Put |
Put.add(Cell cell)
Add the specified KeyValue to this Put operation.
|
Delete |
Delete.addDeleteMarker(Cell kv)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Use
Delete.add(Cell)
instead |
protected int |
Result.binarySearch(Cell[] kvs,
byte[] family,
byte[] qualifier) |
protected int |
Result.binarySearch(Cell[] kvs,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Searches for the latest value for the specified column.
|
static Result |
Result.create(Cell[] cells)
Instantiate a Result with the specified array of KeyValues.
|
static Result |
Result.create(Cell[] cells,
Boolean exists,
boolean stale) |
static Result |
Result.create(Cell[] cells,
Boolean exists,
boolean stale,
boolean mayHaveMoreCellsInRow) |
Modifier and Type | Method and Description |
---|---|
static Result |
Result.create(List<Cell> cells)
Instantiate a Result with the specified List of KeyValues.
|
static Result |
Result.create(List<Cell> cells,
Boolean exists) |
static Result |
Result.create(List<Cell> cells,
Boolean exists,
boolean stale) |
static Result |
Result.create(List<Cell> cells,
Boolean exists,
boolean stale,
boolean mayHaveMoreCellsInRow) |
Increment |
Increment.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Increment.Increment(byte[], long, NavigableMap) instead |
Append |
Append.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Append.Append(byte[], long, NavigableMap) instead |
Delete |
Delete.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Delete.Delete(byte[], long, NavigableMap) instead |
Mutation |
Mutation.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Mutation.Mutation(byte[], long, NavigableMap) instead |
Put |
Put.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Use
Put.Put(byte[], long, NavigableMap) instead |
Constructor and Description |
---|
Append(byte[] row,
long ts,
NavigableMap<byte[],List<Cell>> familyMap)
Construct the Append with user defined data.
|
Delete(byte[] row,
long ts,
NavigableMap<byte[],List<Cell>> familyMap)
Construct the Delete with user defined data.
|
Increment(byte[] row,
long ts,
NavigableMap<byte[],List<Cell>> familyMap)
Construct the Increment with user defined data.
|
Mutation(byte[] row,
long ts,
NavigableMap<byte[],List<Cell>> familyMap)
Construct the mutation with user defined data.
|
Put(byte[] row,
long ts,
NavigableMap<byte[],List<Cell>> familyMap)
Construct the Put with user defined data.
|
Modifier and Type | Method and Description |
---|---|
Long |
LongColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
BigDecimal |
BigDecimalColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Double |
DoubleColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
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 |
---|---|
boolean |
ConstraintProcessor.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> e,
InternalScanner s,
Cell curRowCell,
boolean hasMore) |
Modifier and Type | Method and Description |
---|---|
default Cell |
RegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell)
Called after a new cell has been created during an increment operation, but before
it is committed to the WAL or memstore.
|
Modifier and Type | Method and Description |
---|---|
abstract T |
ColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
default Cell |
RegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell)
Called after a new cell has been created during an increment operation, but before
it is committed to the WAL or memstore.
|
default boolean |
RegionObserver.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> c,
InternalScanner s,
Cell curRowCell,
boolean hasMore)
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
|
default void |
RegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c,
Mutation mutation,
Cell cell,
byte[] byteNow,
Get get)
Deprecated.
Since hbase-2.0.0. No replacement. To be removed in hbase-3.0.0 and replaced
with something that doesn't expose IntefaceAudience.Private classes.
|
Modifier and Type | Method and Description |
---|---|
default void |
RegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called after the client performs a Get
|
default void |
RegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called before the client performs a Get
|
Modifier and Type | Method and Description |
---|---|
boolean |
DelegatingInternalScanner.next(List<Cell> result,
ScannerContext scannerContext) |
void |
WriteHeavyIncrementObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
Modifier and Type | Method and Description |
---|---|
Cell |
FilterWrapper.getNextCellHint(Cell currentCell) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
FilterList.getNextCellHint(Cell currentCell) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell cell) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell cell) |
Cell |
FilterListWithOR.getNextCellHint(Cell currentCell) |
Cell |
TimestampsFilter.getNextCellHint(Cell currentCell)
Pick the next cell that the scanner should seek to.
|
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
FilterListWithAND.getNextCellHint(Cell currentCell) |
abstract Cell |
Filter.getNextCellHint(Cell currentCell)
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
|
Cell |
FilterBase.getNextCellHint(Cell currentCell)
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null Cell.
|
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
FilterList.transformCell(Cell c) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterListBase.transformCell(Cell c)
For FilterList, we can consider a filter list as a node in a tree.
|
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
Give the filter a chance to transform the passed KeyValue.
|
Modifier and Type | Method and Description |
---|---|
protected int |
FilterListBase.compareCell(Cell a,
Cell b) |
protected boolean |
CompareFilter.compareFamily(CompareFilter.CompareOp compareOp,
ByteArrayComparable comparator,
Cell cell)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0.
Use
CompareFilter.compareFamily(CompareOperator, ByteArrayComparable, Cell) |
protected boolean |
CompareFilter.compareFamily(CompareOperator op,
ByteArrayComparable comparator,
Cell cell) |
protected boolean |
CompareFilter.compareQualifier(CompareFilter.CompareOp compareOp,
ByteArrayComparable comparator,
Cell cell)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0.
Use
CompareFilter.compareQualifier(CompareOperator, ByteArrayComparable, Cell) |
protected boolean |
CompareFilter.compareQualifier(CompareOperator op,
ByteArrayComparable comparator,
Cell cell) |
protected boolean |
CompareFilter.compareRow(CompareFilter.CompareOp compareOp,
ByteArrayComparable comparator,
Cell cell)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0.
Use
CompareFilter.compareRow(CompareOperator, ByteArrayComparable, Cell) |
protected boolean |
CompareFilter.compareRow(CompareOperator op,
ByteArrayComparable comparator,
Cell cell) |
protected boolean |
CompareFilter.compareValue(CompareFilter.CompareOp compareOp,
ByteArrayComparable comparator,
Cell cell)
Deprecated.
Since 2.0.0. Will be removed in 3.0.0.
Use
CompareFilter.compareValue(CompareOperator, ByteArrayComparable, Cell) |
protected boolean |
CompareFilter.compareValue(CompareOperator op,
ByteArrayComparable comparator,
Cell cell) |
Filter.ReturnCode |
FilterWrapper.filterCell(Cell c) |
Filter.ReturnCode |
MultiRowRangeFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
InclusiveStopFilter.filterCell(Cell c) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterCell(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterList.filterCell(Cell c) |
Filter.ReturnCode |
ColumnPrefixFilter.filterCell(Cell cell) |
Filter.ReturnCode |
ColumnRangeFilter.filterCell(Cell c) |
Filter.ReturnCode |
WhileMatchFilter.filterCell(Cell c) |
Filter.ReturnCode |
RandomRowFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnPaginationFilter.filterCell(Cell c) |
Filter.ReturnCode |
ValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnCountGetFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
FilterListWithOR.filterCell(Cell c) |
Filter.ReturnCode |
TimestampsFilter.filterCell(Cell c) |
Filter.ReturnCode |
SkipFilter.filterCell(Cell c) |
Filter.ReturnCode |
DependentColumnFilter.filterCell(Cell c) |
Filter.ReturnCode |
PrefixFilter.filterCell(Cell c) |
Filter.ReturnCode |
FirstKeyOnlyFilter.filterCell(Cell c) |
Filter.ReturnCode |
PageFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
QualifierFilter.filterCell(Cell c) |
Filter.ReturnCode |
KeyOnlyFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterCell(Cell c) |
Filter.ReturnCode |
FilterListWithAND.filterCell(Cell c) |
Filter.ReturnCode |
FamilyFilter.filterCell(Cell c) |
Filter.ReturnCode |
SingleColumnValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
RowFilter.filterCell(Cell v) |
Filter.ReturnCode |
Filter.filterCell(Cell c)
A way to filter based on the column family, column qualifier and/or the column value.
|
Filter.ReturnCode |
FuzzyRowFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnPrefixFilter.filterColumn(Cell cell) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterColumn(Cell cell) |
Filter.ReturnCode |
FilterWrapper.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
MultiRowRangeFilter.filterKeyValue(Cell ignored)
Deprecated.
|
Filter.ReturnCode |
InclusiveStopFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterList.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnPrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnRangeFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
WhileMatchFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
RandomRowFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnPaginationFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ValueFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnCountGetFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
TimestampsFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
SkipFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
DependentColumnFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
PrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FirstKeyOnlyFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
PageFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
QualifierFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
KeyOnlyFilter.filterKeyValue(Cell ignored)
Deprecated.
|
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FamilyFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
SingleColumnValueFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterListBase.filterKeyValue(Cell c) |
Filter.ReturnCode |
RowFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
Filter.filterKeyValue(Cell c)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
Instead use filterCell(Cell)
|
Filter.ReturnCode |
FuzzyRowFilter.filterKeyValue(Cell c)
Deprecated.
|
boolean |
FilterWrapper.filterRowKey(Cell cell) |
boolean |
MultiRowRangeFilter.filterRowKey(Cell firstRowCell) |
boolean |
InclusiveStopFilter.filterRowKey(Cell firstRowCell) |
boolean |
FilterList.filterRowKey(Cell firstRowCell) |
boolean |
ColumnPrefixFilter.filterRowKey(Cell cell) |
boolean |
ColumnRangeFilter.filterRowKey(Cell cell) |
boolean |
WhileMatchFilter.filterRowKey(Cell cell) |
boolean |
RandomRowFilter.filterRowKey(Cell firstRowCell) |
boolean |
ColumnPaginationFilter.filterRowKey(Cell cell) |
boolean |
ColumnCountGetFilter.filterRowKey(Cell cell) |
boolean |
ColumnValueFilter.filterRowKey(Cell cell) |
boolean |
FilterListWithOR.filterRowKey(Cell firstRowCell) |
boolean |
TimestampsFilter.filterRowKey(Cell cell) |
boolean |
SkipFilter.filterRowKey(Cell cell) |
boolean |
PrefixFilter.filterRowKey(Cell firstRowCell) |
boolean |
FirstKeyOnlyFilter.filterRowKey(Cell cell) |
boolean |
PageFilter.filterRowKey(Cell cell) |
boolean |
KeyOnlyFilter.filterRowKey(Cell cell) |
boolean |
MultipleColumnPrefixFilter.filterRowKey(Cell cell) |
boolean |
FilterListWithAND.filterRowKey(Cell firstRowCell) |
boolean |
SingleColumnValueFilter.filterRowKey(Cell cell) |
boolean |
CompareFilter.filterRowKey(Cell cell) |
boolean |
RowFilter.filterRowKey(Cell firstRowCell) |
abstract boolean |
Filter.filterRowKey(Cell firstRowCell)
Filters a row based on the row key.
|
boolean |
FilterBase.filterRowKey(Cell cell) |
Cell |
FilterWrapper.getNextCellHint(Cell currentCell) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
FilterList.getNextCellHint(Cell currentCell) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell cell) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell cell) |
Cell |
FilterListWithOR.getNextCellHint(Cell currentCell) |
Cell |
TimestampsFilter.getNextCellHint(Cell currentCell)
Pick the next cell that the scanner should seek to.
|
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
FilterListWithAND.getNextCellHint(Cell currentCell) |
abstract Cell |
Filter.getNextCellHint(Cell currentCell)
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
|
Cell |
FilterBase.getNextCellHint(Cell currentCell)
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null Cell.
|
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
FilterList.transformCell(Cell c) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterListBase.transformCell(Cell c)
For FilterList, we can consider a filter list as a node in a tree.
|
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
Give the filter a chance to transform the passed KeyValue.
|
Modifier and Type | Method and Description |
---|---|
void |
FilterWrapper.filterRowCells(List<Cell> kvs) |
void |
FilterList.filterRowCells(List<Cell> cells)
Filters that never filter by modifying the returned List of Cells can inherit this
implementation that does nothing.
|
void |
DependentColumnFilter.filterRowCells(List<Cell> kvs) |
void |
SingleColumnValueExcludeFilter.filterRowCells(List<Cell> kvs) |
void |
FilterListBase.filterRowCells(List<Cell> cells)
Filters that never filter by modifying the returned List of Cells can inherit this
implementation that does nothing.
|
abstract void |
Filter.filterRowCells(List<Cell> kvs)
Chance to alter the list of Cells to be submitted.
|
void |
FilterBase.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
FilterWrapper.FilterRowRetCode |
FilterWrapper.filterRowCellsWithRet(List<Cell> kvs) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
HalfStoreFileReader.splitCell |
Modifier and Type | Method and Description |
---|---|
Optional<Cell> |
HalfStoreFileReader.getFirstKey() |
Optional<Cell> |
HalfStoreFileReader.getLastKey() |
Optional<Cell> |
HalfStoreFileReader.midKey() |
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 |
RowIndexSeekerV1.getCell() |
Cell |
DataBlockEncoder.EncodedSeeker.getCell() |
Cell |
FastDiffDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
RowIndexCodecV1.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DiffKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block)
Return first key in block as a cell.
|
Cell |
RowIndexSeekerV1.getKey() |
Cell |
DataBlockEncoder.EncodedSeeker.getKey()
From the current position creates a cell using the key part
of the current buffer
|
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 |
RowIndexSeekerV1.compareKey(CellComparator comparator,
Cell key) |
int |
DataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator,
Cell key)
Compare the given key against the current key
|
int |
RowIndexCodecV1.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
DataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
int |
FastDiffDeltaEncoder.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 |
PrefixKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
RowIndexSeekerV1.seekToKeyInBlock(Cell seekCell,
boolean seekBefore) |
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 |
RowIndexEncoderV1.write(Cell cell) |
int |
NoneEncoder.write(Cell cell) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
HFileWriterImpl.firstCellInBlock
First cell in a block.
|
protected Cell |
HFileWriterImpl.lastCell
The Cell previously appended.
|
protected Cell |
HFileReaderImpl.HFileScannerImpl.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.
|
Modifier and Type | Method and Description |
---|---|
Cell |
HFileReaderImpl.HFileScannerImpl.getCell() |
Cell |
HFileReaderImpl.EncodedScanner.getCell() |
Cell |
HFileScanner.getCell() |
protected Cell |
HFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(HFileBlock curBlock) |
protected Cell |
HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(HFileBlock curBlock) |
Cell |
HFileReaderImpl.HFileScannerImpl.getKey() |
Cell |
HFileReaderImpl.EncodedScanner.getKey() |
Cell |
HFileScanner.getKey()
Gets the current key in the form of a cell.
|
static Cell |
HFileWriterImpl.getMidpoint(CellComparator comparator,
Cell left,
Cell right)
Try to return a Cell that falls between
left and
right but that is shorter; i.e. |
Cell |
HFileReaderImpl.HFileScannerImpl.getNextIndexedKey() |
Cell |
BlockWithScanInfo.getNextIndexedKey() |
Cell |
HFileScanner.getNextIndexedKey() |
Cell |
CompoundBloomFilterWriter.getPrevCell() |
Modifier and Type | Method and Description |
---|---|
Optional<Cell> |
HFileReaderImpl.getFirstKey() |
Optional<Cell> |
HFile.Reader.getFirstKey() |
Optional<Cell> |
HFileReaderImpl.getLastKey() |
Optional<Cell> |
HFile.Reader.getLastKey() |
Optional<Cell> |
HFileReaderImpl.midKey() |
Optional<Cell> |
HFile.Reader.midKey() |
Modifier and Type | Method and Description |
---|---|
void |
HFileWriterImpl.append(Cell cell)
Add key/value to file.
|
void |
CompoundBloomFilterWriter.append(Cell cell) |
protected int |
HFileReaderImpl.HFileScannerImpl.blockSeek(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 boolean |
HFileWriterImpl.checkKey(Cell cell)
Checks that the given Cell's key does not violate the key order.
|
int |
HFileReaderImpl.HFileScannerImpl.compareKey(CellComparator comparator,
Cell key) |
int |
HFileReaderImpl.EncodedScanner.compareKey(CellComparator comparator,
Cell key) |
boolean |
CompoundBloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type) |
int |
HFileDataBlockEncoderImpl.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
NoOpDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
HFileDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
static Cell |
HFileWriterImpl.getMidpoint(CellComparator comparator,
Cell left,
Cell right)
Try to return a Cell that falls between
left and
right but that is shorter; i.e. |
protected int |
HFileReaderImpl.HFileScannerImpl.loadBlockAndSeekToKey(HFileBlock seekToBlock,
Cell nextIndexedKey,
boolean rewind,
Cell key,
boolean seekBefore) |
protected int |
HFileReaderImpl.EncodedScanner.loadBlockAndSeekToKey(HFileBlock seekToBlock,
Cell nextIndexedKey,
boolean rewind,
Cell key,
boolean seekBefore) |
int |
HFileReaderImpl.HFileScannerImpl.reseekTo(Cell key) |
int |
HFileScanner.reseekTo(Cell cell)
Reseek to or just before the passed
cell . |
boolean |
HFileReaderImpl.HFileScannerImpl.seekBefore(Cell key) |
boolean |
HFileScanner.seekBefore(Cell cell)
Consider the cell stream of all the cells in the file,
c[0] .. |
int |
HFileReaderImpl.HFileScannerImpl.seekTo(Cell key) |
int |
HFileScanner.seekTo(Cell cell)
SeekTo or just before the passed
cell . |
int |
HFileReaderImpl.HFileScannerImpl.seekTo(Cell key,
boolean rewind)
An internal API function.
|
Constructor and Description |
---|
BlockWithScanInfo(HFileBlock hFileBlock,
Cell nextIndexedKey) |
Modifier and Type | Method and Description |
---|---|
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength) |
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength,
List<Tag> tags) |
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength,
String visExpression)
Deprecated.
|
static Cell |
Import.filterKv(Filter filter,
Cell c)
Attempt to filter out the keyvalue
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.NullWritable,Cell> |
HFileInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context) |
org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,Cell> |
HFileOutputFormat2.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) |
Modifier and Type | Method and Description |
---|---|
protected void |
Import.Importer.addPutToKv(Put put,
Cell kv) |
KeyValue |
CellSerialization.CellDeserializer.deserialize(Cell ignore) |
protected boolean |
WALPlayer.WALMapper.filter(org.apache.hadoop.mapreduce.Mapper.Context context,
Cell cell) |
static Cell |
Import.filterKv(Filter filter,
Cell c)
Attempt to filter out the keyvalue
|
int |
Import.CellWritableComparablePartitioner.getPartition(Import.CellWritableComparable key,
Cell value,
int numPartitions) |
void |
CellSerialization.CellSerializer.serialize(Cell kv) |
Modifier and Type | Method and Description |
---|---|
CellSerialization.CellDeserializer |
CellSerialization.getDeserializer(Class<Cell> t) |
CellSerialization.CellSerializer |
CellSerialization.getSerializer(Class<Cell> c) |
protected void |
CellSortReducer.reduce(ImmutableBytesWritable row,
Iterable<Cell> kvs,
org.apache.hadoop.mapreduce.Reducer.Context context) |
protected void |
Import.CellReducer.reduce(Import.CellWritableComparable row,
Iterable<Cell> kvs,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Constructor and Description |
---|
CellWritableComparable(Cell kv) |
Modifier and Type | Method and Description |
---|---|
static Cell |
MobUtils.createMobRefCell(Cell cell,
byte[] fileName,
byte[] refCellTags) |
static Cell |
MobUtils.createMobRefCell(Cell cell,
byte[] fileName,
Tag tableNameTag)
Creates a mob reference KeyValue.
|
static Cell |
MobUtils.createMobRefDeleteMarker(Cell cell)
Creates a mob ref delete marker.
|
Cell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks)
Reads a cell from the mob file.
|
Cell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks,
long readPt)
Reads a cell from the mob file.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
MobUtils.createMobRefCell(Cell cell,
byte[] fileName,
byte[] refCellTags) |
static Cell |
MobUtils.createMobRefCell(Cell cell,
byte[] fileName,
Tag tableNameTag)
Creates a mob reference KeyValue.
|
static Cell |
MobUtils.createMobRefDeleteMarker(Cell cell)
Creates a mob ref delete marker.
|
static String |
MobUtils.getMobFileName(Cell cell)
Gets the mob file name from the mob ref cell.
|
static int |
MobUtils.getMobValueLength(Cell cell)
Gets the mob value length from the mob ref cell.
|
static Tag |
MobUtils.getTableNameTag(Cell cell)
Gets the table name tag.
|
static boolean |
MobUtils.hasValidMobRefCellValue(Cell cell)
Indicates whether the current mob ref cell has a valid value.
|
static boolean |
MobUtils.isMobReferenceCell(Cell cell)
Whether the current cell is a mob reference cell.
|
Cell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks)
Reads a cell from the mob file.
|
Cell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks,
long readPt)
Reads a cell from the mob file.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
ProtobufUtil.toCell(ExtendedCellBuilder cellBuilder,
CellProtos.Cell cell) |
Modifier and Type | Method and Description |
---|---|
static CellProtos.Cell |
ProtobufUtil.toCell(Cell kv) |
Modifier and Type | Method and Description |
---|---|
protected static String |
QuotaTableUtil.extractSnapshotNameFromSizeCell(Cell c) |
Modifier and Type | Class and Description |
---|---|
class |
ByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset
|
class |
NoTagByteBufferChunkKeyValue
ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
|
Modifier and Type | Field and Description |
---|---|
protected Cell |
SegmentScanner.current |
static Cell |
KeyValueScanner.NO_NEXT_INDEXED_KEY
The byte array represents for NO_NEXT_INDEXED_KEY;
The actual value is irrelevant because this is always compared by reference.
|
Modifier and Type | Field and Description |
---|---|
protected Iterator<Cell> |
SegmentScanner.iter |
Modifier and Type | Method and Description |
---|---|
Cell |
CellSet.ceiling(Cell e) |
Cell |
CellFlatMap.ceilingKey(Cell k) |
Cell |
ImmutableMemStoreLAB.copyCellInto(Cell cell) |
Cell |
MemStoreLABImpl.copyCellInto(Cell cell) |
Cell |
MemStoreLAB.copyCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
CellSet.first() |
Cell |
CellFlatMap.firstKey() |
Cell |
CellSet.floor(Cell e) |
Cell |
CellFlatMap.floorKey(Cell k) |
Cell |
ImmutableMemStoreLAB.forceCopyOfBigCellInto(Cell cell)
The process of merging assumes all cells are allocated on mslab.
|
Cell |
MemStoreLABImpl.forceCopyOfBigCellInto(Cell cell)
When a cell's size is too big (bigger than maxAlloc),
copyCellInto does not allocate it on MSLAB.
|
Cell |
MemStoreLAB.forceCopyOfBigCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
CellSet.get(Cell kv) |
Cell |
CellFlatMap.get(Object o) |
protected Cell |
CellChunkMap.getCell(int i) |
protected Cell |
CellArrayMap.getCell(int i) |
protected abstract Cell |
CellFlatMap.getCell(int i) |
protected Cell |
AbstractMemStore.getLowest(Cell a,
Cell b) |
Cell |
SegmentScanner.getNextIndexedKey() |
Cell |
StoreScanner.getNextIndexedKey() |
Cell |
NonLazyKeyValueScanner.getNextIndexedKey() |
Cell |
KeyValueHeap.getNextIndexedKey() |
Cell |
StoreFileScanner.getNextIndexedKey() |
Cell |
KeyValueScanner.getNextIndexedKey() |
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
Cell |
CellSet.higher(Cell e) |
Cell |
CellFlatMap.higherKey(Cell k) |
Cell |
CompositeImmutableSegment.last() |
Cell |
CellSet.last() |
Cell |
Segment.last() |
Cell |
CellFlatMap.lastKey() |
Cell |
CellSet.lower(Cell e) |
Cell |
CellFlatMap.lowerKey(Cell k) |
Cell |
CompositeImmutableSegment.maybeCloneWithAllocator(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
|
Cell |
Segment.maybeCloneWithAllocator(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.
|
Cell |
MemStoreMergerSegmentsIterator.next() |
Cell |
SegmentScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
MemStoreCompactorSegmentsIterator.next() |
Cell |
SnapshotSegmentScanner.next() |
Cell |
ReversedKeyValueHeap.next() |
Cell |
KeyValueHeap.next() |
Cell |
StoreFileScanner.next() |
Cell |
KeyValueScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
SegmentScanner.peek()
Look at the next Cell in this scanner, but do not iterate the scanner
|
Cell |
SnapshotSegmentScanner.peek() |
Cell |
StoreScanner.peek() |
Cell |
KeyValueHeap.peek() |
Cell |
StoreFileScanner.peek() |
Cell |
KeyValueScanner.peek()
Look at the next Cell in this scanner, but do not iterate scanner.
|
Cell |
CellSet.pollFirst() |
Cell |
CellSet.pollLast() |
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Cell |
CellFlatMap.put(Cell k,
Cell v) |
Cell |
CellFlatMap.remove(Object o) |
Cell |
HMobStore.resolve(Cell reference,
boolean cacheBlocks)
Reads the cell from the mob file, and the read point does not count.
|
Cell |
HMobStore.resolve(Cell reference,
boolean cacheBlocks,
long readPt,
boolean readEmptyValueOnMobCellMiss)
Reads the cell from the mob file.
|
Modifier and Type | Method and Description |
---|---|
Map.Entry<Cell,Cell> |
CellFlatMap.ceilingEntry(Cell k) |
Map.Entry<Cell,Cell> |
CellFlatMap.ceilingEntry(Cell k) |
Comparator<? super Cell> |
CellFlatMap.comparator() |
Comparator<? super Cell> |
CellSet.comparator() |
Iterator<Cell> |
CellSet.descendingIterator() |
NavigableSet<Cell> |
CellFlatMap.descendingKeySet() |
NavigableMap<Cell,Cell> |
CellFlatMap.descendingMap() |
NavigableMap<Cell,Cell> |
CellFlatMap.descendingMap() |
NavigableSet<Cell> |
CellSet.descendingSet() |
Set<Map.Entry<Cell,Cell>> |
CellFlatMap.entrySet() |
Set<Map.Entry<Cell,Cell>> |
CellFlatMap.entrySet() |
Map.Entry<Cell,Cell> |
CellFlatMap.firstEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.firstEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.floorEntry(Cell k) |
Map.Entry<Cell,Cell> |
CellFlatMap.floorEntry(Cell k) |
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
List<Cell> |
Region.get(Get get,
boolean withCoprocessor)
Do a get based on the get parameter.
|
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor,
long nonceGroup,
long nonce) |
Optional<Cell> |
StoreFileReader.getFirstKey() |
Optional<Cell> |
StoreFile.getFirstKey()
Get the first key in this store file.
|
Optional<Cell> |
HStoreFile.getFirstKey() |
protected Iterator<Cell> |
SegmentScanner.getIterator(Cell cell) |
Optional<Cell> |
StoreFileReader.getLastKey() |
Optional<Cell> |
StoreFile.getLastKey()
Get the last key in this store file.
|
Optional<Cell> |
HStoreFile.getLastKey() |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell toKey,
boolean inclusive) |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell toKey,
boolean inclusive) |
SortedSet<Cell> |
CompositeImmutableSegment.headSet(Cell firstKeyOnRow) |
SortedSet<Cell> |
CellSet.headSet(Cell toElement) |
SortedSet<Cell> |
Segment.headSet(Cell firstKeyOnRow) |
NavigableSet<Cell> |
CellSet.headSet(Cell toElement,
boolean inclusive) |
Map.Entry<Cell,Cell> |
CellFlatMap.higherEntry(Cell k) |
Map.Entry<Cell,Cell> |
CellFlatMap.higherEntry(Cell k) |
Iterator<Cell> |
CompositeImmutableSegment.iterator() |
Iterator<Cell> |
CellSet.iterator() |
Iterator<Cell> |
Segment.iterator() |
NavigableSet<Cell> |
CellFlatMap.keySet() |
Map.Entry<Cell,Cell> |
CellFlatMap.lastEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.lastEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.lowerEntry(Cell k) |
Map.Entry<Cell,Cell> |
CellFlatMap.lowerEntry(Cell k) |
Optional<Cell> |
StoreFileReader.midKey() |
NavigableSet<Cell> |
CellFlatMap.navigableKeySet() |
Map.Entry<Cell,Cell> |
CellFlatMap.pollFirstEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.pollFirstEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.pollLastEntry() |
Map.Entry<Cell,Cell> |
CellFlatMap.pollLastEntry() |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell fromKey,
boolean fromInclusive,
Cell toKey,
boolean toInclusive) |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell fromKey,
boolean fromInclusive,
Cell toKey,
boolean toInclusive) |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell k1,
Cell k2) |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell k1,
Cell k2) |
NavigableSet<Cell> |
CellSet.subSet(Cell fromElement,
boolean fromInclusive,
Cell toElement,
boolean toInclusive) |
SortedSet<Cell> |
CellSet.subSet(Cell fromElement,
Cell toElement) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell fromKey,
boolean inclusive) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell fromKey,
boolean inclusive) |
protected SortedSet<Cell> |
CompositeImmutableSegment.tailSet(Cell firstCell)
Returns a subset of the segment cell set, which starts with the given cell
|
SortedSet<Cell> |
CellSet.tailSet(Cell fromElement) |
protected SortedSet<Cell> |
Segment.tailSet(Cell firstCell)
Returns a subset of the segment cell set, which starts with the given cell
|
NavigableSet<Cell> |
CellSet.tailSet(Cell fromElement,
boolean inclusive) |
Collection<Cell> |
CellFlatMap.values() |
Modifier and Type | Method and Description |
---|---|
boolean |
CellSet.add(Cell e) |
void |
MutableSegment.add(Cell cell,
boolean mslabUsed,
MemStoreSizing memStoreSizing)
Adds the given cell into the segment
|
void |
AbstractMemStore.add(Cell cell,
MemStoreSizing memstoreSizing) |
void |
MemStore.add(Cell cell,
MemStoreSizing memstoreSizing)
Write an update
|
void |
HStore.add(Cell cell,
MemStoreSizing memstoreSizing)
Adds a value to the memstore
|
void |
DateTieredMultiFileWriter.append(Cell cell) |
void |
StripeMultiFileWriter.BoundaryMultiWriter.append(Cell cell) |
void |
StripeMultiFileWriter.SizeMultiWriter.append(Cell cell) |
void |
StoreFileWriter.append(Cell cell) |
void |
CellSink.append(Cell cell)
Append the given cell
|
boolean |
SegmentScanner.backwardSeek(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 KeyValue
|
boolean |
ReversedKeyValueHeap.backwardSeek(Cell seekKey) |
boolean |
ReversedStoreScanner.backwardSeek(Cell key) |
boolean |
NonReversedNonLazyKeyValueScanner.backwardSeek(Cell key) |
boolean |
StoreFileScanner.backwardSeek(Cell key) |
boolean |
KeyValueScanner.backwardSeek(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 KeyValue
|
Cell |
CellSet.ceiling(Cell e) |
Map.Entry<Cell,Cell> |
CellFlatMap.ceilingEntry(Cell k) |
Cell |
CellFlatMap.ceilingKey(Cell k) |
protected void |
StoreScanner.checkScanOrder(Cell prevKV,
Cell kv,
CellComparator comparator)
Check whether scan as expected order
|
protected void |
ReversedStoreScanner.checkScanOrder(Cell prevKV,
Cell kv,
CellComparator comparator) |
int |
CompositeImmutableSegment.compare(Cell left,
Cell right) |
int |
Segment.compare(Cell left,
Cell right) |
int |
KeyValueHeap.KVScannerComparator.compare(Cell left,
Cell right)
Compares two KeyValue
|
int |
CompositeImmutableSegment.compareRows(Cell left,
Cell right) |
int |
Segment.compareRows(Cell left,
Cell right) |
Cell |
ImmutableMemStoreLAB.copyCellInto(Cell cell) |
Cell |
MemStoreLABImpl.copyCellInto(Cell cell) |
Cell |
MemStoreLAB.copyCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
Cell kv,
boolean forward) |
Cell |
CellSet.floor(Cell e) |
Map.Entry<Cell,Cell> |
CellFlatMap.floorEntry(Cell k) |
Cell |
CellFlatMap.floorKey(Cell k) |
Cell |
ImmutableMemStoreLAB.forceCopyOfBigCellInto(Cell cell)
The process of merging assumes all cells are allocated on mslab.
|
Cell |
MemStoreLABImpl.forceCopyOfBigCellInto(Cell cell)
When a cell's size is too big (bigger than maxAlloc),
copyCellInto does not allocate it on MSLAB.
|
Cell |
MemStoreLAB.forceCopyOfBigCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
CellSet.get(Cell kv) |
protected Iterator<Cell> |
SegmentScanner.getIterator(Cell cell) |
protected Cell |
AbstractMemStore.getLowest(Cell a,
Cell b) |
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.headMap(Cell toKey,
boolean inclusive) |
SortedSet<Cell> |
CompositeImmutableSegment.headSet(Cell firstKeyOnRow) |
SortedSet<Cell> |
CellSet.headSet(Cell toElement) |
SortedSet<Cell> |
Segment.headSet(Cell firstKeyOnRow) |
NavigableSet<Cell> |
CellSet.headSet(Cell toElement,
boolean inclusive) |
protected long |
Segment.heapSizeChange(Cell cell,
boolean succ) |
Cell |
CellSet.higher(Cell e) |
Map.Entry<Cell,Cell> |
CellFlatMap.higherEntry(Cell k) |
Cell |
CellFlatMap.higherKey(Cell k) |
void |
TimeRangeTracker.includeTimestamp(Cell cell)
Update the current TimestampRange to include the timestamp from
cell . |
protected void |
CompositeImmutableSegment.internalAdd(Cell cell,
boolean mslabUsed,
MemStoreSizing memstoreSizing) |
protected void |
Segment.internalAdd(Cell cell,
boolean mslabUsed,
MemStoreSizing memstoreSizing) |
Cell |
CellSet.lower(Cell e) |
Map.Entry<Cell,Cell> |
CellFlatMap.lowerEntry(Cell k) |
Cell |
CellFlatMap.lowerKey(Cell k) |
Cell |
CompositeImmutableSegment.maybeCloneWithAllocator(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
|
Cell |
Segment.maybeCloneWithAllocator(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 long |
Segment.offHeapSizeChange(Cell cell,
boolean succ) |
boolean |
StoreFileReader.passesGeneralRowColBloomFilter(Cell cell)
A method for checking Bloom filters.
|
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
boolean |
RegionCoprocessorHost.postScannerFilterRow(InternalScanner s,
Cell curRowCell)
This will be called by the scan flow when the current scanned row is being filtered out by the
filter.
|
boolean |
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation,
Cell kv,
byte[] byteNow,
Get get)
Deprecated.
In hbase-2.0.0. Will be removed in hbase-3.0.0. Added explicitly for a single
Coprocessor for its needs only. Will be removed.
|
Cell |
CellFlatMap.put(Cell k,
Cell v) |
boolean |
SegmentScanner.requestSeek(Cell c,
boolean forward,
boolean useBloom) |
boolean |
ReversedKeyValueHeap.requestSeek(Cell key,
boolean forward,
boolean useBloom) |
boolean |
NonLazyKeyValueScanner.requestSeek(Cell kv,
boolean forward,
boolean useBloom) |
boolean |
KeyValueHeap.requestSeek(Cell key,
boolean forward,
boolean useBloom)
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.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. |
boolean |
StoreFileScanner.requestSeek(Cell kv,
boolean forward,
boolean useBloom)
Pretend we have done a seek but don't do it yet, if possible.
|
boolean |
KeyValueScanner.requestSeek(Cell kv,
boolean forward,
boolean useBloom)
Similar to
KeyValueScanner.seek(org.apache.hadoop.hbase.Cell) (or KeyValueScanner.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. |
boolean |
SegmentScanner.reseek(Cell cell)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
SnapshotSegmentScanner.reseek(Cell seekCell) |
boolean |
ReversedKeyValueHeap.reseek(Cell seekKey) |
boolean |
StoreScanner.reseek(Cell kv) |
boolean |
ReversedStoreScanner.reseek(Cell kv) |
boolean |
KeyValueHeap.reseek(Cell seekKey)
This function is identical to the
KeyValueHeap.seek(Cell) function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey). |
boolean |
StoreFileScanner.reseek(Cell key) |
boolean |
KeyValueScanner.reseek(Cell key)
Reseek the scanner at or after the specified KeyValue.
|
Cell |
HMobStore.resolve(Cell reference,
boolean cacheBlocks)
Reads the cell from the mob file, and the read point does not count.
|
Cell |
HMobStore.resolve(Cell reference,
boolean cacheBlocks,
long readPt,
boolean readEmptyValueOnMobCellMiss)
Reads the cell from the mob file.
|
protected void |
HRegion.restoreEdit(HStore s,
Cell cell,
MemStoreSizing memstoreAccounting)
Used by tests
|
protected void |
StripeMultiFileWriter.sanityCheckLeft(byte[] left,
Cell cell)
Subclasses can call this method to make sure the first KV is within multi-writer range.
|
protected void |
StripeMultiFileWriter.sanityCheckRight(byte[] right,
Cell cell)
Subclasses can call this method to make sure the last KV is within multi-writer range.
|
boolean |
SegmentScanner.seek(Cell cell)
Seek the scanner at or after the specified Cell.
|
boolean |
SnapshotSegmentScanner.seek(Cell seekCell) |
boolean |
ReversedKeyValueHeap.seek(Cell seekKey) |
boolean |
StoreScanner.seek(Cell key) |
boolean |
ReversedStoreScanner.seek(Cell key) |
boolean |
KeyValueHeap.seek(Cell seekKey)
Seeks all scanners at or below the specified seek key.
|
boolean |
StoreFileScanner.seek(Cell key) |
boolean |
KeyValueScanner.seek(Cell key)
Seek the scanner at or after the specified KeyValue.
|
protected boolean |
StoreScanner.seekAsDirection(Cell kv)
Do a reseek in a normal StoreScanner(scan forward)
|
protected boolean |
ReversedStoreScanner.seekAsDirection(Cell kv)
Do a backwardSeek in a reversed StoreScanner(scan backward)
|
static boolean |
StoreFileScanner.seekAtOrAfter(HFileScanner s,
Cell k) |
protected void |
StoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek)
Seek the specified scanners with the given key
|
protected void |
ReversedStoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek) |
protected boolean |
StoreScanner.seekToNextRow(Cell c) |
protected boolean |
ReversedStoreScanner.seekToNextRow(Cell kv) |
boolean |
SegmentScanner.seekToPreviousRow(Cell cell)
Seek the scanner at the first Cell of the row which is the previous row
of specified key
|
boolean |
ReversedKeyValueHeap.seekToPreviousRow(Cell seekKey) |
boolean |
ReversedStoreScanner.seekToPreviousRow(Cell key) |
boolean |
NonReversedNonLazyKeyValueScanner.seekToPreviousRow(Cell key) |
boolean |
StoreFileScanner.seekToPreviousRow(Cell originalKey) |
boolean |
KeyValueScanner.seekToPreviousRow(Cell key)
Seek the scanner at the first Cell of the row which is the previous row
of specified key
|
protected void |
StoreFileScanner.setCurrentCell(Cell newVal) |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell fromKey,
boolean fromInclusive,
Cell toKey,
boolean toInclusive) |
NavigableMap<Cell,Cell> |
CellFlatMap.subMap(Cell k1,
Cell k2) |
NavigableSet<Cell> |
CellSet.subSet(Cell fromElement,
boolean fromInclusive,
Cell toElement,
boolean toInclusive) |
SortedSet<Cell> |
CellSet.subSet(Cell fromElement,
Cell toElement) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell k) |
NavigableMap<Cell,Cell> |
CellFlatMap.tailMap(Cell fromKey,
boolean inclusive) |
protected SortedSet<Cell> |
CompositeImmutableSegment.tailSet(Cell firstCell)
Returns a subset of the segment cell set, which starts with the given cell
|
SortedSet<Cell> |
CellSet.tailSet(Cell fromElement) |
protected SortedSet<Cell> |
Segment.tailSet(Cell firstCell)
Returns a subset of the segment cell set, which starts with the given cell
|
NavigableSet<Cell> |
CellSet.tailSet(Cell fromElement,
boolean inclusive) |
void |
StoreFileWriter.trackTimestamps(Cell cell)
Record the earlest Put timestamp.
|
protected boolean |
StoreScanner.trySkipToNextColumn(Cell cell)
|
protected boolean |
StoreScanner.trySkipToNextRow(Cell cell)
See if we should actually SEEK or rather just SKIP to the next Cell (see HBASE-13109).
|
Iterator<HStoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. |
Iterator<HStoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
protected void |
CompositeImmutableSegment.updateMetaInfo(Cell cellToAdd,
boolean succ,
boolean mslabUsed,
MemStoreSizing memstoreSizing) |
protected void |
Segment.updateMetaInfo(Cell cellToAdd,
boolean succ,
boolean mslabUsed,
MemStoreSizing memstoreSizing) |
protected void |
Segment.updateMetaInfo(Cell cellToAdd,
boolean succ,
MemStoreSizing memstoreSizing) |
void |
MutableSegment.upsert(Cell cell,
long readpoint,
MemStoreSizing memStoreSizing) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractMemStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing) |
void |
MemStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing)
Write the updates
|
void |
HStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing)
Adds the specified value to the memstore
|
boolean |
CellSet.addAll(Collection<? extends Cell> c) |
void |
HRegion.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now)
Check the collection of families for valid timestamps
|
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
default boolean |
InternalScanner.next(List<Cell> result)
Grab the next row's worth of values.
|
boolean |
MobStoreScanner.next(List<Cell> outResult,
ScannerContext ctx)
Firstly reads the cells from the HBase.
|
boolean |
StoreScanner.next(List<Cell> outResult,
ScannerContext scannerContext)
Get the next row of values from this Store.
|
boolean |
ReversedMobStoreScanner.next(List<Cell> outResult,
ScannerContext ctx)
Firstly reads the cells from the HBase.
|
boolean |
KeyValueHeap.next(List<Cell> result,
ScannerContext scannerContext)
Gets the next row of keys from the top-most scanner.
|
boolean |
InternalScanner.next(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
boolean |
RegionScanner.nextRaw(List<Cell> result)
Grab the next row's worth of values.
|
boolean |
RegionScanner.nextRaw(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
boolean |
RegionCoprocessorHost.preGet(Get get,
List<Cell> results)
Supports Coprocessor 'bypass'.
|
void |
HRegion.prepareDeleteTimestamps(Mutation mutation,
Map<byte[],List<Cell>> familyMap,
byte[] byteNow)
Set up correct timestamps in the KVs in Delete object.
|
void |
CellFlatMap.putAll(Map<? extends Cell,? extends Cell> map) |
void |
CellFlatMap.putAll(Map<? extends Cell,? extends Cell> map) |
void |
AbstractMemStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing) |
void |
MemStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing)
Update or insert the specified cells.
|
void |
HStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing)
Adds or replaces the specified KeyValues.
|
Constructor and Description |
---|
CellArrayMap(Comparator<? super Cell> comparator,
Cell[] b,
int min,
int max,
boolean descending) |
Constructor and Description |
---|
CellArrayMap(Comparator<? super Cell> comparator,
Cell[] b,
int min,
int max,
boolean descending) |
CellChunkMap(Comparator<? super Cell> comparator,
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 Cell> comparator,
int min,
int max,
boolean d) |
Constructor and Description |
---|
ParallelSeekHandler(KeyValueScanner scanner,
Cell keyValue,
long readPoint,
CountDownLatch latch) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
ScanQueryMatcher.currentRow
Row the query is on
|
protected Cell |
ScanDeleteTracker.deleteCell |
protected Cell |
ScanQueryMatcher.startKey
Key to seek to in memstore and StoreFiles
|
Modifier and Type | Method and Description |
---|---|
protected static Cell |
ScanQueryMatcher.createStartKeyFromRow(byte[] startRow,
ScanInfo scanInfo) |
Cell |
ScanQueryMatcher.currentRow() |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell cell) |
Cell |
UserScanQueryMatcher.getNextKeyHint(Cell cell) |
Cell |
CompactionScanQueryMatcher.getNextKeyHint(Cell cell) |
abstract Cell |
ScanQueryMatcher.getNextKeyHint(Cell cell)
Delegate to
Filter.getNextCellHint(Cell) . |
Cell |
ScanQueryMatcher.getStartKey() |
Modifier and Type | Method and Description |
---|---|
void |
ScanDeleteTracker.add(Cell cell)
Add the specified Cell to the list of deletes to check against for this row operation.
|
void |
NewVersionBehaviorTracker.add(Cell cell) |
void |
DeleteTracker.add(Cell cell)
Add the specified cell to the list of deletes to check against for this row operation.
|
void |
NewVersionBehaviorTracker.DeleteVersionsNode.addVersionDelete(Cell cell) |
ScanQueryMatcher.MatchCode |
ScanWildcardColumnTracker.checkColumn(Cell cell,
byte type)
Checks if the column is present in the list of requested columns by returning the match code
instance.
|
ScanQueryMatcher.MatchCode |
ExplicitColumnTracker.checkColumn(Cell cell,
byte type)
Checks if the column is present in the list of requested columns by returning the match code
instance.
|
ScanQueryMatcher.MatchCode |
NewVersionBehaviorTracker.checkColumn(Cell cell,
byte type) |
ScanQueryMatcher.MatchCode |
ColumnTracker.checkColumn(Cell cell,
byte type)
Checks if the column is present in the list of requested columns by returning the match code
instance.
|
protected ScanQueryMatcher.MatchCode |
ScanQueryMatcher.checkDeleted(DeleteTracker deletes,
Cell cell) |
ScanQueryMatcher.MatchCode |
ScanWildcardColumnTracker.checkVersions(Cell cell,
long timestamp,
byte type,
boolean ignoreCount)
Keeps track of the number of versions for the columns asked for.
|
ScanQueryMatcher.MatchCode |
ExplicitColumnTracker.checkVersions(Cell cell,
long timestamp,
byte type,
boolean ignoreCount) |
ScanQueryMatcher.MatchCode |
NewVersionBehaviorTracker.checkVersions(Cell cell,
long timestamp,
byte type,
boolean ignoreCount) |
ScanQueryMatcher.MatchCode |
ColumnTracker.checkVersions(Cell cell,
long timestamp,
byte type,
boolean ignoreCount)
Keeps track of the number of versions for the columns asked for.
|
int |
ScanQueryMatcher.compareKeyForNextColumn(Cell nextIndexed,
Cell currentCell) |
int |
ScanQueryMatcher.compareKeyForNextRow(Cell nextIndexed,
Cell currentCell) |
void |
ExplicitColumnTracker.doneWithColumn(Cell cell) |
default void |
ColumnTracker.doneWithColumn(Cell cell)
This method is used to inform the column tracker that we are done with this column.
|
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell cell) |
Cell |
UserScanQueryMatcher.getNextKeyHint(Cell cell) |
Cell |
CompactionScanQueryMatcher.getNextKeyHint(Cell cell) |
abstract Cell |
ScanQueryMatcher.getNextKeyHint(Cell cell)
Delegate to
Filter.getNextCellHint(Cell) . |
ScanQueryMatcher.MatchCode |
ScanWildcardColumnTracker.getNextRowOrNextColumn(Cell cell) |
ScanQueryMatcher.MatchCode |
ExplicitColumnTracker.getNextRowOrNextColumn(Cell cell) |
ScanQueryMatcher.MatchCode |
NewVersionBehaviorTracker.getNextRowOrNextColumn(Cell cell) |
ScanQueryMatcher.MatchCode |
ColumnTracker.getNextRowOrNextColumn(Cell cell)
Retrieve the MatchCode for the next row or column
|
DeleteTracker.DeleteResult |
ScanDeleteTracker.isDeleted(Cell cell)
Check if the specified Cell buffer has been deleted by a previously seen delete.
|
DeleteTracker.DeleteResult |
NewVersionBehaviorTracker.isDeleted(Cell cell)
This method is not idempotent, we will save some info to judge VERSION_MASKED.
|
DeleteTracker.DeleteResult |
DeleteTracker.isDeleted(Cell cell)
Check if the specified cell buffer has been deleted by a previously seen delete.
|
ScanQueryMatcher.MatchCode |
IncludeAllCompactionQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
StripeCompactionScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
NormalUserScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
RawScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
MinorCompactionScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
MajorCompactionScanQueryMatcher.match(Cell cell) |
abstract ScanQueryMatcher.MatchCode |
ScanQueryMatcher.match(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)
|
protected ScanQueryMatcher.MatchCode |
UserScanQueryMatcher.matchColumn(Cell cell,
long timestamp,
byte typeByte) |
boolean |
UserScanQueryMatcher.moreRowsMayExistAfter(Cell cell) |
boolean |
CompactionScanQueryMatcher.moreRowsMayExistAfter(Cell cell) |
abstract boolean |
ScanQueryMatcher.moreRowsMayExistAfter(Cell cell) |
protected ScanQueryMatcher.MatchCode |
ScanQueryMatcher.preCheck(Cell cell)
Check before the delete logic.
|
protected long |
NewVersionBehaviorTracker.prepare(Cell cell)
Reset the map if it is different with the last Cell.
|
void |
ScanQueryMatcher.setToNewRow(Cell currentRow)
Set the row when there is change in row
|
protected void |
CompactionScanQueryMatcher.trackDelete(Cell cell) |
protected ScanQueryMatcher.MatchCode |
DropDeletesCompactionScanQueryMatcher.tryDropDelete(Cell cell) |
Constructor and Description |
---|
ScanQueryMatcher(Cell startKey,
ScanInfo scanInfo,
ColumnTracker columns,
long oldestUnexpiredTS,
long now) |
Modifier and Type | Method and Description |
---|---|
void |
StoreHotnessProtector.finish(Map<byte[],List<Cell>> familyMaps) |
void |
StoreHotnessProtector.start(Map<byte[],List<Cell>> familyMaps) |
Modifier and Type | Method and Description |
---|---|
void |
WALCellCodec.EnsureKvEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
Cell |
BulkLoadCellFilter.filterCell(Cell cell,
org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate)
Filters the bulk load cell using the supplied predicate.
|
Cell |
ScopeWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Cell |
WALCellFilter.filterCell(WAL.Entry entry,
Cell cell)
Applies the filter, possibly returning a different Cell instance.
|
Cell |
NamespaceTableCfWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
Cell |
BulkLoadCellFilter.filterCell(Cell cell,
org.apache.hbase.thirdparty.com.google.common.base.Predicate<byte[]> famPredicate)
Filters the bulk load cell using the supplied predicate.
|
Cell |
ScopeWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Cell |
WALCellFilter.filterCell(WAL.Entry entry,
Cell cell)
Applies the filter, possibly returning a different Cell instance.
|
Cell |
NamespaceTableCfWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
Cell |
ScannerResultGenerator.next() |
Cell |
RowResultGenerator.next() |
Modifier and Type | Method and Description |
---|---|
void |
ScannerResultGenerator.putBack(Cell kv) |
abstract void |
ResultGenerator.putBack(Cell kv) |
void |
RowResultGenerator.putBack(Cell kv) |
Constructor and Description |
---|
CellModel(Cell cell)
Constructor from KeyValue
|
Modifier and Type | Method and Description |
---|---|
Cell |
AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
boolean |
TableAuthManager.authorize(User user,
TableName table,
Cell cell,
Permission.Action action)
Authorize a user for a given KV.
|
static List<Permission> |
AccessControlLists.getCellPermissionsForUser(User user,
Cell cell) |
Cell |
AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
boolean |
AccessController.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> e,
InternalScanner s,
Cell curRowCell,
boolean hasMore) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
Modifier and Type | Method and Description |
---|---|
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
protected List<List<Cell>> |
DefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths() |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityNewVersionBehaivorTracker.add(Cell cell) |
void |
VisibilityScanDeleteTracker.add(Cell delCell) |
boolean |
VisibilityExpEvaluator.evaluate(Cell cell)
Evaluates whether the passed cell passes Scan/Get Authorization.
|
static Byte |
VisibilityUtils.extractAndPartitionTags(Cell cell,
List<Tag> visTags,
List<Tag> nonVisTags)
Extracts and partitions the visibility tags and nonVisibility Tags
|
static Byte |
VisibilityUtils.extractVisibilityTags(Cell cell,
List<Tag> tags)
Extract the visibility tags of the given Cell into the given List
|
DeleteTracker.DeleteResult |
VisibilityNewVersionBehaivorTracker.isDeleted(Cell cell) |
DeleteTracker.DeleteResult |
VisibilityScanDeleteTracker.isDeleted(Cell cell) |
static boolean |
VisibilityUtils.isVisibilityTagsPresent(Cell cell) |
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
boolean |
VisibilityController.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> e,
InternalScanner s,
Cell curRowCell,
boolean hasMore) |
void |
VisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
protected Pair<Map<String,Integer>,Map<String,List<Integer>>> |
DefaultVisibilityLabelServiceImpl.extractLabelsAndAuths(List<List<Cell>> labelDetails) |
void |
VisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
static Cell |
ProtobufUtil.toCell(ExtendedCellBuilder cellBuilder,
CellProtos.Cell cell) |
Modifier and Type | Method and Description |
---|---|
static CellProtos.Cell |
ProtobufUtil.toCell(Cell kv) |
static ClientProtos.Cursor |
ProtobufUtil.toCursor(Cell cell) |
Modifier and Type | Method and Description |
---|---|
Filter.ReturnCode |
SparkSQLPushDownFilter.filterCell(Cell c) |
Modifier and Type | Method and Description |
---|---|
static List<TCell> |
ThriftUtilities.cellFromHBase(Cell in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell object.
|
static List<TCell> |
ThriftUtilities.cellFromHBase(Cell[] in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell array.
|
Modifier and Type | Class and Description |
---|---|
class |
MapReduceExtendedCell
A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
|
Modifier and Type | Method and Description |
---|---|
Cell |
BloomContext.getLastCell() |
Cell |
BloomFilterWriter.getPrevCell()
Returns the previous cell written by this writer
|
Cell |
CollectionBackedScanner.next() |
Cell |
CollectionBackedScanner.peek() |
Modifier and Type | Method and Description |
---|---|
void |
BloomFilterChunk.add(Cell cell) |
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Deprecated.
|
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.
|
boolean |
BloomFilter.contains(Cell keyCell,
ByteBuff bloom,
BloomType type)
Check if the specified key is contained in the bloom filter.
|
static boolean |
BloomFilterUtil.contains(Cell cell,
ByteBuff bloomBuf,
int bloomOffset,
int bloomSize,
Hash hash,
int hashCount,
BloomType type) |
protected boolean |
RowBloomContext.isNewKey(Cell cell) |
protected boolean |
RowColBloomContext.isNewKey(Cell cell) |
protected abstract boolean |
BloomContext.isNewKey(Cell cell)
Returns true if the cell is a new key as per the bloom type
|
boolean |
CollectionBackedScanner.reseek(Cell seekCell) |
boolean |
CollectionBackedScanner.seek(Cell seekCell) |
void |
BloomContext.writeBloom(Cell cell)
Bloom information from the cell is retrieved
|
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Deprecated.
|
Constructor and Description |
---|
CellHashKey(Cell cell) |
CollectionBackedScanner(CellComparator comparator,
Cell... array) |
MapReduceExtendedCell(Cell cell) |
RowBloomHashKey(Cell cell) |
RowColBloomHashKey(Cell cell) |
Constructor and Description |
---|
CollectionBackedScanner(List<Cell> list) |
CollectionBackedScanner(List<Cell> list,
CellComparator comparator) |
CollectionBackedScanner(SortedSet<Cell> set) |
CollectionBackedScanner(SortedSet<Cell> set,
CellComparator comparator) |
Modifier and Type | Method and Description |
---|---|
ArrayList<Cell> |
WALEdit.getCells() |
Modifier and Type | Method and Description |
---|---|
WALEdit |
WALEdit.add(Cell cell) |
WALEdit |
WALEdit.add(Cell cell,
byte[] family) |
static WALProtos.BulkLoadDescriptor |
WALEdit.getBulkLoadDescriptor(Cell cell)
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
|
static WALProtos.CompactionDescriptor |
WALEdit.getCompaction(Cell kv)
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
|
static WALProtos.FlushDescriptor |
WALEdit.getFlushDescriptor(Cell cell) |
static WALProtos.RegionEventDescriptor |
WALEdit.getRegionEventDescriptor(Cell cell) |
static boolean |
WALEdit.isCompactionMarker(Cell cell)
Returns true if the given cell is a serialized
WALProtos.CompactionDescriptor |
static boolean |
WALEdit.isMetaEditFamily(Cell cell) |
Modifier and Type | Method and Description |
---|---|
void |
WALEdit.add(Map<byte[],List<Cell>> familyMap)
Append the given map of family->edits to a WALEdit data structure.
|
void |
WALEdit.setCells(ArrayList<Cell> cells)
This is not thread safe.
|
Copyright © 2007–2019 Cloudera. All rights reserved.