Modifier and Type | Class and Description |
---|---|
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 |
NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0
|
class |
TagRewriteCell
This can be used when a Cell has to change with addition/removal of one or more tags.
|
Modifier and Type | Field and Description |
---|---|
static Cell |
HConstants.NO_NEXT_INDEXED_KEY
The byte array represents for NO_NEXT_INDEXED_KEY;
The actual value is irrelevant because this is always compared by reference.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
CellUtil.createCell(byte[] row)
Create a Cell with specific row.
|
static Cell |
CellUtil.createCell(byte[] row,
byte[] value)
Create a Cell with specific row and value.
|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier)
Create a Cell with specific row.
|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
byte[] tags,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
KeyValue.Type type,
byte[] value,
byte[] tags) |
static Cell |
CellUtil.createCell(byte[] rowArray,
int rowOffset,
int rowLength,
byte[] familyArray,
int familyOffset,
int familyLength,
byte[] qualifierArray,
int qualifierOffset,
int qualifierLength) |
Cell |
CellScanner.current() |
static Cell |
CellComparator.getMidpoint(KeyValue.KVComparator comparator,
Cell left,
Cell right)
Try to return a Cell that falls between
left and right but that is
shorter; i.e. |
Modifier and Type | Method and Description |
---|---|
static List<Cell> |
HBaseTestingUtility.getFromStoreFile(HStore store,
byte[] row,
NavigableSet<byte[]> columns)
Do a small get/scan against one store.
|
static List<Cell> |
HBaseTestingUtility.getFromStoreFile(HStore store,
Get get)
Do a small get/scan against one store.
|
Modifier and Type | Method and Description |
---|---|
static int |
KeyValueUtil.appendKeyTo(Cell cell,
byte[] output,
int offset) |
static int |
KeyValueUtil.appendToByteArray(Cell cell,
byte[] output,
int offset)
copy key and value
|
static boolean |
CellComparator.areKeyLengthsEqual(Cell a,
Cell b)
lengths
|
static boolean |
CellComparator.areRowLengthsEqual(Cell a,
Cell b) |
static void |
PerformanceEvaluationCommons.assertKey(byte[] expected,
Cell c) |
static KeyValue |
KeyValue.cloneAndAddTags(Cell c,
List<Tag> newTags)
Create a new KeyValue by copying existing cell and adding new tags
|
static byte[] |
CellUtil.cloneFamily(Cell cell) |
static byte[] |
CellUtil.cloneQualifier(Cell cell) |
static byte[] |
CellUtil.cloneRow(Cell cell)
get individual arrays for tests
|
static byte[] |
CellUtil.cloneValue(Cell cell) |
int |
CellComparator.compare(Cell a,
Cell b) |
int |
CellComparator.RowComparator.compare(Cell a,
Cell b) |
int |
KeyValue.MetaComparator.compare(Cell left,
Cell right)
Compare key portion of a
KeyValue for keys in hbase:meta
table. |
int |
KeyValue.KVComparator.compare(Cell left,
Cell right)
Compares the Key of a cell -- with fields being more significant in this order:
rowkey, colfam/qual, timestamp, type, mvcc
|
int |
KeyValue.RawBytesComparator.compare(Cell left,
Cell right) |
static int |
CellComparator.compare(Cell a,
Cell b,
boolean ignoreSequenceid)
Compare cells.
|
static int |
CellComparator.compareColumns(Cell left,
Cell right) |
static int |
CellComparator.compareCommonFamilyPrefix(Cell left,
Cell right,
int familyCommonPrefix) |
static int |
CellComparator.compareCommonQualifierPrefix(Cell left,
Cell right,
int qualCommonPrefix) |
static int |
CellComparator.compareCommonRowPrefix(Cell left,
Cell right,
int rowCommonPrefix) |
static int |
CellComparator.compareFamilies(Cell left,
Cell right) |
int |
CellComparator.compareFlatKey(Cell left,
Cell right) |
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) |
int |
KeyValue.MetaComparator.compareOnlyKeyPortion(Cell left,
Cell right) |
int |
KeyValue.KVComparator.compareOnlyKeyPortion(Cell left,
Cell right) |
int |
KeyValue.RawBytesComparator.compareOnlyKeyPortion(Cell left,
Cell right) |
static int |
CellComparator.compareQualifiers(Cell left,
Cell right) |
protected int |
KeyValue.MetaComparator.compareRowKey(Cell l,
Cell r)
Override the row key comparison to parse and compare the meta row key parts.
|
protected int |
KeyValue.KVComparator.compareRowKey(Cell left,
Cell right)
Compares the only the user specified portion of a Key.
|
static int |
CellComparator.compareRows(Cell left,
Cell right)
Do not use comparing rows from hbase:meta.
|
int |
KeyValue.KVComparator.compareRows(Cell left,
Cell right) |
static int |
CellComparator.compareTimestamps(Cell left,
Cell right) |
int |
KeyValue.KVComparator.compareTimestamps(Cell left,
Cell right) |
static int |
CellComparator.compareWithoutRow(Cell leftCell,
Cell rightCell) |
static int |
CellUtil.copyFamilyTo(Cell cell,
byte[] destination,
int destinationOffset) |
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) |
static int |
CellUtil.copyRowTo(Cell cell,
byte[] destination,
int destinationOffset)
copyTo
|
static int |
CellUtil.copyTagTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the tags info into the tag portion of the cell
|
static byte[] |
KeyValueUtil.copyToNewByteArray(Cell cell) |
static ByteBuffer |
KeyValueUtil.copyToNewByteBuffer(Cell cell)
The position will be set to the beginning of the new ByteBuffer
|
static KeyValue |
KeyValueUtil.copyToNewKeyValue(Cell cell)
copy key only
|
static int |
CellUtil.copyValueTo(Cell cell,
byte[] destination,
int destinationOffset) |
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray) |
static KeyValue |
KeyValueUtil.createFirstKeyInIncrementedRow(Cell in)
Increment the row bytes and clear the other fields
|
static KeyValue |
KeyValueUtil.createFirstKeyInNextRow(Cell in)
Append single byte 0x00 to the end of the input row key
|
static KeyValue |
KeyValueUtil.createFirstOnRowColTS(Cell kv,
long ts)
Creates the first KV with the row/family/qualifier of this KV and the given
timestamp.
|
static KeyValue |
KeyValueUtil.createLastOnRow(Cell kv)
Creates a keyValue for the specified keyvalue larger than or equal to all other possible
KeyValues that have the same row, family, qualifer.
|
static KeyValue |
KeyValueUtil.createLastOnRowCol(Cell kv)
Similar to
KeyValueUtil.createLastOnRow(byte[], int, int, byte[], int, int, byte[], int, int)
but creates the last key on the row/column of this KV (the value part of
the returned KV is always empty). |
static KeyValue |
KeyValueUtil.ensureKeyValue(Cell cell)
Deprecated.
without any replacement.
|
static boolean |
CellComparator.equals(Cell a,
Cell b)
equals
|
static boolean |
CellComparator.equalsFamily(Cell a,
Cell b) |
static boolean |
CellComparator.equalsIgnoreMvccVersion(Cell a,
Cell b)
special case for KeyValue.equals
|
static boolean |
CellComparator.equalsQualifier(Cell a,
Cell b) |
static boolean |
CellComparator.equalsRow(Cell a,
Cell b) |
static boolean |
CellComparator.equalsTimestamp(Cell a,
Cell b) |
static boolean |
CellComparator.equalsType(Cell a,
Cell b) |
static long |
CellUtil.estimatedHeapSizeOf(Cell cell)
This is an estimate of the heap space occupied by a cell.
|
static long |
CellUtil.estimatedHeapSizeOfWithoutTags(Cell cell)
Deprecated.
|
static int |
CellUtil.estimatedSerializedSizeOf(Cell cell) |
static int |
CellUtil.estimatedSerializedSizeOfKey(Cell cell) |
static int |
CellUtil.estimatedSizeOf(Cell cell)
Deprecated.
please use estimatedSerializedSizeOf(Cell)
|
static ByteRange |
CellUtil.fillFamilyRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillQualifierRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillRowRange(Cell cell,
ByteRange range)
ByteRange
|
static ByteRange |
CellUtil.fillTagRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillValueRange(Cell cell,
ByteRange range) |
static int |
CellComparator.findCommonPrefixInFamilyPart(Cell left,
Cell right,
int familyCommonPrefix) |
static int |
CellUtil.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 |
CellComparator.findCommonPrefixInQualifierPart(Cell left,
Cell right,
int qualifierCommonPrefix) |
static int |
CellComparator.findCommonPrefixInRowPart(Cell left,
Cell right,
int rowCommonPrefix) |
static String |
CellUtil.getCellKeyAsString(Cell cell) |
static byte[] |
CellUtil.getCellKeySerializedAsKeyValueKey(Cell cell)
This method exists just to encapsulate how we serialize keys.
|
static Cell |
CellComparator.getMidpoint(KeyValue.KVComparator comparator,
Cell left,
Cell right)
Try to return a Cell that falls between
left and right but that is
shorter; i.e. |
static ByteBuffer |
CellUtil.getQualifierBufferShallowCopy(Cell cell) |
static byte |
CellUtil.getRowByte(Cell cell,
int index)
misc
|
static byte[] |
CellUtil.getTagArray(Cell cell)
Returns tag value in a new byte array.
|
static ByteBuffer |
CellUtil.getValueBufferShallowCopy(Cell cell) |
static int |
CellComparator.hashCode(Cell cell)
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
|
static int |
CellComparator.hashCodeIgnoreMvcc(Cell cell)
Returns a hash code that is always the same for two Cells having a matching
equals(..) result.
|
static boolean |
CellUtil.isDelete(Cell cell) |
static boolean |
CellUtil.isDeleteColumnOrFamily(Cell cell) |
static boolean |
CellUtil.isDeleteColumns(Cell cell) |
static boolean |
CellUtil.isDeleteColumnVersion(Cell cell) |
static boolean |
CellUtil.isDeleteFamily(Cell cell) |
static boolean |
CellUtil.isDeleteFamilyVersion(Cell cell) |
static boolean |
CellUtil.isDeleteType(Cell cell) |
static int |
KeyValueUtil.keyLength(Cell cell)
Returns number of bytes this cell's key part would have been used if serialized as in
KeyValue . |
static int |
KeyValueUtil.length(Cell cell)
Returns number of bytes this cell would have been used if serialized as in
KeyValue |
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
int foffset,
int flength,
byte[] qual,
int qoffset,
int qlength) |
static boolean |
CellUtil.matchingColumn(Cell left,
Cell right) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf,
int offset,
int length) |
static boolean |
CellUtil.matchingFamily(Cell left,
Cell right) |
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf,
int offset,
int length) |
static boolean |
CellUtil.matchingQualifier(Cell left,
Cell right) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf,
int offset,
int length) |
static boolean |
CellUtil.matchingRow(Cell left,
Cell right) |
boolean |
KeyValue.KVComparator.matchingRowColumn(Cell left,
Cell right)
Compares the row and column of two keyvalues for equality
|
boolean |
KeyValue.KVComparator.matchingRows(Cell left,
Cell right)
Compares the row of two keyvalues for equality
|
static boolean |
CellUtil.matchingValue(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingValue(Cell left,
Cell right) |
static void |
KeyValueUtil.oswrite(Cell cell,
OutputStream out,
boolean withTags) |
static void |
CellUtil.setSequenceId(Cell cell,
long seqId)
Sets the given seqId to the cell.
|
static void |
CellUtil.setTimestamp(Cell cell,
byte[] ts,
int tsOffset)
Sets the given timestamp to the cell.
|
static void |
CellUtil.setTimestamp(Cell cell,
long ts)
Sets the given timestamp to the cell.
|
static String |
CellUtil.toString(Cell cell,
boolean verbose)
Returns a string representation of the cell
|
static boolean |
CellUtil.updateLatestStamp(Cell cell,
byte[] ts,
int tsOffset)
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP . |
static boolean |
CellUtil.updateLatestStamp(Cell cell,
long ts)
Sets the given timestamp to the cell iff current timestamp is
HConstants.LATEST_TIMESTAMP . |
static void |
CellUtil.writeFlatKey(Cell cell,
DataOutputStream out)
Writes the Cell's key part as it would have serialized in a KeyValue.
|
static void |
CellUtil.writeRowKeyExcludingCommon(Cell cell,
short rLen,
int commonPrefix,
DataOutputStream out)
Write rowkey excluding the common part.
|
Modifier and Type | Method and Description |
---|---|
static void |
HBaseTestingUtility.assertKVListsEqual(String additionalMsg,
List<? extends Cell> expected,
List<? extends Cell> actual) |
static void |
HBaseTestingUtility.assertKVListsEqual(String additionalMsg,
List<? extends Cell> expected,
List<? extends Cell> actual) |
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.
|
boolean |
HBaseTestCase.ScannerIncommon.next(List<Cell> values) |
boolean |
HBaseTestCase.ClientScannerIncommon.next(List<Cell> values) |
boolean |
HBaseTestCase.InternalScannerIncommon.next(List<Cell> results) |
Constructor and Description |
---|
KeyValue(Cell c) |
TagRewriteCell(Cell cell,
byte[] tags) |
Modifier and Type | Field and Description |
---|---|
protected NavigableMap<byte[],List<Cell>> |
Mutation.familyMap |
Modifier and Type | Method and Description |
---|---|
Cell |
Result.current() |
Cell |
Result.getColumnLatestCell(byte[] family,
byte[] qualifier)
The Cell for the most recent timestamp for a given column.
|
Cell |
Result.getColumnLatestCell(byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
The Cell for the most recent timestamp for a given column.
|
Cell[] |
Result.rawCells()
Return the array of Cells backing this Result instance.
|
Modifier and Type | Method and Description |
---|---|
List<Cell> |
Put.get(byte[] family,
byte[] qualifier)
Returns a list of all KeyValue objects with matching column family and qualifier.
|
List<Cell> |
Result.getColumnCells(byte[] family,
byte[] qualifier)
Return the Cells for the specific column.
|
NavigableMap<byte[],List<Cell>> |
Mutation.getFamilyCellMap()
Method for retrieving the put's familyMap
|
List<Cell> |
Result.listCells()
Create a sorted list of the Cell's in this result.
|
Modifier and Type | Method and Description |
---|---|
Append |
Append.add(Cell cell)
Add column and value to this Append operation.
|
Increment |
Increment.add(Cell cell)
Add the specified KeyValue to this operation.
|
Put |
Put.add(Cell kv)
Add the specified KeyValue to this Put operation.
|
Delete |
Delete.addDeleteMarker(Cell kv)
Advanced use only.
|
protected int |
Result.binarySearch(Cell[] kvs,
byte[] family,
byte[] qualifier) |
protected int |
Result.binarySearch(Cell[] kvs,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Searches for the latest value for the specified column.
|
static Result |
Result.create(Cell[] cells)
Instantiate a Result with the specified array of KeyValues.
|
static Result |
Result.create(Cell[] cells,
Boolean exists,
boolean stale) |
static Result |
Result.create(Cell[] cells,
Boolean exists,
boolean stale,
boolean partial) |
Filter.ReturnCode |
TestHCM.BlockingFilter.filterKeyValue(Cell ignored) |
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 partial) |
void |
TestClientOperationInterrupt.TestCoprocessor.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
TestHCM.SleepAndFailFirstTime.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
TestReplicasClient.SlowMeCopro.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
TestReplicaWithCluster.SlowMeCopro.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Append |
Append.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Delete |
Delete.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Increment |
Increment.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Mutation |
Mutation.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Method for setting the put's familyMap
|
Put |
Put.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Modifier and Type | Method and Description |
---|---|
BigDecimal |
BigDecimalColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Double |
DoubleColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
Long |
LongColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Modifier and Type | Method and Description |
---|---|
Cell |
BaseDecoder.current() |
protected abstract Cell |
BaseDecoder.parseCell()
Extract a Cell.
|
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
abstract void |
BaseEncoder.write(Cell cell) |
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
Cell |
PrefixTreeSeeker.get()
Currently unused.
|
Cell |
PrefixTreeSeeker.getKeyValue()
currently must do deep copy into new array
|
Modifier and Type | Method and Description |
---|---|
int |
PrefixTreeSeeker.compareKey(KeyValue.KVComparator comparator,
Cell key) |
int |
PrefixTreeCodec.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
PrefixTreeSeeker.seekToKeyInBlock(Cell key,
boolean forceBeforeOnExactMatch) |
protected int |
PrefixTreeSeeker.seekToOrBeforeUsingPositionAtOrAfter(Cell kv,
boolean seekBefore) |
protected int |
PrefixTreeSeeker.seekToOrBeforeUsingPositionAtOrBefore(Cell kv,
boolean seekBefore) |
Modifier and Type | Class and Description |
---|---|
class |
PrefixTreeArrayReversibleScanner
Methods for going backwards through a PrefixTree block.
|
class |
PrefixTreeArrayScanner
Extends PtCell and manipulates its protected fields.
|
class |
PrefixTreeArraySearcher
Searcher extends the capabilities of the Scanner + ReversibleScanner to add the ability to
position itself on a requested Cell without scanning through cells before it.
|
class |
PrefixTreeCell
As the PrefixTreeArrayScanner moves through the tree bytes, it changes the values in the fields
of this class so that Cell logic can be applied, but without allocating new memory for every Cell
iterated through.
|
Modifier and Type | Method and Description |
---|---|
Cell |
PrefixTreeArrayScanner.current()
CellScanner
|
Modifier and Type | Method and Description |
---|---|
int |
PrefixTreeCell.compareTo(Cell other) |
protected int |
PrefixTreeArraySearcher.compareToCurrentToken(Cell key)
Compare only the bytes within the window of the current token
|
protected boolean |
PrefixTreeArraySearcher.currentPositionIsAfter(Cell cell)
internal methods
|
protected int |
PrefixTreeArrayScanner.populateNonRowFieldsAndCompareTo(int cellNum,
Cell key)
fill in family/qualifier/ts/type/value
|
boolean |
PrefixTreeArraySearcher.positionAt(Cell key)
CellSearcher methods
|
CellScannerPosition |
PrefixTreeArraySearcher.positionAtOrAfter(Cell key)
Identical workflow as positionAtOrBefore, but split them to avoid having ~10 extra
if-statements.
|
CellScannerPosition |
PrefixTreeArraySearcher.positionAtOrBefore(Cell key) |
protected CellScannerPosition |
PrefixTreeArraySearcher.positionAtQualifierTimestamp(Cell key,
boolean beforeOnMiss) |
protected boolean |
PrefixTreeArraySearcher.rowMatchesAfterCurrentPosition(Cell key)
compare this.row to key.row but starting at the current rowLength
|
boolean |
PrefixTreeArraySearcher.seekForwardTo(Cell key) |
CellScannerPosition |
PrefixTreeArraySearcher.seekForwardToOrAfter(Cell key) |
CellScannerPosition |
PrefixTreeArraySearcher.seekForwardToOrBefore(Cell key) |
Modifier and Type | Method and Description |
---|---|
void |
PrefixTreeEncoder.write(Cell cell) |
void |
PrefixTreeEncoder.writeWithRepeatRow(Cell cell)
Add a Cell to the output stream but repeat the previous row.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TestRowEncoder.assertKeyAndValueEqual(Cell expected,
Cell actual)
helper
|
Modifier and Type | Method and Description |
---|---|
boolean |
CellSearcher.positionAt(Cell key)
Do everything within this scanner's power to find the key.
|
CellScannerPosition |
CellSearcher.positionAtOrAfter(Cell key)
Same as positionAt(..), but go to the extra effort of finding the next key if there's no exact
match.
|
CellScannerPosition |
CellSearcher.positionAtOrBefore(Cell key)
Same as positionAt(..), but go to the extra effort of finding the previous key if there's no
exact match.
|
boolean |
CellSearcher.seekForwardTo(Cell key)
Note: Added for backwards compatibility with
KeyValueScanner.reseek(org.apache.hadoop.hbase.Cell)
Look for the key, but only look after the current position. |
CellScannerPosition |
CellSearcher.seekForwardToOrAfter(Cell key)
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no
exact match.
|
CellScannerPosition |
CellSearcher.seekForwardToOrBefore(Cell key)
Same as seekForwardTo(..), but go to the extra effort of finding the next key if there's no
exact match.
|
Modifier and Type | Method and Description |
---|---|
Cell |
BaseRegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Cell |
RegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell)
Called after a new cell has been created during an increment operation, but before
it is committed to the WAL or memstore.
|
Modifier and Type | Method and Description |
---|---|
Filter.ReturnCode |
TestRegionObserverScannerOpenHook.NoDataFilter.filterKeyValue(Cell ignored) |
abstract T |
ColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
Cell |
BaseRegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Cell |
RegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell)
Called after a new cell has been created during an increment operation, but before
it is committed to the WAL or memstore.
|
void |
BaseRegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> e,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
void |
RegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> c,
Mutation mutation,
Cell cell,
byte[] byteNow,
Get get)
Called before the server updates the timestamp for version delete with latest timestamp.
|
void |
SimpleRegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> e,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
static void |
TestRowProcessorEndpoint.RowProcessorEndpoint.doScan(HRegion region,
Scan scan,
List<Cell> result) |
void |
BaseRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
RegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called after the client performs a Get
|
void |
SimpleRegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> results) |
void |
BaseRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
RegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called before the client performs a Get
|
void |
SimpleRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> results) |
void |
TestCoprocessorInterface.CoprocessorII.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell kv) |
abstract Cell |
Filter.getNextCellHint(Cell currentKV)
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
|
Cell |
FilterBase.getNextCellHint(Cell currentKV)
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null Cell.
|
Cell |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
ColumnCountGetFilter.transformCell(Cell v) |
Cell |
ColumnPaginationFilter.transformCell(Cell v) |
Cell |
ColumnPrefixFilter.transformCell(Cell v) |
Cell |
ColumnRangeFilter.transformCell(Cell v) |
Cell |
CompareFilter.transformCell(Cell v) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
|
Cell |
FilterList.transformCell(Cell v) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
FirstKeyOnlyFilter.transformCell(Cell v) |
Cell |
InclusiveStopFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
MultipleColumnPrefixFilter.transformCell(Cell v) |
Cell |
PageFilter.transformCell(Cell v) |
Cell |
PrefixFilter.transformCell(Cell v) |
Cell |
RandomRowFilter.transformCell(Cell v) |
Cell |
SingleColumnValueFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
TimestampsFilter.transformCell(Cell v) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
FilterAllFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
Filter.ReturnCode |
ColumnCountGetFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPaginationFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
ColumnRangeFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
DependentColumnFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
FamilyFilter.filterKeyValue(Cell v) |
abstract Filter.ReturnCode |
Filter.filterKeyValue(Cell v)
A way to filter based on the column family, column qualifier and/or the column value.
|
Filter.ReturnCode |
FilterList.filterKeyValue(Cell v) |
Filter.ReturnCode |
FilterWrapper.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyOnlyFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FuzzyRowFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
InclusiveStopFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
KeyOnlyFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
MultiRowRangeFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
PageFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
PrefixFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
QualifierFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
RandomRowFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
RowFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
SingleColumnValueFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
SkipFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
TimestampsFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ValueFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
WhileMatchFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FilterAllFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
TestFilter.SlowScanFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
TestFilterList.AlwaysNextColFilter.filterKeyValue(Cell v) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnRangeFilter.getNextCellHint(Cell kv) |
abstract Cell |
Filter.getNextCellHint(Cell currentKV)
If the filter returns the match code SEEK_NEXT_USING_HINT, then it should also tell which is
the next key it must seek to.
|
Cell |
FilterBase.getNextCellHint(Cell currentKV)
Filters that are not sure which key must be next seeked to, can inherit
this implementation that, by default, returns a null Cell.
|
Cell |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
Cell |
ColumnCountGetFilter.transformCell(Cell v) |
Cell |
ColumnPaginationFilter.transformCell(Cell v) |
Cell |
ColumnPrefixFilter.transformCell(Cell v) |
Cell |
ColumnRangeFilter.transformCell(Cell v) |
Cell |
CompareFilter.transformCell(Cell v) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
|
Cell |
FilterList.transformCell(Cell v) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
FirstKeyOnlyFilter.transformCell(Cell v) |
Cell |
InclusiveStopFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
MultipleColumnPrefixFilter.transformCell(Cell v) |
Cell |
PageFilter.transformCell(Cell v) |
Cell |
PrefixFilter.transformCell(Cell v) |
Cell |
RandomRowFilter.transformCell(Cell v) |
Cell |
SingleColumnValueFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
TimestampsFilter.transformCell(Cell v) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
FilterAllFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
void |
DependentColumnFilter.filterRowCells(List<Cell> kvs) |
abstract void |
Filter.filterRowCells(List<Cell> kvs)
Chance to alter the list of Cells to be submitted.
|
void |
FilterBase.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
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 |
FilterWrapper.filterRowCells(List<Cell> kvs) |
void |
SingleColumnValueExcludeFilter.filterRowCells(List<Cell> kvs) |
FilterWrapper.FilterRowRetCode |
FilterWrapper.filterRowCellsWithRet(List<Cell> kvs) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
HalfStoreFileReader.splitCell |
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 |
DiffKeyDeltaEncoder.DiffSeekerState |
protected static class |
FastDiffDeltaEncoder.FastDiffSeekerState |
Modifier and Type | Field and Description |
---|---|
protected Cell |
EncodingState.prevCell
The previous Cell the encoder encoded.
|
Modifier and Type | Method and Description |
---|---|
Cell |
DataBlockEncoder.EncodedSeeker.getKeyValue() |
Modifier and Type | Method and Description |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value.
|
Modifier and Type | Method and Description |
---|---|
int |
DataBlockEncoder.EncodedSeeker.compareKey(KeyValue.KVComparator comparator,
Cell key) |
int |
DataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
int |
CopyKeyDataBlockEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
DiffKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
FastDiffDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
PrefixKeyDeltaEncoder.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. |
Modifier and Type | Field and Description |
---|---|
protected Cell |
AbstractHFileWriter.firstCellInBlock
First cell in a block.
|
protected Cell |
AbstractHFileWriter.lastCell
The Cell previously appended.
|
protected Cell |
HFileReaderV2.AbstractScannerV2.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.
|
Modifier and Type | Method and Description |
---|---|
protected Cell |
HFileReaderV2.ScannerV2.formNoTagsKeyValue() |
Cell |
HFileReaderV2.ScannerV2.getKeyValue() |
Cell |
HFileReaderV2.EncodedScannerV2.getKeyValue() |
Cell |
HFileReaderV3.ScannerV3.getKeyValue() |
Cell |
HFileScanner.getKeyValue() |
Cell |
BlockWithScanInfo.getNextIndexedKey() |
Cell |
HFileReaderV2.AbstractScannerV2.getNextIndexedKey() |
Cell |
HFileScanner.getNextIndexedKey() |
Modifier and Type | Method and Description |
---|---|
void |
HFile.Writer.append(Cell cell) |
void |
HFileWriterV2.append(Cell cell)
Add key/value to file.
|
void |
HFileWriterV3.append(Cell cell)
Add key/value to file.
|
protected int |
HFileReaderV2.ScannerV2.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 int |
HFileReaderV3.ScannerV3.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 |
AbstractHFileWriter.checkKey(Cell cell)
Checks that the given Cell's key does not violate the key order.
|
abstract int |
HFileReaderV2.AbstractScannerV2.compareKey(KeyValue.KVComparator comparator,
Cell kv) |
int |
HFileReaderV2.ScannerV2.compareKey(KeyValue.KVComparator comparator,
Cell key) |
int |
HFileReaderV2.EncodedScannerV2.compareKey(KeyValue.KVComparator comparator,
Cell key) |
int |
HFileDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
int |
HFileDataBlockEncoderImpl.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
NoOpDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
protected abstract int |
HFileReaderV2.AbstractScannerV2.loadBlockAndSeekToKey(HFileBlock seekToBlock,
Cell nextIndexedKey,
boolean rewind,
Cell key,
boolean seekBefore) |
protected int |
HFileReaderV2.ScannerV2.loadBlockAndSeekToKey(HFileBlock seekToBlock,
Cell nextIndexedKey,
boolean rewind,
Cell key,
boolean seekBefore) |
protected int |
HFileReaderV2.EncodedScannerV2.loadBlockAndSeekToKey(HFileBlock seekToBlock,
Cell nextIndexedKey,
boolean rewind,
Cell key,
boolean seekBefore) |
BlockWithScanInfo |
HFileBlockIndex.BlockIndexReader.loadDataBlockWithScanInfo(Cell key,
HFileBlock currentBlock,
boolean cacheBlocks,
boolean pread,
boolean isCompaction,
DataBlockEncoding expectedDataBlockEncoding)
Return the BlockWithScanInfo which contains the DataBlock with other scan
info such as nextIndexedKey.
|
int |
HFileReaderV2.AbstractScannerV2.reseekTo(Cell key) |
int |
HFileScanner.reseekTo(Cell c) |
int |
HFileBlockIndex.BlockIndexReader.rootBlockContainingKey(Cell key)
Finds the root-level index block containing the given key.
|
boolean |
HFileReaderV2.AbstractScannerV2.seekBefore(Cell key) |
boolean |
HFileScanner.seekBefore(Cell kv) |
int |
HFileReaderV2.AbstractScannerV2.seekTo(Cell key) |
int |
HFileScanner.seekTo(Cell c) |
int |
HFileReaderV2.AbstractScannerV2.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)
Return the data block which contains this key.
|
void |
HFileBlock.Writer.write(Cell cell)
Writes the Cell to this block
|
void |
TestHFileBlockCompatibility.Writer.write(Cell c) |
Constructor and Description |
---|
BlockWithScanInfo(HFileBlock hFileBlock,
Cell nextIndexedKey) |
Modifier and Type | Method and Description |
---|---|
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength) |
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength,
List<Tag> tags) |
Cell |
CellCreator.create(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength,
long timestamp,
byte[] value,
int voffset,
int vlength,
String visExpression)
Deprecated.
|
static Cell |
Import.filterKv(Filter filter,
Cell kv)
Attempt to filter out the keyvalue
|
Modifier and Type | Method and Description |
---|---|
protected void |
Import.Importer.addPutToKv(Put put,
Cell kv) |
protected boolean |
WALPlayer.WALMapper.filter(Context context,
Cell cell) |
static Cell |
Import.filterKv(Filter filter,
Cell kv)
Attempt to filter out the keyvalue
|
Modifier and Type | Method and Description |
---|---|
static Cell |
ProtobufUtil.toCell(CellProtos.Cell cell) |
Modifier and Type | Method and Description |
---|---|
static CellProtos.Cell |
ProtobufUtil.toCell(Cell kv) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
StoreScanner.lastTop |
Modifier and Type | Method and Description |
---|---|
Cell |
CellSkipListSet.ceiling(Cell e) |
Cell |
CellSkipListSet.first() |
Cell |
CellSkipListSet.floor(Cell e) |
Cell |
CellSkipListSet.get(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextRow(Cell kv) |
Cell |
KeyValueHeap.getNextIndexedKey() |
Cell |
KeyValueScanner.getNextIndexedKey() |
Cell |
NonLazyKeyValueScanner.getNextIndexedKey() |
Cell |
StoreFileScanner.getNextIndexedKey() |
Cell |
StoreScanner.getNextIndexedKey() |
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
Cell |
HStore.getRowKeyAtOrBefore(byte[] row) |
Cell |
Store.getRowKeyAtOrBefore(byte[] row)
Find the key that matches row exactly, or the one that immediately precedes it.
|
Cell |
ScanQueryMatcher.getStartKey() |
Cell |
CellSkipListSet.higher(Cell e) |
Cell |
CellSkipListSet.last() |
Cell |
CellSkipListSet.lower(Cell e) |
Cell |
DefaultMemStore.MemStoreScanner.next() |
Cell |
KeyValueHeap.next() |
Cell |
KeyValueScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
ReversedKeyValueHeap.next() |
Cell |
StoreFileScanner.next() |
Cell |
DefaultMemStore.MemStoreScanner.peek() |
Cell |
KeyValueHeap.peek() |
Cell |
KeyValueScanner.peek()
Look at the next Cell in this scanner, but do not iterate scanner.
|
Cell |
StoreFileScanner.peek() |
Cell |
StoreScanner.peek() |
Cell |
CellSkipListSet.pollFirst() |
Cell |
CellSkipListSet.pollLast() |
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
Pair<Long,Cell> |
DefaultMemStore.add(Cell cell)
Write an update
|
Pair<Long,Cell> |
HStore.add(Cell cell) |
Pair<Long,Cell> |
MemStore.add(Cell cell)
Write an update
|
Pair<Long,Cell> |
Store.add(Cell cell)
Adds a value to the memstore
|
Comparator<? super Cell> |
CellSkipListSet.comparator() |
Iterator<Cell> |
CellSkipListSet.descendingIterator() |
NavigableSet<Cell> |
CellSkipListSet.descendingSet() |
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
List<Cell> |
Region.get(Get get,
boolean withCoprocessor)
Do a get based on the get parameter.
|
SortedSet<Cell> |
CellSkipListSet.headSet(Cell toElement) |
NavigableSet<Cell> |
CellSkipListSet.headSet(Cell toElement,
boolean inclusive) |
Iterator<Cell> |
CellSkipListSet.iterator() |
NavigableSet<Cell> |
CellSkipListSet.subSet(Cell fromElement,
boolean fromInclusive,
Cell toElement,
boolean toInclusive) |
SortedSet<Cell> |
CellSkipListSet.subSet(Cell fromElement,
Cell toElement) |
SortedSet<Cell> |
CellSkipListSet.tailSet(Cell fromElement) |
NavigableSet<Cell> |
CellSkipListSet.tailSet(Cell fromElement,
boolean inclusive) |
Modifier and Type | Method and Description |
---|---|
boolean |
CellSkipListSet.add(Cell e) |
Pair<Long,Cell> |
DefaultMemStore.add(Cell cell)
Write an update
|
void |
DeleteTracker.add(Cell cell)
Add the specified cell to the list of deletes to check against for
this row operation.
|
Pair<Long,Cell> |
HStore.add(Cell cell) |
Pair<Long,Cell> |
MemStore.add(Cell cell)
Write an update
|
void |
ScanDeleteTracker.add(Cell cell)
Add the specified KeyValue to the list of deletes to check against for
this row operation.
|
Pair<Long,Cell> |
Store.add(Cell cell)
Adds a value to the memstore
|
void |
StoreFile.Writer.append(Cell cell) |
void |
StripeMultiFileWriter.BoundaryMultiWriter.append(Cell cell) |
void |
StripeMultiFileWriter.SizeMultiWriter.append(Cell cell) |
boolean |
DefaultMemStore.MemStoreScanner.backwardSeek(Cell key)
Seek scanner to the given key first.
|
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 |
StoreFileScanner.backwardSeek(Cell key) |
Cell |
CellSkipListSet.ceiling(Cell e) |
protected void |
StoreScanner.checkScanOrder(Cell prevKV,
Cell kv,
KeyValue.KVComparator comparator)
Check whether scan as expected order
|
int |
KeyValueHeap.KVScannerComparator.compare(Cell left,
Cell right)
Compares two KeyValue
|
int |
ScanQueryMatcher.compareKeyForNextColumn(Cell nextIndexed,
Cell kv) |
int |
ScanQueryMatcher.compareKeyForNextRow(Cell nextIndexed,
Cell kv) |
long |
DefaultMemStore.delete(Cell deleteCell)
Write a delete
|
long |
MemStore.delete(Cell deleteCell)
Write a delete
|
static boolean |
NonLazyKeyValueScanner.doRealSeek(KeyValueScanner scanner,
Cell kv,
boolean forward) |
Cell |
CellSkipListSet.floor(Cell e) |
Cell |
CellSkipListSet.get(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextRow(Cell kv) |
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
SortedSet<Cell> |
CellSkipListSet.headSet(Cell toElement) |
NavigableSet<Cell> |
CellSkipListSet.headSet(Cell toElement,
boolean inclusive) |
Cell |
CellSkipListSet.higher(Cell e) |
void |
TimeRangeTracker.includeTimestamp(Cell cell)
Update the current TimestampRange to include the timestamp from Cell
If the Key is of type DeleteColumn or DeleteFamily, it includes the
entire time range from 0 to timestamp of the key.
|
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 KeyValue buffer has been deleted by a previously
seen delete.
|
Cell |
CellSkipListSet.lower(Cell e) |
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)
|
boolean |
ScanQueryMatcher.moreRowsMayExistAfter(Cell kv) |
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
boolean |
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation,
Cell kv,
byte[] byteNow,
Get get) |
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 |
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 |
NonLazyKeyValueScanner.requestSeek(Cell kv,
boolean forward,
boolean useBloom) |
boolean |
ReversedKeyValueHeap.requestSeek(Cell key,
boolean forward,
boolean useBloom) |
boolean |
StoreFileScanner.requestSeek(Cell kv,
boolean forward,
boolean useBloom)
Pretend we have done a seek but don't do it yet, if possible.
|
boolean |
DefaultMemStore.MemStoreScanner.reseek(Cell key)
Move forward on the sub-lists set previously by seek.
|
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 |
KeyValueScanner.reseek(Cell key)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
ReversedKeyValueHeap.reseek(Cell seekKey) |
boolean |
StoreFileScanner.reseek(Cell key) |
boolean |
StoreScanner.reseek(Cell kv) |
protected void |
StoreScanner.resetScannerStack(Cell lastTopKey) |
protected boolean |
HRegion.restoreEdit(Store s,
Cell cell)
Used by tests
|
void |
DefaultMemStore.rollback(Cell cell)
Remove n key from the memstore.
|
void |
HStore.rollback(Cell cell) |
void |
MemStore.rollback(Cell cell)
Remove n key from the memstore.
|
void |
Store.rollback(Cell cell)
Removes a Cell from the memstore.
|
boolean |
DefaultMemStore.MemStoreScanner.seek(Cell key)
Set the scanner at the seek key.
|
boolean |
KeyValueHeap.seek(Cell seekKey)
Seeks all scanners at or below the specified seek key.
|
boolean |
KeyValueScanner.seek(Cell key)
Seek the scanner at or after the specified KeyValue.
|
boolean |
ReversedKeyValueHeap.seek(Cell seekKey) |
boolean |
StoreFileScanner.seek(Cell key) |
boolean |
StoreScanner.seek(Cell key) |
protected boolean |
StoreScanner.seekAsDirection(Cell kv)
Do a reseek in a normal StoreScanner(scan forward)
|
static boolean |
StoreFileScanner.seekAtOrAfter(HFileScanner s,
Cell k) |
protected void |
StoreScanner.seekScanners(List<? extends KeyValueScanner> scanners,
Cell seekKey,
boolean isLazy,
boolean isParallelSeek)
Seek the specified scanners with the given key
|
protected boolean |
StoreScanner.seekToNextRow(Cell kv) |
boolean |
DefaultMemStore.MemStoreScanner.seekToPreviousRow(Cell originalKey)
Separately get the KeyValue before the specified key from kvset and
snapshotset, and use the row of higher one as the previous row of
specified key, then seek to the first KeyValue of previous row
|
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 |
StoreFileScanner.seekToPreviousRow(Cell originalKey) |
protected void |
StoreFileScanner.setCurrentCell(Cell newVal) |
NavigableSet<Cell> |
CellSkipListSet.subSet(Cell fromElement,
boolean fromInclusive,
Cell toElement,
boolean toInclusive) |
SortedSet<Cell> |
CellSkipListSet.subSet(Cell fromElement,
Cell toElement) |
SortedSet<Cell> |
CellSkipListSet.tailSet(Cell fromElement) |
NavigableSet<Cell> |
CellSkipListSet.tailSet(Cell fromElement,
boolean inclusive) |
void |
StoreFile.Writer.trackTimestamps(Cell cell)
Record the earlest Put timestamp.
|
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
Iterator<StoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. |
Modifier and Type | Method and Description |
---|---|
boolean |
CellSkipListSet.addAll(Collection<? extends Cell> c) |
void |
TestSeekOptimizations.assertKVListsEqual(String additionalMsg,
List<? extends Cell> expected,
List<? extends Cell> actual) |
void |
TestSeekOptimizations.assertKVListsEqual(String additionalMsg,
List<? extends Cell> expected,
List<? extends Cell> actual) |
void |
HRegion.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now) |
void |
Region.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now)
Check the collection of families for valid timestamps
|
boolean |
InternalScanner.next(List<Cell> results)
Grab the next row's worth of values.
|
boolean |
KeyValueHeap.next(List<Cell> result)
Gets the next row of keys from the top-most scanner.
|
boolean |
StoreScanner.next(List<Cell> outResult) |
boolean |
InternalScanner.next(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
boolean |
KeyValueHeap.next(List<Cell> result,
ScannerContext scannerContext) |
boolean |
StoreScanner.next(List<Cell> outResult,
ScannerContext scannerContext)
Get the next row of values from this Store.
|
boolean |
RegionScanner.nextRaw(List<Cell> result)
Grab the next row's worth of values.
|
boolean |
RegionScanner.nextRaw(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
boolean |
RegionCoprocessorHost.preGet(Get get,
List<Cell> results) |
void |
HRegion.prepareDeleteTimestamps(Mutation mutation,
Map<byte[],List<Cell>> familyMap,
byte[] byteNow) |
void |
Region.prepareDeleteTimestamps(Mutation mutation,
Map<byte[],List<Cell>> familyCellMap,
byte[] now)
Set up correct timestamps in the KVs in Delete object.
|
void |
HRegion.updateCellTimestamps(Iterable<List<Cell>> cellItr,
byte[] now) |
void |
Region.updateCellTimestamps(Iterable<List<Cell>> values,
byte[] now)
Replace any cell timestamps set to HConstants#LATEST_TIMESTAMP with the
provided current timestamp.
|
long |
DefaultMemStore.upsert(Iterable<Cell> cells,
long readpoint)
Update or insert the specified KeyValues.
|
long |
HStore.upsert(Iterable<Cell> cells,
long readpoint) |
long |
MemStore.upsert(Iterable<Cell> cells,
long readpoint)
Update or insert the specified cells.
|
long |
Store.upsert(Iterable<Cell> cells,
long readpoint)
Adds or replaces the specified KeyValues.
|
Modifier and Type | Method and Description |
---|---|
void |
Compactor.CellSink.append(Cell cell) |
Constructor and Description |
---|
ParallelSeekHandler(KeyValueScanner scanner,
Cell keyValue,
long readPoint,
CountDownLatch latch) |
Modifier and Type | Method and Description |
---|---|
ArrayList<Cell> |
WALEdit.getCells() |
Modifier and Type | Method and Description |
---|---|
WALEdit |
WALEdit.add(Cell cell) |
static WALProtos.BulkLoadDescriptor |
WALEdit.getBulkLoadDescriptor(Cell cell)
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
|
static WALProtos.CompactionDescriptor |
WALEdit.getCompaction(Cell kv)
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
|
static WALProtos.FlushDescriptor |
WALEdit.getFlushDescriptor(Cell cell) |
static WALProtos.RegionEventDescriptor |
WALEdit.getRegionEventDescriptor(Cell cell) |
static boolean |
WALEdit.isMetaEditFamily(Cell cell) |
void |
WALCellCodec.EnsureKvEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
long |
FSHLog.append(HTableDescriptor htd,
HRegionInfo hri,
WALKey key,
WALEdit edits,
AtomicLong sequenceId,
boolean inMemstore,
List<Cell> memstoreCells) |
void |
WALEdit.setCells(ArrayList<Cell> cells)
This is not thread safe.
|
Modifier and Type | Method and Description |
---|---|
void |
TestReplicationWithTags.TestCoprocessorForTagsAtSink.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
TestMasterReplication.CoprocessorCounter.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
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 |
---|---|
Cell |
AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
boolean |
TableAuthManager.authorize(User user,
TableName table,
Cell cell,
Permission.Action action)
Authorize a user for a given KV.
|
static List<Permission> |
AccessControlLists.getCellPermissionsForUser(User user,
Cell cell) |
Cell |
AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
void |
AccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
Modifier and Type | Method and Description |
---|---|
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
protected List<List<Cell>> |
DefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths() |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityScanDeleteTracker.add(Cell delCell) |
boolean |
VisibilityExpEvaluator.evaluate(Cell cell)
Evaluates whether the passed cell passes Scan/Get Authorization.
|
static Byte |
VisibilityUtils.extractAndPartitionTags(Cell cell,
List<Tag> visTags,
List<Tag> nonVisTags)
Extracts and partitions the visibility tags and nonVisibility Tags
|
static Byte |
VisibilityUtils.extractVisibilityTags(Cell cell,
List<Tag> tags)
Extract the visibility tags of the given Cell into the given List
|
DeleteTracker.DeleteResult |
VisibilityScanDeleteTracker.isDeleted(Cell cell) |
static boolean |
VisibilityUtils.isVisibilityTagsPresent(Cell cell) |
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
void |
VisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
protected Pair<Map<String,Integer>,Map<String,List<Integer>>> |
DefaultVisibilityLabelServiceImpl.extractLabelsAndAuths(List<List<Cell>> labelDetails) |
void |
TestVisibilityLabelsReplication.TestCoprocessorForTagsAtSink.postGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
void |
VisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
IntegrationTestLoadAndVerify.WALSearcher.WALMapperSearcher.filter(Context context,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
static List<TCell> |
ThriftUtilities.cellFromHBase(Cell in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell object.
|
static List<TCell> |
ThriftUtilities.cellFromHBase(Cell[] in)
This utility method creates a list of Thrift TCell "struct" based on
an Hbase Cell array.
|
Modifier and Type | Method and Description |
---|---|
Cell |
CollectionBackedScanner.next() |
Cell |
CollectionBackedScanner.peek() |
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
<any> comparator)
Binary search for keys in indexes.
|
boolean |
CollectionBackedScanner.reseek(Cell seekCell) |
boolean |
CollectionBackedScanner.seek(Cell seekCell) |
Constructor and Description |
---|
CollectionBackedScanner(KeyValue.KVComparator comparator,
Cell... array) |
Constructor and Description |
---|
CollectionBackedScanner(List<Cell> list) |
CollectionBackedScanner(List<Cell> list,
KeyValue.KVComparator comparator) |
CollectionBackedScanner(SortedSet<Cell> set) |
CollectionBackedScanner(SortedSet<Cell> set,
KeyValue.KVComparator comparator) |
Modifier and Type | Method and Description |
---|---|
long |
WAL.append(HTableDescriptor htd,
HRegionInfo info,
WALKey key,
WALEdit edits,
AtomicLong sequenceId,
boolean inMemstore,
List<Cell> memstoreKVs)
Append a set of edits to the WAL.
|
long |
FaultyFSLog.append(HTableDescriptor htd,
HRegionInfo info,
WALKey key,
WALEdit edits,
AtomicLong sequenceId,
boolean isInMemstore,
List<Cell> cells) |