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
|
private static class |
PrivateCellUtil.EmptyByteBufferExtendedCell
These cells are used in reseeks/seeks to improve the read performance.
|
private static class |
PrivateCellUtil.EmptyCell
These cells are used in reseeks/seeks to improve the read performance.
|
private static class |
PrivateCellUtil.FirstOnRowByteBufferExtendedCell |
private static class |
PrivateCellUtil.FirstOnRowCell |
private static class |
PrivateCellUtil.FirstOnRowColByteBufferExtendedCell |
private static class |
PrivateCellUtil.FirstOnRowColCell |
private static class |
PrivateCellUtil.FirstOnRowColTSByteBufferExtendedCell |
private static class |
PrivateCellUtil.FirstOnRowColTSCell |
private static class |
PrivateCellUtil.FirstOnRowDeleteFamilyCell |
private static class |
PrivateCellUtil.LastOnRowByteBufferExtendedCell |
private static class |
PrivateCellUtil.LastOnRowCell |
private static class |
PrivateCellUtil.LastOnRowColByteBufferExtendedCell |
private static class |
PrivateCellUtil.LastOnRowColCell |
(package private) static class |
PrivateCellUtil.TagRewriteByteBufferExtendedCell |
(package private) static class |
PrivateCellUtil.TagRewriteCell
This can be used when a Cell has to change with addition/removal of one or more tags.
|
(package private) static class |
PrivateCellUtil.ValueAndTagRewriteByteBufferExtendedCell |
(package private) static class |
PrivateCellUtil.ValueAndTagRewriteCell |
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 | Field and Description |
---|---|
protected Cell |
PrivateCellUtil.TagRewriteCell.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 |
PrivateCellUtil.createCell(Cell cell,
byte[] tags) |
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[] value,
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,
List<Tag> 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.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) |
(package private) static Cell |
PrivateCellUtil.createNextOnRowCol(Cell cell,
long ts,
byte type) |
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
|
private int |
KeyValue.calculateHashForKey(Cell cell) |
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[] |
PrivateCellUtil.cloneTags(Cell cell) |
static byte[] |
CellUtil.cloneTags(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0.
Use
RawCell.cloneTags() |
static byte[] |
CellUtil.cloneValue(Cell cell) |
int |
CellComparatorImpl.compare(Cell a,
Cell b) |
int |
CellComparator.compare(Cell leftCell,
Cell rightCell)
Lexographically compares two cells.
|
int |
KeyValue.MetaComparator.compare(Cell left,
Cell right)
Deprecated.
Compare key portion of a
KeyValue for keys in hbase:meta
table. |
int |
KeyValue.KVComparator.compare(Cell left,
Cell right)
Deprecated.
Compares the Key of a cell -- with fields being more significant in this order:
rowkey, colfam/qual, timestamp, type, mvcc
|
int |
CellComparatorImpl.compare(Cell a,
Cell b,
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 |
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.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 |
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
|
(package private) int |
KeyValue.KVComparator.compareColumns(Cell left,
short lrowlength,
Cell right,
short rrowlength)
Deprecated.
|
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.MetaCellComparator.compareRows(ByteBuffer row,
Cell cell) |
default int |
CellComparator.compareRows(ByteBuffer row,
Cell cell) |
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 |
CellComparator.compareRows(Cell leftCell,
Cell rightCell)
Lexographically compares the rows of two cells.
|
int |
KeyValue.KVComparator.compareRows(Cell left,
Cell right)
Deprecated.
|
(package private) static int |
CellComparatorImpl.compareRows(Cell left,
int leftRowLength,
Cell right,
int rightRowLength) |
int |
CellComparatorImpl.compareTimestamps(Cell left,
Cell right) |
int |
CellComparator.compareTimestamps(Cell leftCell,
Cell rightCell)
Compares cell's timestamps in DESCENDING order.
|
int |
KeyValue.KVComparator.compareTimestamps(Cell left,
Cell right)
Deprecated.
|
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.
|
(package private) static int |
PrivateCellUtil.compareWithoutRow(CellComparator comparator,
Cell left,
byte[] right,
int roffset,
int rlength,
short rowlength)
Compare columnFamily, qualifier, timestamp, and key type (everything except the row).
|
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 |
PrivateCellUtil.createCell(Cell cell,
byte[] tags) |
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[] value,
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,
List<Tag> 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 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) |
(package private) static Cell |
PrivateCellUtil.createNextOnRowCol(Cell cell,
long ts,
byte type) |
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 |
PrivateCellUtil.equalsIgnoreMvccVersion(Cell a,
Cell b)
special case for Cell.equals
|
static boolean |
CellUtil.equalsIgnoreMvccVersion(Cell a,
Cell b)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
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 |
PrivateCellUtil.estimatedSerializedSizeOf(Cell cell)
Estimate based on keyvalue's serialization format in the RPC layer.
|
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.estimatedSerializedSizeOfKey(Cell cell)
Calculates the serialized key size.
|
static int |
CellUtil.estimatedSerializedSizeOfKey(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static ByteRange |
PrivateCellUtil.fillFamilyRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillFamilyRange(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.fillQualifierRange(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.fillRowRange(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.fillTagRange(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 ByteRange |
CellUtil.fillValueRange(Cell cell,
ByteRange range)
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 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 String |
CellUtil.getCellKeyAsString(Cell cell) |
static String |
CellUtil.getCellKeyAsString(Cell cell,
Function<Cell,String> rowConverter) |
static byte[] |
PrivateCellUtil.getCellKeySerializedAsKeyValueKey(Cell cell)
This method exists just to encapsulate how we serialize keys.
|
static byte[] |
CellUtil.getCellKeySerializedAsKeyValueKey(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static List<RegionInfo> |
MetaTableAccessor.getMergeRegions(Cell[] cells) |
static Map<String,RegionInfo> |
MetaTableAccessor.getMergeRegionsWithName(Cell[] cells) |
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) |
private static long |
MetaTableAccessor.getReplicationBarrier(Cell c) |
static int |
PrivateCellUtil.getRowAsInt(Cell cell)
Converts the rowkey bytes of the given cell into an int value
|
static byte |
PrivateCellUtil.getRowByte(Cell cell,
int index)
misc
|
static byte |
CellUtil.getRowByte(Cell cell,
int index)
Deprecated.
|
static int |
KeyValueUtil.getSerializedSize(Cell cell,
boolean withTags) |
private static int |
CellUtil.getSumOfCellElementLengths(Cell cell) |
private static int |
CellUtil.getSumOfCellKeyElementLengths(Cell cell) |
static Optional<Tag> |
PrivateCellUtil.getTag(Cell cell,
byte type)
Retrieve Cell's first tag, matching the passed in type
|
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 byte[] |
CellUtil.getTagArray(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static List<Tag> |
PrivateCellUtil.getTags(Cell cell) |
static List<Tag> |
CellUtil.getTags(Cell cell)
Deprecated.
As of 2.0.0 and will be removed in 3.0.0
|
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 |
PrivateCellUtil.getValueBufferShallowCopy(Cell cell) |
static ByteBuffer |
CellUtil.getValueBufferShallowCopy(Cell cell)
Deprecated.
As of HBase-2.0. Will be removed in 3.0.
|
static boolean |
MetaTableAccessor.hasMergeRegions(Cell[] cells) |
static boolean |
CellUtil.isDelete(Cell cell) |
static boolean |
PrivateCellUtil.isDeleteColumnOrFamily(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.isDeleteColumns(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.isDeleteColumnVersion(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.isDeleteFamily(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.isDeleteFamilyVersion(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.isDeleteType(Cell cell) |
static boolean |
CellUtil.isDeleteType(Cell cell)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
private static boolean |
MetaTableAccessor.isMergeQualifierPrefix(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 boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
PrivateCellUtil.matchingColumn(Cell left,
byte[] fam,
int foffset,
int flength,
byte[] qual,
int qoffset,
int qlength) |
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 |
CellUtil.matchingColumn(Cell left,
Cell right) |
static boolean |
CellUtil.matchingColumnFamilyAndQualifierPrefix(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf) |
static boolean |
PrivateCellUtil.matchingFamily(Cell left,
byte[] buf,
int offset,
int length) |
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 |
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 |
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,
byte[] buf,
int offset,
int length)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0.
|
static boolean |
CellUtil.matchingQualifier(Cell left,
Cell right) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, byte[]) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf,
int offset,
int length)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, Cell) |
static boolean |
CellUtil.matchingRow(Cell left,
Cell right)
Deprecated.
As of release 2.0.0, this will be removed in HBase 3.0.0. Instead use
CellUtil.matchingRows(Cell, Cell) |
static boolean |
CellUtil.matchingRowColumn(Cell left,
Cell right)
Compares the row and column of two keyvalues for equality
|
boolean |
KeyValue.KVComparator.matchingRowColumn(Cell left,
Cell right)
Deprecated.
Compares the row and column of two keyvalues for equality
|
static boolean |
CellUtil.matchingRowColumnBytes(Cell left,
Cell right) |
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
|
private boolean |
KeyValue.KVComparator.matchingRows(Cell left,
short lrowlength,
Cell right,
short rrowlength)
Deprecated.
|
static boolean |
CellUtil.matchingTimestamp(Cell a,
Cell b) |
static boolean |
PrivateCellUtil.matchingType(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 |
CellUtil.matchingValue(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingValue(Cell left,
Cell right) |
static boolean |
PrivateCellUtil.matchingValue(Cell left,
Cell right,
int lvlength,
int rvlength) |
static int |
KeyValueUtil.oswrite(Cell cell,
OutputStream out,
boolean withTags) |
static boolean |
PrivateCellUtil.qualifierStartsWith(Cell left,
byte[] startsWith)
Finds if the start of the qualifier part of the Cell matches
buf |
static void |
PrivateCellUtil.setSequenceId(Cell cell,
long seqId)
Sets the given seqId to the cell.
|
static void |
CellUtil.setSequenceId(Cell cell,
long seqId)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
static void |
PrivateCellUtil.setTimestamp(Cell cell,
byte[] ts)
Sets the given timestamp to the cell.
|
static void |
CellUtil.setTimestamp(Cell cell,
byte[] ts,
int tsOffset)
Deprecated.
As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
|
static void |
PrivateCellUtil.setTimestamp(Cell cell,
long ts)
Sets the given timestamp to the cell.
|
static void |
CellUtil.setTimestamp(Cell cell,
long ts)
Deprecated.
As of HBase-2.0. Will be a LimitedPrivate API in HBase-3.0.
|
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 |
PrivateCellUtil.updateLatestStamp(Cell cell,
long ts)
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP . |
static boolean |
CellUtil.updateLatestStamp(Cell cell,
long ts)
Deprecated.
As of HBase-2.0. Will be removed in HBase-3.0
|
(package private) static void |
PrivateCellUtil.ValueAndTagRewriteCell.write(ByteBuffer buf,
int offset,
Cell cell,
byte[] value,
byte[] tags)
Made into a static method so as to reuse the logic
within ValueAndTagRewriteByteBufferExtendedCell
|
(package private) static int |
PrivateCellUtil.ValueAndTagRewriteCell.write(OutputStream out,
boolean withTags,
Cell cell,
byte[] value,
byte[] tags)
Made into a static method so as to reuse the logic within
ValueAndTagRewriteByteBufferExtendedCell
|
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 |
PrivateCellUtil.writeRowKeyExcludingCommon(Cell cell,
short rLen,
int commonPrefix,
DataOutputStream out)
Write rowkey excluding the common part.
|
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.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 |
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.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.
|
static String |
CellUtil.getCellKeyAsString(Cell cell,
Function<Cell,String> rowConverter) |
Constructor and Description |
---|
KeyValue(Cell c) |
TagRewriteCell(Cell cell,
byte[] tags) |
ValueAndTagRewriteCell(Cell cell,
byte[] value,
byte[] tags) |
Modifier and Type | Class and Description |
---|---|
private static class |
Mutation.CellWrapper |
Modifier and Type | Field and Description |
---|---|
private Cell |
Mutation.CellWrapper.cell |
private Cell[] |
Result.cells |
private Cell |
BatchScanResultCache.lastCell |
private Cell |
AllowPartialScanResultCache.lastCell |
Modifier and Type | Field and Description |
---|---|
protected NavigableMap<byte[],List<Cell>> |
Mutation.familyMap |
(package private) List<Cell> |
ClientSideRegionScanner.values |
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.
|
(package private) List<Cell> |
Mutation.getCellList(byte[] family)
Creates an empty list if one doesn't exist for the given column family
or else it returns the associated list of Cell objects.
|
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.
|
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.
|
(package private) Mutation |
Mutation.add(Cell cell) |
Append |
Append.add(Cell cell)
Add column and value to this Append 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.
|
private static Map<String,Object> |
Mutation.cellToStringMap(Cell c) |
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) |
(package private) static Result |
ConnectionUtils.filterCells(Result result,
Cell keepCellsAfter) |
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 |
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 |
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 |
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 |
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 |
Constructor and Description |
---|
CellWrapper(Cell cell) |
Result(Cell[] cells,
Boolean exists,
boolean stale,
boolean mayHaveMoreCellsInRow)
Private ctor.
|
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 |
private Cell |
BaseDecoder.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 |
CellCodec.CellDecoder.parseCell() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected Cell |
CellCodecWithTags.CellDecoder.parseCell() |
protected abstract Cell |
BaseDecoder.parseCell()
Extract a Cell.
|
protected Cell |
MessageCodec.MessageDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
void |
CellCodec.CellEncoder.write(Cell cell) |
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell) |
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
void |
CellCodecWithTags.CellEncoder.write(Cell cell) |
abstract void |
BaseEncoder.write(Cell cell) |
void |
MessageCodec.MessageEncoder.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)
Deprecated.
since 2.2.0 and will be removedin 4.0.0. Use
RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List) or
RegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List) instead. |
Modifier and Type | Method and Description |
---|---|
default List<Pair<Cell,Cell>> |
RegionObserver.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an append operation, but before
they are committed to the WAL or memstore.
|
default List<Pair<Cell,Cell>> |
RegionObserver.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an append operation, but before
they are committed to the WAL or memstore.
|
default List<Pair<Cell,Cell>> |
RegionObserver.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an increment operation, but before
they are committed to the WAL or memstore.
|
default List<Pair<Cell,Cell>> |
RegionObserver.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an increment operation, but before
they are committed to the WAL or memstore.
|
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)
Deprecated.
since 2.2.0 and will be removedin 4.0.0. Use
RegionObserver.postIncrementBeforeWAL(ObserverContext, Mutation, List) or
RegionObserver.postAppendBeforeWAL(ObserverContext, Mutation, List) instead. |
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 List<Pair<Cell,Cell>> |
RegionObserver.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an append operation, but before
they are committed to the WAL or memstore.
|
default List<Pair<Cell,Cell>> |
RegionObserver.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an append operation, but before
they are committed to the WAL or memstore.
|
default void |
RegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called after the client performs a Get
|
default List<Pair<Cell,Cell>> |
RegionObserver.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an increment operation, but before
they are committed to the WAL or memstore.
|
default List<Pair<Cell,Cell>> |
RegionObserver.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs)
Called after a list of new cells has been created during an increment operation, but before
they are committed to the WAL or memstore.
|
default void |
RegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called before the client performs a Get
|
void |
MetaTableMetrics.ExampleRegionObserverMeta.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
private Cell |
WriteHeavyIncrementObserver.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long ts,
long value) |
Modifier and Type | Method and Description |
---|---|
private Delete |
BulkDeleteEndpoint.createDeleteMutation(List<Cell> deleteRow,
org.apache.hadoop.hbase.coprocessor.example.generated.BulkDeleteProtos.BulkDeleteRequest.DeleteType deleteType,
Long timestamp) |
boolean |
DelegatingInternalScanner.next(List<Cell> result,
ScannerContext scannerContext) |
void |
ExampleRegionObserverWithMetrics.ExampleRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
ExampleRegionObserverWithMetrics.ExampleRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
WriteHeavyIncrementObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
Modifier and Type | Class and Description |
---|---|
(package private) static class |
KeyOnlyFilter.KeyOnlyByteBufferExtendedCell |
(package private) static class |
KeyOnlyFilter.KeyOnlyCell |
Modifier and Type | Field and Description |
---|---|
private Cell |
KeyOnlyFilter.KeyOnlyCell.cell |
Modifier and Type | Field and Description |
---|---|
private List<Cell> |
FilterListWithOR.prevCellList |
Modifier and Type | Method and Description |
---|---|
private Cell |
KeyOnlyFilter.createKeyOnlyCell(Cell c) |
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 |
FilterListWithAND.getNextCellHint(Cell currentCell) |
Cell |
FilterList.getNextCellHint(Cell currentCell) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell cell) |
Cell |
TimestampsFilter.getNextCellHint(Cell currentCell)
Pick the next cell that the scanner should seek to.
|
Cell |
FilterListWithOR.getNextCellHint(Cell currentCell) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell cell) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
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 |
FilterWrapper.getNextCellHint(Cell currentCell) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterList.transformCell(Cell c) |
Cell |
FilterListBase.transformCell(Cell c)
For FilterList, we can consider a filter list as a node in a tree.
|
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
Give the filter a chance to transform the passed KeyValue.
|
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterWrapper.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
private Filter.ReturnCode |
FilterListWithOR.calculateReturnCodeByPrevCellAndRC(Filter subFilter,
Cell currentCell,
Cell prevCell,
Filter.ReturnCode prevCode)
For MUST_PASS_ONE, we cannot make sure that when filter-A in filter list return NEXT_COL then
the next cell passing to filterList will be the first cell in next column, because if filter-B
in filter list return SKIP, then the filter list will return SKIP.
|
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) |
private static int |
ColumnPrefixFilter.compareQualifierPart(Cell cell,
int length,
byte[] prefix) |
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) |
private boolean |
ColumnValueFilter.compareValue(CompareOperator op,
ByteArrayComparable comparator,
Cell cell)
This method is used to determine a cell should be included or filtered out.
|
private Cell |
KeyOnlyFilter.createKeyOnlyCell(Cell c) |
Filter.ReturnCode |
Filter.filterCell(Cell c)
A way to filter based on the column family, column qualifier and/or the column value.
|
Filter.ReturnCode |
PageFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
DependentColumnFilter.filterCell(Cell c) |
Filter.ReturnCode |
FilterListWithAND.filterCell(Cell c) |
Filter.ReturnCode |
FilterList.filterCell(Cell c) |
Filter.ReturnCode |
RowFilter.filterCell(Cell v) |
Filter.ReturnCode |
ColumnRangeFilter.filterCell(Cell c) |
Filter.ReturnCode |
QualifierFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnCountGetFilter.filterCell(Cell c) |
Filter.ReturnCode |
TimestampsFilter.filterCell(Cell c) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterCell(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterListWithOR.filterCell(Cell c) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterCell(Cell c) |
Filter.ReturnCode |
WhileMatchFilter.filterCell(Cell c) |
Filter.ReturnCode |
MultiRowRangeFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
SingleColumnValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
FirstKeyOnlyFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnPaginationFilter.filterCell(Cell c) |
Filter.ReturnCode |
RandomRowFilter.filterCell(Cell c) |
Filter.ReturnCode |
ColumnPrefixFilter.filterCell(Cell cell) |
Filter.ReturnCode |
ColumnValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
ValueFilter.filterCell(Cell c) |
Filter.ReturnCode |
SkipFilter.filterCell(Cell c) |
Filter.ReturnCode |
FamilyFilter.filterCell(Cell c) |
Filter.ReturnCode |
FuzzyRowFilter.filterCell(Cell c) |
Filter.ReturnCode |
InclusiveStopFilter.filterCell(Cell c) |
Filter.ReturnCode |
PrefixFilter.filterCell(Cell c) |
Filter.ReturnCode |
KeyOnlyFilter.filterCell(Cell ignored) |
Filter.ReturnCode |
FilterWrapper.filterCell(Cell c) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterColumn(Cell cell) |
Filter.ReturnCode |
ColumnPrefixFilter.filterColumn(Cell cell) |
private boolean |
SingleColumnValueFilter.filterColumnValue(Cell cell) |
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 |
PageFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
DependentColumnFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterList.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
RowFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnRangeFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
QualifierFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnCountGetFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
TimestampsFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FilterListBase.filterKeyValue(Cell c) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
WhileMatchFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
MultiRowRangeFilter.filterKeyValue(Cell ignored)
Deprecated.
|
Filter.ReturnCode |
SingleColumnValueFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FirstKeyOnlyFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnPaginationFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
RandomRowFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ColumnPrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
ValueFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
SkipFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FamilyFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
FuzzyRowFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
InclusiveStopFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
PrefixFilter.filterKeyValue(Cell c)
Deprecated.
|
Filter.ReturnCode |
KeyOnlyFilter.filterKeyValue(Cell ignored)
Deprecated.
|
Filter.ReturnCode |
FilterWrapper.filterKeyValue(Cell c)
Deprecated.
|
abstract boolean |
Filter.filterRowKey(Cell firstRowCell)
Filters a row based on the row key.
|
boolean |
PageFilter.filterRowKey(Cell cell) |
boolean |
FilterListWithAND.filterRowKey(Cell firstRowCell) |
boolean |
FilterList.filterRowKey(Cell firstRowCell) |
boolean |
RowFilter.filterRowKey(Cell firstRowCell) |
boolean |
ColumnRangeFilter.filterRowKey(Cell cell) |
boolean |
ColumnCountGetFilter.filterRowKey(Cell cell) |
boolean |
TimestampsFilter.filterRowKey(Cell cell) |
boolean |
FilterListWithOR.filterRowKey(Cell firstRowCell) |
boolean |
MultipleColumnPrefixFilter.filterRowKey(Cell cell) |
boolean |
WhileMatchFilter.filterRowKey(Cell cell) |
boolean |
MultiRowRangeFilter.filterRowKey(Cell firstRowCell) |
boolean |
CompareFilter.filterRowKey(Cell cell) |
boolean |
SingleColumnValueFilter.filterRowKey(Cell cell) |
boolean |
FirstKeyOnlyFilter.filterRowKey(Cell cell) |
boolean |
ColumnPaginationFilter.filterRowKey(Cell cell) |
boolean |
RandomRowFilter.filterRowKey(Cell firstRowCell) |
boolean |
ColumnPrefixFilter.filterRowKey(Cell cell) |
boolean |
ColumnValueFilter.filterRowKey(Cell cell) |
boolean |
SkipFilter.filterRowKey(Cell cell) |
boolean |
InclusiveStopFilter.filterRowKey(Cell firstRowCell) |
boolean |
FilterBase.filterRowKey(Cell cell) |
boolean |
PrefixFilter.filterRowKey(Cell firstRowCell) |
boolean |
KeyOnlyFilter.filterRowKey(Cell cell) |
boolean |
FilterWrapper.filterRowKey(Cell cell) |
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 |
FilterListWithAND.getNextCellHint(Cell currentCell) |
Cell |
FilterList.getNextCellHint(Cell currentCell) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell cell) |
Cell |
TimestampsFilter.getNextCellHint(Cell currentCell)
Pick the next cell that the scanner should seek to.
|
Cell |
FilterListWithOR.getNextCellHint(Cell currentCell) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell cell) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell cell) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
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 |
FilterWrapper.getNextCellHint(Cell currentCell) |
private boolean |
FirstKeyValueMatchingQualifiersFilter.hasOneMatchingQualifier(Cell c)
Deprecated.
|
(package private) boolean |
FuzzyRowFilter.RowTracker.lessThan(Cell currentCell,
byte[] nextRowKey) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterList.transformCell(Cell c) |
Cell |
FilterListBase.transformCell(Cell c)
For FilterList, we can consider a filter list as a node in a tree.
|
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
Give the filter a chance to transform the passed KeyValue.
|
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterWrapper.transformCell(Cell v) |
private void |
FilterListWithOR.updatePrevCellList(int index,
Cell currentCell,
Filter.ReturnCode currentRC) |
(package private) boolean |
FuzzyRowFilter.RowTracker.updateTracker(Cell currentCell) |
(package private) void |
FuzzyRowFilter.RowTracker.updateWith(Cell currentCell,
Pair<byte[],byte[]> fuzzyData) |
Modifier and Type | Method and Description |
---|---|
abstract void |
Filter.filterRowCells(List<Cell> kvs)
Chance to alter the list of Cells to be submitted.
|
void |
DependentColumnFilter.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 |
FilterListBase.filterRowCells(List<Cell> cells)
Filters that never filter by modifying the returned List of Cells can inherit this
implementation that does nothing.
|
void |
SingleColumnValueExcludeFilter.filterRowCells(List<Cell> kvs) |
void |
FilterBase.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
void |
FilterWrapper.filterRowCells(List<Cell> kvs) |
FilterWrapper.FilterRowRetCode |
FilterWrapper.filterRowCellsWithRet(List<Cell> kvs) |
Constructor and Description |
---|
KeyOnlyCell(Cell c,
boolean lenAsVal) |
Modifier and Type | Field and Description |
---|---|
private Cell |
HalfStoreFileReader.splitCell |
Modifier and Type | Field and Description |
---|---|
private Optional<Cell> |
HalfStoreFileReader.firstKey |
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 | Class and Description |
---|---|
protected static class |
BufferedDataBlockEncoder.OffheapDecodedExtendedCell |
protected static class |
BufferedDataBlockEncoder.OnheapDecodedCell
Copies only the key part of the keybuffer by doing a deep copy and passes the
seeker state members for taking a clone.
|
Modifier and Type | Field and Description |
---|---|
private Cell |
RowIndexEncoderV1.lastCell
The Cell previously appended.
|
protected Cell |
EncodingState.prevCell
The previous Cell the encoder encoded.
|
Modifier and Type | Method and Description |
---|---|
protected Cell |
AbstractDataBlockEncoder.createFirstKeyCell(ByteBuffer key,
int keyLength) |
Cell |
DataBlockEncoder.EncodedSeeker.getCell() |
Cell |
RowIndexSeekerV1.getCell() |
Cell |
BufferedDataBlockEncoder.BufferedEncodedSeeker.getCell() |
Cell |
DataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block)
Return first key in block as a cell.
|
Cell |
FastDiffDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DiffKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
PrefixKeyDeltaEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
RowIndexCodecV1.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
CopyKeyDataBlockEncoder.getFirstKeyCellInBlock(ByteBuff block) |
Cell |
DataBlockEncoder.EncodedSeeker.getKey()
From the current position creates a cell using the key part
of the current buffer
|
Cell |
RowIndexSeekerV1.getKey() |
Cell |
BufferedDataBlockEncoder.BufferedEncodedSeeker.getKey() |
Cell |
RowIndexSeekerV1.SeekerState.toCell() |
Cell |
BufferedDataBlockEncoder.SeekerState.toCell() |
private Cell |
BufferedDataBlockEncoder.SeekerState.toOffheapCell(ByteBuffer valAndTagsBuffer,
int vOffset,
int tagsLenSerializationSize) |
private Cell |
BufferedDataBlockEncoder.SeekerState.toOnheapCell(ByteBuffer valAndTagsBuffer,
int vOffset,
int tagsLenSerializationSize) |
Modifier and Type | Method and Description |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value.
|
Modifier and Type | Method and Description |
---|---|
protected int |
BufferedDataBlockEncoder.afterEncodingKeyValue(Cell cell,
DataOutputStream out,
HFileBlockDefaultEncodingContext encodingCtx) |
private int |
RowIndexSeekerV1.binarySearch(Cell seekCell,
boolean seekBefore) |
protected boolean |
RowIndexEncoderV1.checkRow(Cell cell) |
static int |
BufferedDataBlockEncoder.compareCommonFamilyPrefix(Cell left,
Cell right,
int familyCommonPrefix) |
static int |
BufferedDataBlockEncoder.compareCommonQualifierPrefix(Cell left,
Cell right,
int qualCommonPrefix) |
static int |
BufferedDataBlockEncoder.compareCommonRowPrefix(Cell left,
Cell right,
int rowCommonPrefix)
common prefixes
|
int |
DataBlockEncoder.EncodedSeeker.compareKey(CellComparator comparator,
Cell key)
Compare the given key against the current key
|
int |
RowIndexSeekerV1.compareKey(CellComparator comparator,
Cell key) |
int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareKey(CellComparator comparator,
Cell key) |
private int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareTypeBytes(Cell key,
Cell right) |
private int |
FastDiffDeltaEncoder.compressSingleKeyValue(DataOutputStream out,
Cell cell,
Cell prevCell) |
private int |
DiffKeyDeltaEncoder.compressSingleKeyValue(DataOutputStream out,
Cell cell,
Cell prevCell) |
void |
DataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
void |
BufferedDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
void |
RowIndexCodecV1.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
private static int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInFamilyPart(Cell left,
Cell right,
int familyCommonPrefix) |
private static int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInQualifierPart(Cell left,
Cell right,
int qualifierCommonPrefix) |
private static int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.findCommonPrefixInRowPart(Cell left,
Cell right,
int rowCommonPrefix) |
int |
FastDiffDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
DiffKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
abstract int |
BufferedDataBlockEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingCtx,
DataOutputStream out) |
int |
PrefixKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
CopyKeyDataBlockEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
DataBlockEncoder.EncodedSeeker.seekToKeyInBlock(Cell key,
boolean seekBefore)
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if
seekBefore is false
the last key that is strictly less than the given key if
seekBefore is true. |
int |
RowIndexSeekerV1.seekToKeyInBlock(Cell seekCell,
boolean seekBefore) |
int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.seekToKeyInBlock(Cell seekCell,
boolean seekBefore) |
int |
NoneEncoder.write(Cell cell) |
void |
RowIndexEncoderV1.write(Cell cell) |
private void |
PrefixKeyDeltaEncoder.writeKeyExcludingCommon(Cell cell,
int commonPrefix,
DataOutputStream out) |
Modifier and Type | Field and Description |
---|---|
private Cell[] |
HFileBlockIndex.CellBasedKeyBlockIndexReader.blockKeys |
protected Cell |
HFileWriterImpl.firstCellInBlock
First cell in a block.
|
protected Cell |
HFileWriterImpl.lastCell
The Cell previously appended.
|
private Cell |
HFileWriterImpl.lastCellOfPreviousBlock
The last(stop) Cell of the previous data block.
|
private Cell |
HFileInfo.lastKeyCell
Last key in the file.
|
protected Cell |
HFileReaderImpl.HFileScannerImpl.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.
|
private Cell |
BlockWithScanInfo.nextIndexedKey
The first key in the next block following this one in the HFile.
|
private Cell |
HFilePrettyPrinter.KeyValueStatsCollector.prevCell |
private Cell |
CompoundBloomFilterWriter.prevCell
The prev Cell that was processed
|
Modifier and Type | Field and Description |
---|---|
private AtomicReference<Cell> |
HFileBlockIndex.CellBasedKeyBlockIndexReader.midKey
Pre-computed mid-key
|
Modifier and Type | Method and Description |
---|---|
Cell |
HFileScanner.getCell() |
Cell |
HFileReaderImpl.HFileScannerImpl.getCell() |
Cell |
HFileReaderImpl.EncodedScanner.getCell() |
protected Cell |
HFileReaderImpl.HFileScannerImpl.getFirstKeyCellInBlock(HFileBlock curBlock) |
protected Cell |
HFileReaderImpl.EncodedScanner.getFirstKeyCellInBlock(HFileBlock curBlock) |
Cell |
HFileScanner.getKey()
Gets the current key in the form of a cell.
|
Cell |
HFileReaderImpl.HFileScannerImpl.getKey() |
Cell |
HFileReaderImpl.EncodedScanner.getKey() |
Cell |
HFileWriterImpl.getLastCell() |
Cell |
HFileInfo.getLastKeyCell() |
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 |
HFileScanner.getNextIndexedKey() |
Cell |
HFileReaderImpl.HFileScannerImpl.getNextIndexedKey() |
Cell |
BlockWithScanInfo.getNextIndexedKey() |
Cell |
CompoundBloomFilterWriter.getPrevCell() |
Cell |
HFileBlockIndex.CellBasedKeyBlockIndexReader.getRootBlockKey(int i) |
Cell |
HFileBlockIndex.ByteArrayKeyBlockIndexReader.midkey(HFile.CachingBlockReader cachingBlockReader) |
Cell |
HFileBlockIndex.CellBasedKeyBlockIndexReader.midkey(HFile.CachingBlockReader cachingBlockReader) |
abstract Cell |
HFileBlockIndex.BlockIndexReader.midkey(HFile.CachingBlockReader cachingBlockReader)
An approximation to the
HFile 's mid-key. |
Modifier and Type | Method and Description |
---|---|
Optional<Cell> |
HFile.Reader.getFirstKey() |
Optional<Cell> |
HFileReaderImpl.getFirstKey() |
Optional<Cell> |
HFile.Reader.getLastKey() |
Optional<Cell> |
HFileReaderImpl.getLastKey() |
Optional<Cell> |
HFile.Reader.midKey() |
Optional<Cell> |
HFileReaderImpl.midKey() |
Modifier and Type | Method and Description |
---|---|
void |
CompoundBloomFilterWriter.append(Cell cell) |
void |
HFileWriterImpl.append(Cell cell)
Add key/value to file.
|
(package private) static int |
HFileBlockIndex.BlockIndexReader.binarySearchNonRootIndex(Cell key,
ByteBuff nonRootIndex,
CellComparator comparator)
Performs a binary search over a non-root level index block.
|
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.
|
void |
HFilePrettyPrinter.KeyValueStatsCollector.collect(Cell cell) |
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) |
void |
NoOpDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
void |
HFileDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
void |
HFileDataBlockEncoderImpl.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
private String |
HFileWriterImpl.getLexicalErrorMessage(Cell 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. |
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) |
BlockWithScanInfo |
HFileBlockIndex.ByteArrayKeyBlockIndexReader.loadDataBlockWithScanInfo(Cell key,
HFileBlock currentBlock,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
DataBlockEncoding expectedDataBlockEncoding,
HFile.CachingBlockReader cachingBlockReader) |
BlockWithScanInfo |
HFileBlockIndex.CellBasedKeyBlockIndexReader.loadDataBlockWithScanInfo(Cell key,
HFileBlock currentBlock,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
DataBlockEncoding expectedDataBlockEncoding,
HFile.CachingBlockReader cachingBlockReader) |
abstract BlockWithScanInfo |
HFileBlockIndex.BlockIndexReader.loadDataBlockWithScanInfo(Cell key,
HFileBlock currentBlock,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
DataBlockEncoding expectedDataBlockEncoding,
HFile.CachingBlockReader cachingBlockReader)
Return the BlockWithScanInfo, a data structure which contains the Data HFileBlock with
other scan info such as the key that starts the next HFileBlock.
|
(package private) static int |
HFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(ByteBuff nonRootBlock,
Cell key,
CellComparator comparator)
Search for one key using the secondary index in a non-root block.
|
int |
HFileScanner.reseekTo(Cell cell)
Reseek to or just before the passed
cell . |
int |
HFileReaderImpl.HFileScannerImpl.reseekTo(Cell key) |
int |
HFileBlockIndex.ByteArrayKeyBlockIndexReader.rootBlockContainingKey(Cell key) |
int |
HFileBlockIndex.CellBasedKeyBlockIndexReader.rootBlockContainingKey(Cell key) |
abstract int |
HFileBlockIndex.BlockIndexReader.rootBlockContainingKey(Cell key)
Finds the root-level index block containing the given key.
|
boolean |
HFileScanner.seekBefore(Cell cell)
Consider the cell stream of all the cells in the file,
c[0] .. |
boolean |
HFileReaderImpl.HFileScannerImpl.seekBefore(Cell key) |
int |
HFileScanner.seekTo(Cell cell)
SeekTo or just before the passed
cell . |
int |
HFileReaderImpl.HFileScannerImpl.seekTo(Cell key) |
int |
HFileReaderImpl.HFileScannerImpl.seekTo(Cell key,
boolean rewind)
An internal API function.
|
HFileBlock |
HFileBlockIndex.BlockIndexReader.seekToDataBlock(Cell key,
HFileBlock currentBlock,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
DataBlockEncoding expectedDataBlockEncoding,
HFile.CachingBlockReader cachingBlockReader)
Return the data block which contains this key.
|
(package private) void |
HFileBlock.Writer.write(Cell cell)
Writes the Cell to this block
|
Constructor and Description |
---|
BlockWithScanInfo(HFileBlock hFileBlock,
Cell nextIndexedKey) |
Modifier and Type | Field and Description |
---|---|
private Cell |
Import.CellWritableComparable.kv |
private Cell |
HFileInputFormat.HFileRecordReader.value
A private cache of the key value so it doesn't need to be loaded twice from the scanner.
|
Modifier and Type | Method and Description |
---|---|
(package private) static <V extends Cell> |
HFileOutputFormat2.createRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context,
org.apache.hadoop.mapreduce.OutputCommitter committer) |
Modifier and Type | Method and Description |
---|---|
private Cell |
SyncTable.SyncMapper.checkAndResetTimestamp(Cell sourceCell) |
private static Cell |
Import.convertKv(Cell kv,
Map<byte[],byte[]> cfRenameMap) |
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.
since 0.98.9
|
static Cell |
Import.filterKv(Filter filter,
Cell c)
Attempt to filter out the keyvalue
|
Cell |
HFileInputFormat.HFileRecordReader.getCurrentValue() |
Cell |
SyncTable.SyncMapper.CellScanner.nextCellInRow()
Returns the next Cell in the current row or null iff none remain.
|
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) |
private Cell |
SyncTable.SyncMapper.checkAndResetTimestamp(Cell sourceCell) |
private int |
SyncTable.SyncMapper.compareCellKeysWithinRow(Cell c1,
Cell c2)
Compare families, qualifiers, and timestamps of the given Cells.
|
private static Cell |
Import.convertKv(Cell kv,
Map<byte[],byte[]> cfRenameMap) |
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 | Field and Description |
---|---|
private Cell |
MobCell.cell |
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 |
MobCell.getCell() |
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.
|
MobCell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks)
Reads a cell from the mob file.
|
MobCell |
MobFile.readCell(Cell search,
boolean cacheMobBlocks,
long readPt)
Reads a cell from the mob file.
|
Constructor and Description |
---|
MobCell(Cell cell) |
MobCell(Cell cell,
StoreFileScanner sfScanner) |
Modifier and Type | Method and Description |
---|---|
private void |
HFileProcedurePrettyPrinter.printCell(Cell cell) |
Modifier and Type | Method and Description |
---|---|
protected static String |
QuotaTableUtil.extractSnapshotNameFromSizeCell(Cell c) |
(package private) static long |
QuotaTableUtil.parseSnapshotSize(Cell c)
Parses the snapshot size from the given Cell's value.
|
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 |
---|---|
private Cell[] |
CellArrayMap.block |
private Cell |
CellFlatMap.CellFlatMapEntry.cell |
private Cell |
StoreFileScanner.cur |
protected Cell |
SegmentScanner.current |
private Cell |
SnapshotSegmentScanner.current |
private Cell |
StoreFileScanner.delayedSeekKV |
protected Cell |
HRegion.RegionScannerImpl.joinedContinuationRow
If the joined heap data gathering is interrupted due to scan limits, this will
contain the row for which we are populating the values.
|
private Cell |
SegmentScanner.last |
private Cell |
StripeMultiFileWriter.BoundaryMultiWriter.lastCell |
private Cell |
StripeMultiFileWriter.SizeMultiWriter.lastCell |
private Cell |
ScannerContext.lastPeekedCell |
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.
|
private Cell |
StoreScanner.prevCell |
private Cell |
SegmentScanner.stopSkippingKVsRow |
Modifier and Type | Field and Description |
---|---|
private Comparator<? super Cell> |
CellFlatMap.comparator |
private NavigableMap<Cell,Cell> |
CellSet.delegatee |
private NavigableMap<Cell,Cell> |
CellSet.delegatee |
private Optional<Cell> |
HStoreFile.firstKey |
protected Iterator<Cell> |
SegmentScanner.iter |
private Iterator<Cell> |
SnapshotSegmentScanner.iter |
private List<Cell> |
MemStoreCompactorSegmentsIterator.kvs |
private Iterator<Cell> |
MemStoreCompactorSegmentsIterator.kvsIterator |
private Optional<Cell> |
HStoreFile.lastKey |
private static List<Cell> |
HRegion.MOCKED_LIST
A mocked list implementation - discards all updates.
|
Modifier and Type | Method and Description |
---|---|
Cell |
CellSet.ceiling(Cell e) |
Cell |
CellFlatMap.ceilingKey(Cell k) |
private Cell |
MemStoreLABImpl.copyBBECellInto(ByteBufferExtendedCell cell,
int maxAlloc)
Mostly a duplicate of
MemStoreLABImpl.copyCellInto(Cell, int) } done for perf sake. |
private static Cell |
MemStoreLABImpl.copyBBECToChunkCell(ByteBufferExtendedCell cell,
ByteBuffer buf,
int offset,
int len)
Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
out of it
|
Cell |
ImmutableMemStoreLAB.copyCellInto(Cell cell) |
Cell |
MemStoreLAB.copyCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
MemStoreLABImpl.copyCellInto(Cell cell) |
private Cell |
MemStoreLABImpl.copyCellInto(Cell cell,
int maxAlloc) |
private Cell |
CellChunkImmutableSegment.copyCellIntoMSLAB(Cell cell,
MemStoreSizing memstoreSizing) |
private static Cell |
MemStoreLABImpl.copyToChunkCell(Cell cell,
ByteBuffer buf,
int offset,
int len)
Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
out of it
|
private static Cell |
MemStoreLABImpl.createChunkCell(ByteBuffer buf,
int offset,
int len,
int tagsLen,
long sequenceId) |
private static Cell |
AbstractMemStore.deepCopyIfNeeded(Cell cell) |
Cell |
CellSet.first() |
(package private) Cell |
MutableSegment.first()
Returns the first cell in the segment
|
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 |
MemStoreLAB.forceCopyOfBigCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
MemStoreLABImpl.forceCopyOfBigCellInto(Cell cell)
When a cell's size is too big (bigger than maxAlloc),
copyCellInto does not allocate it on MSLAB.
|
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) |
private Cell |
SegmentScanner.getHighest(Cell first,
Cell second)
Private internal method that returns the higher of the two key values, or null
if they are both null
|
Cell |
CellFlatMap.CellFlatMapEntry.getKey() |
(package private) Cell |
ScannerContext.getLastPeekedCell() |
protected Cell |
AbstractMemStore.getLowest(Cell a,
Cell b) |
Cell |
KeyValueScanner.getNextIndexedKey() |
Cell |
StoreScanner.getNextIndexedKey() |
Cell |
SegmentScanner.getNextIndexedKey() |
Cell |
NonLazyKeyValueScanner.getNextIndexedKey() |
Cell |
KeyValueHeap.getNextIndexedKey() |
Cell |
StoreFileScanner.getNextIndexedKey() |
(package private) Cell |
DefaultMemStore.getNextRow(Cell cell) |
(package private) Cell |
CompactingMemStore.getNextRow(Cell cell) |
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
Cell |
CellFlatMap.CellFlatMapEntry.getValue() |
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.
|
private Cell |
AbstractMemStore.maybeCloneWithAllocator(MutableSegment currentActive,
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 |
KeyValueScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
ReversedKeyValueHeap.next() |
Cell |
CellFlatMap.CellFlatMapIterator.next() |
Cell |
MemStoreMergerSegmentsIterator.next() |
Cell |
SegmentScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
KeyValueHeap.next() |
Cell |
StoreFileScanner.next() |
Cell |
MemStoreCompactorSegmentsIterator.next() |
Cell |
SnapshotSegmentScanner.next() |
Cell |
KeyValueScanner.peek()
Look at the next Cell in this scanner, but do not iterate scanner.
|
Cell |
StoreScanner.peek() |
Cell |
SegmentScanner.peek()
Look at the next Cell in this scanner, but do not iterate the scanner
|
Cell |
KeyValueHeap.peek() |
Cell |
StoreFileScanner.peek() |
Cell |
SnapshotSegmentScanner.peek() |
Cell |
CellSet.pollFirst() |
Cell |
CellSet.pollLast() |
Cell |
CellFlatMap.put(Cell k,
Cell v) |
private static Cell |
HRegion.reckonDelta(Cell delta,
Cell currentCell,
byte[] columnFamily,
long now,
Mutation mutation,
Function<Cell,byte[]> supplier) |
Cell |
CellFlatMap.remove(Object o) |
Cell |
CellFlatMap.CellFlatMapEntry.setValue(Cell value) |
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() |
private static Iterator<Cell> |
SnapshotSegmentScanner.createIterator(Segment segment) |
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> |
Region.get(Get get,
boolean withCoprocessor)
Do a get based on the get parameter.
|
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor,
long nonceGroup,
long nonce) |
private List<Cell> |
HRegion.get(Mutation mutation,
HStore store,
List<Cell> coordinates,
IsolationLevel isolation,
TimeRange tr)
Do a specific Get on passed
columnFamily and column qualifiers. |
(package private) NavigableMap<Cell,Cell> |
CellSet.getDelegatee() |
(package private) NavigableMap<Cell,Cell> |
CellSet.getDelegatee() |
Optional<Cell> |
HStoreFile.getFirstKey() |
Optional<Cell> |
StoreFile.getFirstKey()
Get the first key in this store file.
|
Optional<Cell> |
StoreFileReader.getFirstKey() |
protected Iterator<Cell> |
SegmentScanner.getIterator(Cell cell) |
Optional<Cell> |
HStoreFile.getLastKey() |
Optional<Cell> |
StoreFile.getLastKey()
Get the last key in this store file.
|
Optional<Cell> |
StoreFileReader.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> |
CellFlatMap.CellFlatMapCollection.iterator() |
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() |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postAppendBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postAppendBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postIncrementBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postIncrementBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
private List<Cell> |
HRegion.reckonDeltasByStore(HStore store,
Region.Operation op,
Mutation mutation,
Durability effectiveDurability,
long now,
List<Cell> deltas,
List<Cell> results)
Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed
column family/Store.
|
private static List<Cell> |
HRegion.sort(List<Cell> cells,
CellComparator comparator) |
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 |
CellFlatMap.CellFlatMapCollection.add(Cell k) |
boolean |
CellSet.add(Cell e) |
void |
MutableSegment.add(Cell cell,
boolean mslabUsed,
MemStoreSizing memStoreSizing,
boolean sizeAddedPreOperation)
Adds the given cell into the segment
|
void |
HStore.add(Cell cell,
MemStoreSizing memstoreSizing)
Adds a value to the memstore
|
void |
MemStore.add(Cell cell,
MemStoreSizing memstoreSizing)
Write an update
|
void |
AbstractMemStore.add(Cell cell,
MemStoreSizing memstoreSizing) |
void |
DateTieredMultiFileWriter.append(Cell cell) |
void |
StripeMultiFileWriter.BoundaryMultiWriter.append(Cell cell) |
void |
StripeMultiFileWriter.SizeMultiWriter.append(Cell cell) |
void |
CellSink.append(Cell cell)
Append the given cell
|
void |
StoreFileWriter.append(Cell cell) |
private void |
StoreFileWriter.appendDeleteFamilyBloomFilter(Cell cell) |
private void |
StoreFileWriter.appendGeneralBloomfilter(Cell cell) |
private void |
HRegion.applyToMemStore(HStore store,
Cell cell,
MemStoreSizing memstoreAccounting) |
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
|
boolean |
NonReversedNonLazyKeyValueScanner.backwardSeek(Cell key) |
boolean |
ReversedKeyValueHeap.backwardSeek(Cell seekKey) |
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 |
StoreFileScanner.backwardSeek(Cell key) |
boolean |
ReversedStoreScanner.backwardSeek(Cell key) |
Cell |
CellSet.ceiling(Cell e) |
Map.Entry<Cell,Cell> |
CellFlatMap.ceilingEntry(Cell k) |
Cell |
CellFlatMap.ceilingKey(Cell k) |
private boolean |
CompactingMemStore.checkAndAddToActiveSize(MutableSegment currActive,
Cell cellToAdd,
MemStoreSizing memstoreSizing)
Check whether anything need to be done based on the current active set size.
|
private boolean |
StoreFileReader.checkGeneralBloomFilter(byte[] key,
Cell kvKey,
BloomFilter bloomFilter) |
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 |
KeyValueHeap.KVScannerComparator.compare(Cell left,
Cell right)
Compares two KeyValue
|
int |
Segment.compare(Cell left,
Cell right) |
int |
ReversedKeyValueHeap.ReversedKVScannerComparator.compareRows(Cell left,
Cell right)
Compares rows of two KeyValue
|
int |
CompositeImmutableSegment.compareRows(Cell left,
Cell right) |
int |
Segment.compareRows(Cell left,
Cell right) |
Cell |
ImmutableMemStoreLAB.copyCellInto(Cell cell) |
Cell |
MemStoreLAB.copyCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
MemStoreLABImpl.copyCellInto(Cell cell) |
private Cell |
MemStoreLABImpl.copyCellInto(Cell cell,
int maxAlloc) |
private Cell |
CellChunkImmutableSegment.copyCellIntoMSLAB(Cell cell,
MemStoreSizing memstoreSizing) |
private static Cell |
MemStoreLABImpl.copyToChunkCell(Cell cell,
ByteBuffer buf,
int offset,
int len)
Clone the passed cell by copying its data into the passed buf and create a cell with a chunkid
out of it
|
private static Cell |
AbstractMemStore.deepCopyIfNeeded(Cell cell) |
private void |
AbstractMemStore.doAdd(MutableSegment currentActive,
Cell cell,
MemStoreSizing memstoreSizing) |
private void |
AbstractMemStore.doAddOrUpsert(Cell cell,
long readpoint,
MemStoreSizing memstoreSizing,
boolean doAdd) |
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
Cell kv,
boolean forward) |
private void |
AbstractMemStore.doUpsert(MutableSegment currentActive,
Cell cell,
long readpoint,
MemStoreSizing memstoreSizing) |
Filter.ReturnCode |
MobReferenceOnlyFilter.filterCell(Cell cell) |
private boolean |
HRegion.RegionScannerImpl.filterRowKey(Cell current) |
private int |
CellFlatMap.find(Cell needle)
Binary search for a given key in between given boundaries of the array.
|
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 |
MemStoreLAB.forceCopyOfBigCellInto(Cell cell)
Allocates slice in this LAB and copy the passed Cell into this area.
|
Cell |
MemStoreLABImpl.forceCopyOfBigCellInto(Cell cell)
When a cell's size is too big (bigger than maxAlloc),
copyCellInto does not allocate it on MSLAB.
|
private boolean |
KeyValueHeap.generalizedSeek(boolean isLazy,
Cell seekKey,
boolean forward,
boolean useBloom) |
Cell |
CellSet.get(Cell kv) |
(package private) static int |
Segment.getCellLength(Cell cell)
Get cell length after serialized in
KeyValue |
private Cell |
SegmentScanner.getHighest(Cell first,
Cell second)
Private internal method that returns the higher of the two key values, or null
if they are both null
|
protected Iterator<Cell> |
SegmentScanner.getIterator(Cell cell) |
private static long |
HRegion.getLongValue(Cell cell) |
protected Cell |
AbstractMemStore.getLowest(Cell a,
Cell b) |
(package private) Cell |
DefaultMemStore.getNextRow(Cell cell) |
(package private) Cell |
CompactingMemStore.getNextRow(Cell cell) |
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
private HStore |
HRegion.getStore(Cell cell)
Return HStore instance.
|
private int |
CellFlatMap.getValidIndex(Cell key,
boolean inclusive,
boolean tail)
Get the index of the given anchor key for creating subsequent 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 allocated) |
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,
boolean sizeAddedPreOperation) |
protected void |
Segment.internalAdd(Cell cell,
boolean mslabUsed,
MemStoreSizing memstoreSizing,
boolean sizeAddedPreOperation) |
private void |
AbstractMemStore.internalAdd(MutableSegment currentActive,
Cell toAdd,
boolean mslabUsed,
MemStoreSizing memstoreSizing) |
private boolean |
StripeMultiFileWriter.BoundaryMultiWriter.isCellAfterCurrentWriter(Cell cell) |
private static boolean |
StripeStoreFileManager.isOpen(Cell key) |
private boolean |
HRegion.RegionScannerImpl.joinedHeapMayHaveData(Cell currentRowCell) |
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.
|
private Cell |
AbstractMemStore.maybeCloneWithAllocator(MutableSegment currentActive,
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.
|
private boolean |
HRegion.RegionScannerImpl.moreCellsInRow(Cell nextKv,
Cell currentRowCell)
Based on the nextKv in the heap, and the current row, decide whether or not there are more
cells to be read in the heap.
|
protected boolean |
ReversedRegionScannerImpl.nextRow(ScannerContext scannerContext,
Cell curRowCell) |
protected boolean |
HRegion.RegionScannerImpl.nextRow(ScannerContext scannerContext,
Cell curRowCell) |
private int |
StripeStoreFileManager.nonOpenRowCompare(Cell k1,
byte[] k2) |
protected long |
Segment.offHeapSizeChange(Cell cell,
boolean allocated) |
private void |
StoreScanner.parallelSeek(List<? extends KeyValueScanner> scanners,
Cell kv)
Seek storefiles in parallel to optimize IO latency as much as possible
|
boolean |
StoreFileReader.passesGeneralRowColBloomFilter(Cell cell)
A method for checking Bloom filters.
|
private boolean |
HRegion.RegionScannerImpl.populateResult(List<Cell> results,
KeyValueHeap heap,
ScannerContext scannerContext,
Cell currentRowCell)
Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is
reached, or remainingResultSize (if not -1) is reaced
|
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.
|
private void |
StripeMultiFileWriter.BoundaryMultiWriter.prepareWriterFor(Cell cell) |
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.
|
protected boolean |
DefaultMemStore.preUpdate(MutableSegment currentActive,
Cell cell,
MemStoreSizing memstoreSizing) |
protected boolean |
CompactingMemStore.preUpdate(MutableSegment currentActive,
Cell cell,
MemStoreSizing memstoreSizing)
Issue any synchronization and test needed before applying the update
For compacting memstore this means checking the update can increase the size without
overflow
|
protected abstract boolean |
AbstractMemStore.preUpdate(MutableSegment currentActive,
Cell cell,
MemStoreSizing memstoreSizing)
Issue any synchronization and test needed before applying the update
|
Cell |
CellFlatMap.put(Cell k,
Cell v) |
private MobCell |
HMobStore.readCell(List<org.apache.hadoop.fs.Path> locations,
String fileName,
Cell search,
boolean cacheMobBlocks,
long readPt,
boolean readEmptyValueOnMobCellMiss)
Reads the cell from a mob file.
|
private static Cell |
HRegion.reckonDelta(Cell delta,
Cell currentCell,
byte[] columnFamily,
long now,
Mutation mutation,
Function<Cell,byte[]> supplier) |
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 |
ReversedKeyValueHeap.requestSeek(Cell key,
boolean forward,
boolean useBloom) |
boolean |
SegmentScanner.requestSeek(Cell c,
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.reseek(Cell key)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
ReversedKeyValueHeap.reseek(Cell seekKey) |
boolean |
StoreScanner.reseek(Cell kv) |
boolean |
SegmentScanner.reseek(Cell cell)
Reseek the scanner at or after the specified KeyValue.
|
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 |
SnapshotSegmentScanner.reseek(Cell seekCell) |
boolean |
ReversedStoreScanner.reseek(Cell kv) |
(package private) static boolean |
StoreFileScanner.reseekAtOrAfter(HFileScanner s,
Cell k) |
private void |
StoreScanner.resetQueryMatcher(Cell lastTopKey) |
MobCell |
HMobStore.resolve(Cell reference,
boolean cacheBlocks)
Reads the cell from the mob file, and the read point does not count.
|
MobCell |
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 |
KeyValueScanner.seek(Cell key)
Seek the scanner at or after the specified KeyValue.
|
boolean |
ReversedKeyValueHeap.seek(Cell seekKey) |
boolean |
StoreScanner.seek(Cell key) |
boolean |
SegmentScanner.seek(Cell cell)
Seek the scanner at or after the specified Cell.
|
boolean |
KeyValueHeap.seek(Cell seekKey)
Seeks all scanners at or below the specified seek key.
|
boolean |
StoreFileScanner.seek(Cell key) |
boolean |
SnapshotSegmentScanner.seek(Cell seekCell) |
boolean |
ReversedStoreScanner.seek(Cell key) |
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) |
private void |
StoreScanner.seekOrSkipToNextColumn(Cell cell) |
private void |
StoreScanner.seekOrSkipToNextRow(Cell cell) |
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 |
KeyValueScanner.seekToPreviousRow(Cell key)
Seek the scanner at the first Cell of the row which is the previous row
of specified key
|
boolean |
NonReversedNonLazyKeyValueScanner.seekToPreviousRow(Cell key) |
boolean |
ReversedKeyValueHeap.seekToPreviousRow(Cell seekKey) |
boolean |
SegmentScanner.seekToPreviousRow(Cell cell)
Seek the scanner at the first Cell of the row which is the previous row
of specified key
|
boolean |
StoreFileScanner.seekToPreviousRow(Cell originalKey) |
boolean |
ReversedStoreScanner.seekToPreviousRow(Cell key) |
protected void |
StoreFileScanner.setCurrentCell(Cell newVal) |
(package private) void |
ScannerContext.setLastPeekedCell(Cell lastPeekedCell) |
Cell |
CellFlatMap.CellFlatMapEntry.setValue(Cell value) |
protected boolean |
CompactingMemStore.shouldFlushInMemory(MutableSegment currActive,
Cell cellToAdd,
MemStoreSizing memstoreSizing) |
protected boolean |
ReversedRegionScannerImpl.shouldStop(Cell currentRowCell) |
protected boolean |
HRegion.RegionScannerImpl.shouldStop(Cell currentRowCell) |
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> |
DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate) |
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.
|
(package private) void |
HRegion.updateDeleteLatestVersionTimestamp(Cell cell,
Get get,
int count,
byte[] byteNow) |
protected void |
CompositeImmutableSegment.updateMetaInfo(Cell cellToAdd,
boolean succ,
boolean mslabUsed,
MemStoreSizing memstoreSizing,
boolean sizeAddedPreOperation) |
protected void |
Segment.updateMetaInfo(Cell cellToAdd,
boolean succ,
boolean mslabUsed,
MemStoreSizing memstoreSizing,
boolean sizeAddedPreOperation) |
protected void |
Segment.updateMetaInfo(Cell cellToAdd,
boolean succ,
MemStoreSizing memstoreSizing) |
private void |
AbstractMemStore.upsert(Cell cell,
long readpoint,
MemStoreSizing memstoreSizing) |
void |
MutableSegment.upsert(Cell cell,
long readpoint,
MemStoreSizing memStoreSizing,
boolean sizeAddedPreOperation) |
Modifier and Type | Method and Description |
---|---|
void |
HStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing)
Adds the specified value to the memstore
|
void |
MemStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing)
Write the updates
|
void |
AbstractMemStore.add(Iterable<Cell> cells,
MemStoreSizing memstoreSizing) |
boolean |
CellFlatMap.CellFlatMapCollection.addAll(Collection<? extends Cell> collection) |
boolean |
CellSet.addAll(Collection<? extends Cell> c) |
protected void |
HRegion.BatchOperation.applyFamilyMapToMemStore(Map<byte[],List<Cell>> familyMap,
MemStoreSizing memstoreAccounting)
Atomically apply the given map of family->edits to the memstore.
|
private void |
HRegion.applyToMemStore(HStore store,
List<Cell> cells,
boolean delta,
MemStoreSizing memstoreAccounting) |
void |
HRegion.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now)
Check the collection of families for valid timestamps
|
(package private) void |
HRegion.delete(NavigableMap<byte[],List<Cell>> familyMap,
Durability durability)
This is used only by unit tests.
|
private List<Cell> |
HRegion.get(Mutation mutation,
HStore store,
List<Cell> coordinates,
IsolationLevel isolation,
TimeRange tr)
Do a specific Get on passed
columnFamily and column qualifiers. |
protected Cell |
AbstractMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
private void |
HRegion.MutationBatchOperation.mergeFamilyMaps(Map<byte[],List<Cell>> familyMap,
Map<byte[],List<Cell>> toBeMerged) |
private void |
HRegion.MutationBatchOperation.mergeFamilyMaps(Map<byte[],List<Cell>> familyMap,
Map<byte[],List<Cell>> toBeMerged) |
(package private) void |
HRegion.metricsUpdateForGet(List<Cell> results,
long before) |
private ScannerContext.NextState |
StoreScanner.needToReturn(List<Cell> outResult)
If the top cell won't be flushed into disk, the new top cell may be
changed after #reopenAfterFlush.
|
default boolean |
InternalScanner.next(List<Cell> result)
Grab the next row's worth of values.
|
boolean |
HRegion.RegionScannerImpl.next(List<Cell> outResults) |
boolean |
StoreScanner.next(List<Cell> outResult,
ScannerContext scannerContext)
Get the next row of values from this Store.
|
boolean |
MobStoreScanner.next(List<Cell> outResult,
ScannerContext ctx)
Firstly reads the cells from the HBase.
|
boolean |
InternalScanner.next(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
boolean |
ReversedMobStoreScanner.next(List<Cell> outResult,
ScannerContext ctx)
Firstly reads the cells from the HBase.
|
boolean |
HRegion.RegionScannerImpl.next(List<Cell> outResults,
ScannerContext scannerContext) |
boolean |
KeyValueHeap.next(List<Cell> result,
ScannerContext scannerContext)
Gets the next row of keys from the top-most scanner.
|
private boolean |
HRegion.RegionScannerImpl.nextInternal(List<Cell> results,
ScannerContext scannerContext) |
boolean |
RegionScanner.nextRaw(List<Cell> result)
Grab the next row's worth of values.
|
boolean |
HRegion.RegionScannerImpl.nextRaw(List<Cell> outResults) |
boolean |
RegionScanner.nextRaw(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
boolean |
HRegion.RegionScannerImpl.nextRaw(List<Cell> outResults,
ScannerContext scannerContext) |
private boolean |
HRegion.RegionScannerImpl.populateFromJoinedHeap(List<Cell> results,
ScannerContext scannerContext) |
private boolean |
HRegion.RegionScannerImpl.populateResult(List<Cell> results,
KeyValueHeap heap,
ScannerContext scannerContext,
Cell currentRowCell)
Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is
reached, or remainingResultSize (if not -1) is reaced
|
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postAppendBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postAppendBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postIncrementBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
RegionCoprocessorHost.postIncrementBeforeWAL(Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
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.
|
(package private) void |
HRegion.put(byte[] row,
byte[] family,
List<Cell> edits)
Add updates first to the wal and then add values to memstore.
|
void |
CellFlatMap.putAll(Map<? extends Cell,? extends Cell> map) |
void |
CellFlatMap.putAll(Map<? extends Cell,? extends Cell> map) |
private static Cell |
HRegion.reckonDelta(Cell delta,
Cell currentCell,
byte[] columnFamily,
long now,
Mutation mutation,
Function<Cell,byte[]> supplier) |
private WALEdit |
HRegion.reckonDeltas(Region.Operation op,
Mutation mutation,
Durability effectiveDurability,
Map<HStore,List<Cell>> forMemStore,
List<Cell> results)
Reckon the Cells to apply to WAL, memstore, and to return to the Client; these Sets are not
always the same dependent on whether to write WAL.
|
private WALEdit |
HRegion.reckonDeltas(Region.Operation op,
Mutation mutation,
Durability effectiveDurability,
Map<HStore,List<Cell>> forMemStore,
List<Cell> results)
Reckon the Cells to apply to WAL, memstore, and to return to the Client; these Sets are not
always the same dependent on whether to write WAL.
|
private List<Cell> |
HRegion.reckonDeltasByStore(HStore store,
Region.Operation op,
Mutation mutation,
Durability effectiveDurability,
long now,
List<Cell> deltas,
List<Cell> results)
Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed
column family/Store.
|
private List<Cell> |
HRegion.reckonDeltasByStore(HStore store,
Region.Operation op,
Mutation mutation,
Durability effectiveDurability,
long now,
List<Cell> deltas,
List<Cell> results)
Reckon the Cells to apply to WAL, memstore, and to return to the Client in passed
column family/Store.
|
private void |
HRegion.recordMutationWithoutWal(Map<byte[],List<Cell>> familyMap)
Update LongAdders for number of puts without wal and the size of possible data loss.
|
(package private) void |
HRegion.rewriteCellTags(Map<byte[],List<Cell>> familyMap,
Mutation m)
Possibly rewrite incoming cell tags.
|
private static List<Cell> |
HRegion.sort(List<Cell> cells,
CellComparator comparator) |
private static void |
HRegion.updateCellTimestamps(Iterable<List<Cell>> cellItr,
byte[] now)
Replace any cell timestamps set to
HConstants.LATEST_TIMESTAMP
provided current timestamp. |
private void |
HRegion.updateSequenceId(Iterable<List<Cell>> cellItr,
long sequenceId) |
void |
HStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing)
Adds or replaces the specified KeyValues.
|
void |
MemStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing)
Update or insert the specified cells.
|
void |
AbstractMemStore.upsert(Iterable<Cell> cells,
long readpoint,
MemStoreSizing memstoreSizing) |
Constructor and Description |
---|
CellArrayMap(Comparator<? super Cell> comparator,
Cell[] b,
int min,
int max,
boolean descending) |
CellFlatMapEntry(Cell cell) |
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) |
CellSet(NavigableMap<Cell,Cell> m) |
CellSet(NavigableMap<Cell,Cell> m) |
CellSet(NavigableMap<Cell,Cell> m,
int numUniqueKeys) |
CellSet(NavigableMap<Cell,Cell> m,
int numUniqueKeys) |
Modifier and Type | Field and Description |
---|---|
private Cell |
ParallelSeekHandler.keyValue |
Constructor and Description |
---|
ParallelSeekHandler(KeyValueScanner scanner,
Cell keyValue,
long readPoint,
CountDownLatch latch) |
Modifier and Type | Field and Description |
---|---|
private Cell |
ScanWildcardColumnTracker.columnCell |
private Cell |
UserScanQueryMatcher.curColCell |
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 |
---|---|
private static Cell |
UserScanQueryMatcher.createStartKey(Scan scan,
ScanInfo scanInfo) |
protected static Cell |
ScanQueryMatcher.createStartKeyFromRow(byte[] startRow,
ScanInfo scanInfo) |
Cell |
ScanQueryMatcher.currentRow() |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell cell) |
abstract Cell |
ScanQueryMatcher.getNextKeyHint(Cell cell)
Delegate to
Filter.getNextCellHint(Cell) . |
Cell |
UserScanQueryMatcher.getNextKeyHint(Cell cell) |
Cell |
CompactionScanQueryMatcher.getNextKeyHint(Cell cell) |
Cell |
ScanQueryMatcher.getStartKey() |
Modifier and Type | Method and Description |
---|---|
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 |
ScanDeleteTracker.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 |
NewVersionBehaviorTracker.checkColumn(Cell cell,
byte type) |
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 |
ColumnTracker.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 |
ScanWildcardColumnTracker.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 |
NewVersionBehaviorTracker.checkVersions(Cell cell,
long timestamp,
byte type,
boolean ignoreCount) |
ScanQueryMatcher.MatchCode |
ExplicitColumnTracker.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.
|
ScanQueryMatcher.MatchCode |
ScanWildcardColumnTracker.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) |
abstract Cell |
ScanQueryMatcher.getNextKeyHint(Cell cell)
Delegate to
Filter.getNextCellHint(Cell) . |
Cell |
UserScanQueryMatcher.getNextKeyHint(Cell cell) |
Cell |
CompactionScanQueryMatcher.getNextKeyHint(Cell cell) |
ScanQueryMatcher.MatchCode |
NewVersionBehaviorTracker.getNextRowOrNextColumn(Cell cell) |
ScanQueryMatcher.MatchCode |
ExplicitColumnTracker.getNextRowOrNextColumn(Cell cell) |
ScanQueryMatcher.MatchCode |
ColumnTracker.getNextRowOrNextColumn(Cell cell)
Retrieve the MatchCode for the next row or column
|
ScanQueryMatcher.MatchCode |
ScanWildcardColumnTracker.getNextRowOrNextColumn(Cell cell) |
private static boolean |
ScanQueryMatcher.isCellTTLExpired(Cell cell,
long oldestTimestamp,
long now) |
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.
|
DeleteTracker.DeleteResult |
ScanDeleteTracker.isDeleted(Cell cell)
Check if the specified Cell buffer has been deleted by a previously seen delete.
|
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)
|
ScanQueryMatcher.MatchCode |
StripeCompactionScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
RawScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
MajorCompactionScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
IncludeAllCompactionQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
NormalUserScanQueryMatcher.match(Cell cell) |
ScanQueryMatcher.MatchCode |
MinorCompactionScanQueryMatcher.match(Cell cell) |
protected ScanQueryMatcher.MatchCode |
UserScanQueryMatcher.matchColumn(Cell cell,
long timestamp,
byte typeByte) |
private ScanQueryMatcher.MatchCode |
UserScanQueryMatcher.mergeFilterResponse(Cell cell,
ScanQueryMatcher.MatchCode matchCode,
Filter.ReturnCode filterResponse)
Call this when scan has filter.
|
abstract boolean |
ScanQueryMatcher.moreRowsMayExistAfter(Cell cell) |
boolean |
UserScanQueryMatcher.moreRowsMayExistAfter(Cell cell) |
boolean |
CompactionScanQueryMatcher.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.
|
private void |
ScanWildcardColumnTracker.resetCell(Cell columnCell) |
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 |
---|---|
protected Cell |
WALCellCodec.CompressedKvDecoder.parseCell() |
protected Cell |
SecureWALCellCodec.EncryptedKvDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
void |
WALCellCodec.CompressedKvEncoder.write(Cell cell) |
void |
WALCellCodec.EnsureKvEncoder.write(Cell cell) |
void |
SecureWALCellCodec.EncryptedKvEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
(package private) static Set<byte[]> |
FSWALEntry.collectFamilies(List<Cell> cells) |
static void |
WALUtil.filterCells(WALEdit edit,
Function<Cell,Cell> mapper) |
static void |
WALUtil.filterCells(WALEdit edit,
Function<Cell,Cell> mapper) |
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 |
WALCellFilter.filterCell(WAL.Entry entry,
Cell cell)
Applies the filter, possibly returning a different Cell instance.
|
Cell |
NamespaceTableCfWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Cell |
ScopeWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
private void |
VerifyWALEntriesReplicationEndpoint.checkCell(Cell cell) |
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 |
WALCellFilter.filterCell(WAL.Entry entry,
Cell cell)
Applies the filter, possibly returning a different Cell instance.
|
Cell |
NamespaceTableCfWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Cell |
ScopeWALEntryFilter.filterCell(WAL.Entry entry,
Cell cell) |
Modifier and Type | Field and Description |
---|---|
private Cell |
SerialReplicationSourceWALReader.firstCellInEntryBeforeFiltering |
Modifier and Type | Method and Description |
---|---|
boolean |
SerialReplicationChecker.canPush(WAL.Entry entry,
Cell firstCellInEdit) |
private boolean |
ReplicationSink.isNewRowOrType(Cell previousCell,
Cell cell) |
void |
SerialReplicationChecker.waitUntilCanPush(WAL.Entry entry,
Cell firstCellInEdit) |
Modifier and Type | Field and Description |
---|---|
private Cell |
RowResultGenerator.cache |
private Cell |
ScannerResultGenerator.cache |
Modifier and Type | Field and Description |
---|---|
private Iterator<Cell> |
ScannerResultGenerator.rowI |
private Iterator<Cell> |
RowResultGenerator.valuesI |
Modifier and Type | Method and Description |
---|---|
Cell |
RowResultGenerator.next() |
Cell |
ScannerResultGenerator.next() |
Modifier and Type | Method and Description |
---|---|
abstract void |
ResultGenerator.putBack(Cell kv) |
void |
RowResultGenerator.putBack(Cell kv) |
void |
ScannerResultGenerator.putBack(Cell kv) |
Constructor and Description |
---|
CellModel(Cell cell)
Constructor from KeyValue
|
Modifier and Type | Method and Description |
---|---|
private Cell |
AccessController.createNewCellWithTags(Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
List<Pair<Cell,Cell>> |
AccessController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
AccessController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
AccessController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
AccessController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
Modifier and Type | Method and Description |
---|---|
boolean |
AuthManager.authorizeCell(User user,
TableName table,
Cell cell,
Permission.Action action)
Check if user has given action privilige in cell scope.
|
private Cell |
AccessController.createNewCellWithTags(Mutation mutation,
Cell oldCell,
Cell newCell) |
Filter.ReturnCode |
AccessControlFilter.filterCell(Cell cell) |
boolean |
AccessControlFilter.filterRowKey(Cell cell) |
static List<Permission> |
PermissionStorage.getCellPermissionsForUser(User user,
Cell cell) |
private static Pair<String,Permission> |
PermissionStorage.parsePermissionRecord(byte[] entryName,
Cell kv,
byte[] cf,
byte[] cq,
boolean filterPerms,
String filterUser) |
boolean |
AccessController.postScannerFilterRow(ObserverContext<RegionCoprocessorEnvironment> e,
InternalScanner s,
Cell curRowCell,
boolean hasMore) |
Modifier and Type | Method and Description |
---|---|
private Cell |
VisibilityController.createNewCellWithTags(Mutation mutation,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
protected List<List<Cell>> |
DefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths() |
List<Pair<Cell,Cell>> |
VisibilityController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
VisibilityController.postAppendBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
VisibilityController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
List<Pair<Cell,Cell>> |
VisibilityController.postIncrementBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation mutation,
List<Pair<Cell,Cell>> cellPairs) |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityNewVersionBehaivorTracker.add(Cell cell) |
void |
VisibilityScanDeleteTracker.add(Cell delCell) |
void |
VisibilityNewVersionBehaivorTracker.VisibilityDeleteVersionsNode.addVersionDelete(Cell cell) |
private boolean |
VisibilityController.checkForReservedVisibilityTagPresence(Cell cell)
Checks whether cell contains any tag with type as VISIBILITY_TAG_TYPE.
|
private Pair<Boolean,Tag> |
VisibilityController.checkForReservedVisibilityTagPresence(Cell cell,
Pair<Boolean,Tag> pair)
Checks whether cell contains any tag with type as VISIBILITY_TAG_TYPE.
|
private Cell |
VisibilityController.createNewCellWithTags(Mutation mutation,
Cell newCell) |
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
|
private boolean |
VisibilityScanDeleteTracker.extractDeleteCellVisTags(Cell delCell,
KeyValue.Type type) |
static Byte |
VisibilityUtils.extractVisibilityTags(Cell cell,
List<Tag> tags)
Extract the visibility tags of the given Cell into the given List
|
Filter.ReturnCode |
VisibilityLabelFilter.filterCell(Cell cell) |
Filter.ReturnCode |
VisibilityController.DeleteVersionVisibilityExpressionFilter.filterCell(Cell cell) |
boolean |
VisibilityLabelFilter.filterRowKey(Cell cell) |
boolean |
VisibilityController.DeleteVersionVisibilityExpressionFilter.filterRowKey(Cell cell) |
DeleteTracker.DeleteResult |
VisibilityNewVersionBehaivorTracker.isDeleted(Cell cell) |
DeleteTracker.DeleteResult |
VisibilityScanDeleteTracker.isDeleted(Cell cell) |
static boolean |
VisibilityUtils.isVisibilityTagsPresent(Cell cell) |
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) |
private boolean |
VisibilityNewVersionBehaivorTracker.tagMatched(Cell put,
VisibilityNewVersionBehaivorTracker.TagInfo delInfo) |
Constructor and Description |
---|
TagInfo(Cell c) |
Modifier and Type | Method and Description |
---|---|
static List<org.apache.hadoop.hbase.thrift.generated.TCell> |
ThriftUtilities.cellFromHBase(Cell in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell object.
|
static List<org.apache.hadoop.hbase.thrift.generated.TCell> |
ThriftUtilities.cellFromHBase(Cell[] in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell array.
|
Modifier and Type | Field and Description |
---|---|
private static Cell[] |
ThriftUtilities.EMPTY_CELL_ARRAY |
Modifier and Type | Method and Description |
---|---|
static Cell |
ThriftUtilities.toCell(ExtendedCellBuilder cellBuilder,
byte[] row,
org.apache.hadoop.hbase.thrift2.generated.TColumnValue columnValue) |
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 | Field and Description |
---|---|
private Cell |
MapReduceExtendedCell.cell |
private Cell |
CollectionBackedScanner.current |
Modifier and Type | Field and Description |
---|---|
private Iterable<Cell> |
CollectionBackedScanner.data |
private Iterator<Cell> |
CollectionBackedScanner.iter |
Modifier and Type | Method and Description |
---|---|
Cell |
BloomContext.getLastCell() |
Cell |
BloomFilterWriter.getPrevCell()
Returns the previous cell written by this writer
|
private Cell |
RowPrefixFixedLengthBloomContext.getRowPrefixCell(Cell cell) |
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.
since 2.0.0 and will be removed in 3.0.0. Use
Bytes.binarySearch(Cell[], Cell, CellComparator) instead. |
static int |
Bytes.binarySearch(Cell[] arr,
Cell key,
CellComparator comparator)
Binary search for keys in indexes.
|
static int |
Bytes.binarySearch(Cell[] arr,
Cell key,
CellComparator comparator)
Binary search for keys in indexes.
|
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) |
private Cell |
RowPrefixFixedLengthBloomContext.getRowPrefixCell(Cell cell) |
protected boolean |
RowBloomContext.isNewKey(Cell cell) |
protected abstract boolean |
BloomContext.isNewKey(Cell cell)
Returns true if the cell is a new key as per the bloom type
|
protected boolean |
RowColBloomContext.isNewKey(Cell cell) |
boolean |
CollectionBackedScanner.reseek(Cell seekCell) |
private void |
BloomContext.sanityCheck(Cell cell) |
boolean |
CollectionBackedScanner.seek(Cell seekCell) |
void |
BloomContext.writeBloom(Cell cell)
Bloom information from the cell is retrieved
|
void |
RowPrefixFixedLengthBloomContext.writeBloom(Cell cell) |
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Deprecated.
since 2.0.0 and will be removed in 3.0.0. Use
Bytes.binarySearch(Cell[], Cell, CellComparator) instead. |
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 | Field and Description |
---|---|
private ArrayList<Cell> |
WALEdit.cells |
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) |
private WALEdit |
WALEdit.addCell(Cell cell) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.BulkLoadDescriptor |
WALEdit.getBulkLoadDescriptor(Cell cell)
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.CompactionDescriptor |
WALEdit.getCompaction(Cell kv)
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
|
static org.apache.hadoop.hbase.shaded.protobuf.generated.WALProtos.FlushDescriptor |
WALEdit.getFlushDescriptor(Cell cell) |
static org.apache.hadoop.hbase.shaded.protobuf.generated.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)
Replaying WALs can read Cell-at-a-time so need this method in those cases.
|
static Map<String,Object> |
WALPrettyPrinter.toStringMap(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–2020 The Apache Software Foundation. All rights reserved.