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 |
---|---|
private Cell |
TagRewriteCell.cell |
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)
Marked as audience Private as of 1.2.0.
|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
long memstoreTS)
Marked as audience Private as of 1.2.0.
|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
KeyValue.Type type,
byte[] value,
byte[] tags)
Marked as audience Private as of 1.2.0.
|
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 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) |
private static int |
CellComparator.calculateHashForKeyValue(Cell cell) |
static List<Tag> |
Tag.carryForwardTags(Cell cell) |
static List<Tag> |
Tag.carryForwardTags(List<Tag> tagsOrNull,
Cell cell) |
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) |
(package private) int |
KeyValue.KVComparator.compareColumns(Cell left,
short lrowlength,
Cell right,
short rrowlength) |
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) |
private static int |
CellComparator.compareStaticIgnoreMvccVersion(Cell a,
Cell b) |
static int |
CellComparator.compareTimestamps(Cell left,
Cell right)
Compares cell's timestamps in DESCENDING order.
|
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 KeyValue |
KeyValueUtil.ensureKeyValueTypeForMR(Cell cell)
Deprecated.
without any replacement.
|
static boolean |
CellComparator.equals(Cell a,
Cell b)
equals
|
static boolean |
CellUtil.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
|
private static int |
CellUtil.getSumOfCellElementLengths(Cell cell) |
private static int |
CellUtil.getSumOfCellKeyElementLengths(Cell cell) |
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
|
private boolean |
KeyValue.KVComparator.matchingRows(Cell left,
short lrowlength,
Cell right,
short rrowlength) |
static boolean |
CellUtil.matchingTimestamp(Cell a,
Cell b) |
static boolean |
CellUtil.matchingType(Cell a,
Cell b) |
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 boolean |
KeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends Cell> kvCollection1,
Collection<? extends Cell> kvCollection2)
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
|
static boolean |
KeyValueTestUtil.containsIgnoreMvccVersion(Collection<? extends Cell> kvCollection1,
Collection<? extends Cell> kvCollection2)
Checks whether KeyValues from kvCollection2 are contained in kvCollection1.
|
static CellScanner |
CellUtil.createCellScanner(Iterable<Cell> cellIterable) |
static CellScanner |
CellUtil.createCellScanner(Iterator<Cell> cells) |
static CellScanner |
CellUtil.createCellScanner(NavigableMap<byte[],List<Cell>> map)
Flatten the map of cells out under the CellScanner
|
static List<KeyValue> |
KeyValueUtil.ensureKeyValues(List<Cell> cells)
Deprecated.
|
Constructor and Description |
---|
KeyValue(Cell c) |
TagRewriteCell(Cell cell,
byte[] tags) |
Modifier and Type | Field and Description |
---|---|
private Cell[] |
Result.cells |
protected Cell |
ClientScanner.lastCellLoadedToCache
The last cell from a not full Row which is added to cache
|
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> |
Put.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 |
---|---|
Put |
Put.add(Cell kv)
Add the specified KeyValue to this Put operation.
|
Increment |
Increment.add(Cell cell)
Add the specified KeyValue to this operation.
|
Append |
Append.add(Cell cell)
Add column and value to this Append operation.
|
Delete |
Delete.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.
|
private static Map<String,Object> |
Mutation.cellToStringMap(Cell c) |
private int |
ClientScanner.compare(Cell a,
Cell b)
Compare two Cells considering reversed scanner.
|
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) |
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) |
Delete |
Delete.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Put |
Put.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
|
Append |
Append.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Constructor and Description |
---|
Result(Cell[] cells,
Boolean exists,
boolean stale,
boolean partial)
Private ctor.
|
Modifier and Type | Method and Description |
---|---|
Double |
DoubleColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
BigDecimal |
BigDecimalColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Long |
LongColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Modifier and Type | Field and Description |
---|---|
private Cell |
BaseDecoder.current |
Modifier and Type | Method and Description |
---|---|
Cell |
BaseDecoder.current() |
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected abstract Cell |
BaseDecoder.parseCell()
Extract a Cell.
|
protected Cell |
CellCodecWithTags.CellDecoder.parseCell() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
protected Cell |
CellCodec.CellDecoder.parseCell() |
protected Cell |
MessageCodec.MessageDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
abstract void |
BaseEncoder.write(Cell cell) |
void |
CellCodecWithTags.CellEncoder.write(Cell cell) |
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell) |
void |
CellCodec.CellEncoder.write(Cell cell) |
void |
MessageCodec.MessageEncoder.write(Cell cell) |
Modifier and Type | Class and Description |
---|---|
private static class |
PrefixTreeSeeker.ClonedPrefixTreeCell
Cloned version of the PrefixTreeCell where except the value part, the rest
of the key part is deep copied
|
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)
Deprecated.
|
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 |
---|---|
private void |
PrefixTreeEncoder.addAfterRowFamilyQualifier(Cell cell)
internal add methods
|
private void |
PrefixTreeEncoder.addFamilyPart(Cell cell) |
private void |
PrefixTreeEncoder.addQualifierPart(Cell cell) |
private void |
PrefixTreeEncoder.addTagPart(Cell cell) |
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 |
---|---|
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) |
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 |
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.
|
Cell |
BaseRegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
abstract T |
ColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
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.
|
Cell |
BaseRegionObserver.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
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 |
BaseRegionObserver.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> e,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
void |
RegionObserver.postGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result)
Called after the client performs a Get
|
void |
BaseRegionObserver.postGetOp(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 |
BaseRegionObserver.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
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) |
Modifier and Type | Field and Description |
---|---|
private Cell |
FilterList.referenceKV
Reference Cell used by
FilterList.transformCell(Cell) for validation purpose. |
private Cell |
FilterList.transformedKV
When filtering a given Cell in
FilterList.filterKeyValue(Cell) ,
this stores the transformed Cell to be returned by FilterList.transformCell(Cell) . |
Modifier and Type | Method and Description |
---|---|
private Cell |
KeyOnlyFilter.createKeyOnlyCell(Cell c) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
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.
|
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 |
ColumnRangeFilter.getNextCellHint(Cell kv) |
Cell |
MultipleColumnPrefixFilter.transformCell(Cell v) |
Cell |
TimestampsFilter.transformCell(Cell v) |
Cell |
ColumnPaginationFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
PageFilter.transformCell(Cell v) |
Cell |
SingleColumnValueFilter.transformCell(Cell v) |
Cell |
CompareFilter.transformCell(Cell v) |
Cell |
FirstKeyOnlyFilter.transformCell(Cell v) |
Cell |
ColumnCountGetFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
InclusiveStopFilter.transformCell(Cell v) |
Cell |
PrefixFilter.transformCell(Cell v) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
ColumnPrefixFilter.transformCell(Cell v) |
Cell |
FilterList.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 |
RandomRowFilter.transformCell(Cell v) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
ColumnRangeFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
private Cell |
KeyOnlyFilter.createKeyOnlyCell(Cell c) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
TimestampsFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPaginationFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
SkipFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
PageFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
SingleColumnValueFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
QualifierFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyOnlyFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FuzzyRowFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
ColumnCountGetFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
KeyOnlyFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
FamilyFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FilterWrapper.filterKeyValue(Cell v) |
Filter.ReturnCode |
RowFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
InclusiveStopFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
PrefixFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ValueFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
WhileMatchFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
FilterList.filterKeyValue(Cell v) |
Filter.ReturnCode |
MultiRowRangeFilter.filterKeyValue(Cell ignored) |
Filter.ReturnCode |
RandomRowFilter.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 |
DependentColumnFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
ColumnRangeFilter.filterKeyValue(Cell kv) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentCell) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV) |
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
MultiRowRangeFilter.getNextCellHint(Cell currentKV) |
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.
|
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 |
ColumnRangeFilter.getNextCellHint(Cell kv) |
private boolean |
FirstKeyValueMatchingQualifiersFilter.hasOneMatchingQualifier(Cell v) |
(package private) boolean |
FuzzyRowFilter.RowTracker.lessThan(Cell currentCell,
byte[] nextRowKey) |
Cell |
MultipleColumnPrefixFilter.transformCell(Cell v) |
Cell |
TimestampsFilter.transformCell(Cell v) |
Cell |
ColumnPaginationFilter.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Cell |
PageFilter.transformCell(Cell v) |
Cell |
SingleColumnValueFilter.transformCell(Cell v) |
Cell |
CompareFilter.transformCell(Cell v) |
Cell |
FirstKeyOnlyFilter.transformCell(Cell v) |
Cell |
ColumnCountGetFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell cell) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
InclusiveStopFilter.transformCell(Cell v) |
Cell |
PrefixFilter.transformCell(Cell v) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
ColumnPrefixFilter.transformCell(Cell v) |
Cell |
FilterList.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 |
RandomRowFilter.transformCell(Cell v) |
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
ColumnRangeFilter.transformCell(Cell v) |
(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 |
---|---|
void |
FilterWrapper.filterRowCells(List<Cell> kvs) |
void |
SingleColumnValueExcludeFilter.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 |
FilterBase.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
abstract void |
Filter.filterRowCells(List<Cell> kvs)
Chance to alter the list of Cells to be submitted.
|
void |
DependentColumnFilter.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 |
BufferedDataBlockEncoder.ClonedSeekerState
Copies only the key part of the keybuffer by doing a deep copy and passes the
seeker state members for taking a clone.
|
protected static class |
BufferedDataBlockEncoder.SeekerState |
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 |
BufferedDataBlockEncoder.BufferedEncodedSeeker.getKeyValue() |
Cell |
DataBlockEncoder.EncodedSeeker.getKeyValue() |
Cell |
BufferedDataBlockEncoder.SeekerState.shallowCopy() |
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) |
int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.compareKey(KeyValue.KVComparator comparator,
Cell key) |
int |
DataBlockEncoder.EncodedSeeker.compareKey(KeyValue.KVComparator 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) |
int |
BufferedDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
DataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
int |
PrefixKeyDeltaEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
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 |
CopyKeyDataBlockEncoder.internalEncode(Cell cell,
HFileBlockDefaultEncodingContext encodingContext,
DataOutputStream out) |
int |
BufferedDataBlockEncoder.BufferedEncodedSeeker.seekToKeyInBlock(Cell seekCell,
boolean seekBefore) |
int |
DataBlockEncoder.EncodedSeeker.seekToKeyInBlock(Cell key,
boolean seekBefore)
Moves the seeker position within the current block to:
the last key that that is less than or equal to the given key if
seekBefore is false
the last key that is strictly less than the given key if
seekBefore is true. |
private void |
PrefixKeyDeltaEncoder.writeKeyExcludingCommon(Cell cell,
int commonPrefix,
DataOutputStream out) |
Modifier and Type | Field and Description |
---|---|
protected Cell |
AbstractHFileWriter.firstCellInBlock
First cell in a block.
|
protected Cell |
AbstractHFileWriter.lastCell
The Cell previously appended.
|
private Cell |
HFileWriterV2.lastCellOfPreviousBlock
The last(stop) Cell of the previous data block.
|
private Cell |
BlockWithScanInfo.nextIndexedKey
The first key in the next block following this one in the HFile.
|
protected Cell |
HFileReaderV2.AbstractScannerV2.nextIndexedKey
The next indexed key is to keep track of the indexed key of the next data block.
|
private Cell |
HFilePrettyPrinter.KeyValueStatsCollector.prevCell |
Modifier and Type | Method and Description |
---|---|
protected Cell |
HFileReaderV2.ScannerV2.formNoTagsKeyValue() |
Cell |
HFileReaderV3.ScannerV3.getKeyValue() |
Cell |
HFileScanner.getKeyValue() |
Cell |
HFileReaderV2.ScannerV2.getKeyValue() |
Cell |
HFileReaderV2.EncodedScannerV2.getKeyValue() |
Cell |
BlockWithScanInfo.getNextIndexedKey() |
Cell |
HFileScanner.getNextIndexedKey() |
Cell |
HFileReaderV2.AbstractScannerV2.getNextIndexedKey() |
Modifier and Type | Method and Description |
---|---|
void |
HFileWriterV2.append(Cell cell)
Add key/value to file.
|
void |
HFileWriterV3.append(Cell cell)
Add key/value to file.
|
void |
HFile.Writer.append(Cell cell) |
(package private) static int |
HFileBlockIndex.BlockIndexReader.binarySearchNonRootIndex(Cell key,
ByteBuffer nonRootIndex,
KeyValue.KVComparator comparator)
Performs a binary search over a non-root level index block.
|
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 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 boolean |
AbstractHFileWriter.checkKey(Cell cell)
Checks that the given Cell's key does not violate the key order.
|
void |
HFilePrettyPrinter.KeyValueStatsCollector.collect(Cell cell) |
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 |
NoOpDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
HFileDataBlockEncoderImpl.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out) |
int |
HFileDataBlockEncoder.encode(Cell cell,
HFileBlockEncodingContext encodingCtx,
DataOutputStream out)
Encodes a KeyValue.
|
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.
|
(package private) static int |
HFileBlockIndex.BlockIndexReader.locateNonRootIndexEntry(ByteBuffer nonRootBlock,
Cell key,
KeyValue.KVComparator comparator)
Search for one key using the secondary index in a non-root block.
|
int |
HFileScanner.reseekTo(Cell c) |
int |
HFileReaderV2.AbstractScannerV2.reseekTo(Cell key) |
int |
HFileBlockIndex.BlockIndexReader.rootBlockContainingKey(Cell key)
Finds the root-level index block containing the given key.
|
boolean |
HFileScanner.seekBefore(Cell kv) |
boolean |
HFileReaderV2.AbstractScannerV2.seekBefore(Cell key) |
int |
HFileScanner.seekTo(Cell c) |
int |
HFileReaderV2.AbstractScannerV2.seekTo(Cell key) |
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
|
Constructor and Description |
---|
BlockWithScanInfo(HFileBlock hFileBlock,
Cell nextIndexedKey) |
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 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.
|
static Cell |
Import.filterKv(Filter filter,
Cell kv)
Attempt to filter out the keyvalue
|
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.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 static 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) |
protected boolean |
WALPlayer.WALMapper.filter(org.apache.hadoop.mapreduce.Mapper.Context context,
Cell cell) |
static Cell |
Import.filterKv(Filter filter,
Cell kv)
Attempt to filter out the keyvalue
|
Modifier and Type | Field and Description |
---|---|
private Cell |
GetClosestRowBeforeTracker.candidate |
(package private) Cell |
DefaultMemStore.Member.cell |
private Cell |
DefaultMemStore.MemStoreScanner.cellSetItRow |
private Cell |
DefaultMemStore.MemStoreScanner.cellSetNextRow |
private Cell |
StoreFileScanner.cur |
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 |
StoreFile.Writer.lastCell |
private Cell |
StripeMultiFileWriter.BoundaryMultiWriter.lastCell |
private Cell |
StripeMultiFileWriter.SizeMultiWriter.lastCell |
private Cell |
StoreFile.Writer.lastDeleteFamilyCell |
protected Cell |
StoreScanner.lastTop |
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 |
DefaultMemStore.MemStoreScanner.snapshotItRow |
private Cell |
DefaultMemStore.MemStoreScanner.snapshotNextRow |
private Cell |
ScanQueryMatcher.startKey
Key to seek to in memstore and StoreFiles
|
private Cell |
DefaultMemStore.MemStoreScanner.stopSkippingKVsRow |
private Cell |
DefaultMemStore.MemStoreScanner.theNext |
Modifier and Type | Field and Description |
---|---|
private Iterator<Cell> |
DefaultMemStore.MemStoreScanner.cellSetIt |
private ConcurrentNavigableMap<Cell,Cell> |
CellSkipListSet.delegatee |
private ConcurrentNavigableMap<Cell,Cell> |
CellSkipListSet.delegatee |
private static List<Cell> |
HRegion.MOCKED_LIST
A mocked list implementation - discards all updates.
|
(package private) NavigableSet<Cell> |
DefaultMemStore.Member.set |
private Iterator<Cell> |
DefaultMemStore.MemStoreScanner.snapshotIt |
Modifier and Type | Method and Description |
---|---|
Cell |
CellSkipListSet.ceiling(Cell e) |
private static Cell |
ScanQueryMatcher.createNextOnRowCol(Cell cell) |
private static Cell |
ScanQueryMatcher.createNextOnRowCol(Cell cell,
long ts,
byte type) |
Cell |
CellSkipListSet.first() |
Cell |
CellSkipListSet.floor(Cell e) |
Cell |
CellSkipListSet.get(Cell kv) |
Cell |
GetClosestRowBeforeTracker.getCandidate() |
private Cell |
DefaultMemStore.MemStoreScanner.getHighest(Cell first,
Cell second) |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextRow(Cell kv) |
private Cell |
DefaultMemStore.getLowest(Cell a,
Cell b) |
private Cell |
DefaultMemStore.MemStoreScanner.getLowest(Cell first,
Cell second) |
private static Cell |
HRegion.getNewCell(byte[] row,
long ts,
Cell cell,
Cell oldCell,
byte[] tagBytes) |
private static Cell |
HRegion.getNewCell(Mutation mutate,
Cell cell) |
private Cell |
DefaultMemStore.MemStoreScanner.getNext(Iterator<Cell> it)
Lock on 'this' must be held by caller.
|
Cell |
KeyValueScanner.getNextIndexedKey() |
Cell |
StoreScanner.getNextIndexedKey() |
Cell |
KeyValueHeap.getNextIndexedKey() |
Cell |
NonLazyKeyValueScanner.getNextIndexedKey() |
Cell |
StoreFileScanner.getNextIndexedKey() |
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
(package private) Cell |
DefaultMemStore.getNextRow(Cell cell) |
private Cell |
DefaultMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
Cell |
Store.getRowKeyAtOrBefore(byte[] row)
Find the key that matches row exactly, or the one that immediately precedes it.
|
Cell |
HStore.getRowKeyAtOrBefore(byte[] row) |
Cell |
ScanQueryMatcher.getStartKey() |
Cell |
CellSkipListSet.higher(Cell e) |
Cell |
CellSkipListSet.last() |
Cell |
CellSkipListSet.lower(Cell e) |
private Cell |
DefaultMemStore.maybeCloneWithAllocator(Cell cell) |
Cell |
DefaultMemStore.MemStoreScanner.next() |
Cell |
KeyValueScanner.next()
Return the next Cell in this scanner, iterating the scanner
|
Cell |
KeyValueHeap.next() |
Cell |
StoreFileScanner.next() |
Cell |
ReversedKeyValueHeap.next() |
Cell |
DefaultMemStore.MemStoreScanner.peek() |
Cell |
KeyValueScanner.peek()
Look at the next Cell in this scanner, but do not iterate scanner.
|
Cell |
StoreScanner.peek() |
Cell |
KeyValueHeap.peek() |
Cell |
StoreFileScanner.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 |
---|---|
private List<Cell> |
HRegion.applyIncrementsToColumnFamily(Increment increment,
byte[] columnFamilyName,
List<Cell> sortedIncrements,
long now,
long mvccNum,
List<Cell> allKVs,
IsolationLevel isolation)
Apply increments to a column family.
|
Comparator<? super Cell> |
CellSkipListSet.comparator() |
Iterator<Cell> |
CellSkipListSet.descendingIterator() |
NavigableSet<Cell> |
CellSkipListSet.descendingSet() |
private List<Cell> |
HRegion.doGet(Store store,
byte[] row,
Map.Entry<byte[],List<Cell>> family,
TimeRange tr)
Run a Get against passed in
store on passed row , etc. |
List<Cell> |
Region.get(Get get,
boolean withCoprocessor)
Do a get based on the get parameter.
|
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
private List<Cell> |
HRegion.getIncrementCurrentValue(Increment increment,
byte[] columnFamily,
List<Cell> increments,
IsolationLevel isolation)
Do a specific Get on passed
columnFamily and column qualifiers
from incrementCoordinates only. |
SortedSet<Cell> |
CellSkipListSet.headSet(Cell toElement) |
NavigableSet<Cell> |
CellSkipListSet.headSet(Cell toElement,
boolean inclusive) |
Iterator<Cell> |
CellSkipListSet.iterator() |
private static List<Cell> |
HRegion.sort(List<Cell> cells,
Comparator<Cell> comparator) |
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 |
---|---|
void |
DeleteTracker.add(Cell cell)
Add the specified cell to the list of deletes to check against for
this row operation.
|
long |
DefaultMemStore.add(Cell cell)
Write an update
|
long |
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.
|
long |
Store.add(Cell cell)
Adds a value to the memstore
|
long |
HStore.add(Cell cell) |
boolean |
CellSkipListSet.add(Cell e) |
private boolean |
GetClosestRowBeforeTracker.addCandidate(Cell kv) |
private void |
GetClosestRowBeforeTracker.addDelete(Cell kv) |
private boolean |
DefaultMemStore.addToCellSet(Cell e) |
void |
StoreFile.Writer.append(Cell cell) |
void |
StripeMultiFileWriter.BoundaryMultiWriter.append(Cell cell) |
void |
StripeMultiFileWriter.SizeMultiWriter.append(Cell cell) |
private void |
StoreFile.Writer.appendDeleteFamilyBloomFilter(Cell cell) |
private void |
StoreFile.Writer.appendGeneralBloomfilter(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 |
ReversedStoreScanner.backwardSeek(Cell key) |
boolean |
StoreFileScanner.backwardSeek(Cell key) |
boolean |
ReversedKeyValueHeap.backwardSeek(Cell seekKey) |
private static List<Tag> |
HRegion.carryForwardTags(Cell cell,
List<Tag> tags) |
Cell |
CellSkipListSet.ceiling(Cell e) |
protected void |
StoreScanner.checkScanOrder(Cell prevKV,
Cell kv,
KeyValue.KVComparator comparator)
Check whether scan as expected order
|
protected void |
ReversedStoreScanner.checkScanOrder(Cell prevKV,
Cell kv,
KeyValue.KVComparator comparator) |
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) |
int |
ReversedKeyValueHeap.ReversedKVScannerComparator.compareRows(Cell left,
Cell right)
Compares rows of two KeyValue
|
private static Cell |
ScanQueryMatcher.createNextOnRowCol(Cell cell) |
private static Cell |
ScanQueryMatcher.createNextOnRowCol(Cell cell,
long ts,
byte type) |
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) |
private boolean |
KeyValueHeap.generalizedSeek(boolean isLazy,
Cell seekKey,
boolean forward,
boolean useBloom) |
Cell |
CellSkipListSet.get(Cell kv) |
(package private) int |
DefaultMemStore.getCellLength(Cell cell)
Get cell length after serialized in
KeyValue |
private Cell |
DefaultMemStore.MemStoreScanner.getHighest(Cell first,
Cell second) |
Cell |
ScanQueryMatcher.getKeyForNextColumn(Cell kv) |
Cell |
ScanQueryMatcher.getKeyForNextRow(Cell kv) |
private static long |
HRegion.getLongValue(Cell cell) |
private Cell |
DefaultMemStore.getLowest(Cell a,
Cell b) |
private Cell |
DefaultMemStore.MemStoreScanner.getLowest(Cell first,
Cell second) |
private static Cell |
HRegion.getNewCell(byte[] row,
long ts,
Cell cell,
Cell oldCell,
byte[] tagBytes) |
private static Cell |
HRegion.getNewCell(Mutation mutate,
Cell cell) |
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
(package private) Cell |
DefaultMemStore.getNextRow(Cell cell) |
private Cell |
DefaultMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
private Store |
HRegion.getStore(Cell cell)
Return HStore instance.
|
(package private) boolean |
GetClosestRowBeforeTracker.handle(Cell kv)
Do right thing with passed key, add to deletes or add to candidates.
|
(package private) boolean |
GetClosestRowBeforeTracker.handleDeletes(Cell kv) |
SortedSet<Cell> |
CellSkipListSet.headSet(Cell toElement) |
NavigableSet<Cell> |
CellSkipListSet.headSet(Cell toElement,
boolean inclusive) |
(package private) static long |
DefaultMemStore.heapSizeChange(Cell cell,
boolean notpresent) |
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.
|
private long |
DefaultMemStore.internalAdd(Cell toAdd,
boolean mslabUsed)
Internal version of add() that doesn't clone Cells with the
allocator, and doesn't take the lock.
|
(package private) boolean |
GetClosestRowBeforeTracker.isBetterCandidate(Cell contender) |
private boolean |
StripeMultiFileWriter.BoundaryMultiWriter.isCellAfterCurrentWriter(Cell cell) |
(package private) static boolean |
HStore.isCellTTLExpired(Cell cell,
long oldestTimestamp,
long now) |
DeleteTracker.DeleteResult |
DeleteTracker.isDeleted(Cell cell)
Check if the specified cell buffer has been deleted by a previously
seen delete.
|
private boolean |
GetClosestRowBeforeTracker.isDeleted(Cell kv) |
DeleteTracker.DeleteResult |
ScanDeleteTracker.isDeleted(Cell cell)
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
|
boolean |
GetClosestRowBeforeTracker.isDeleted(Cell kv,
NavigableSet<KeyValue> ds)
Check if the specified KeyValue buffer has been deleted by a previously
seen delete.
|
boolean |
GetClosestRowBeforeTracker.isExpired(Cell cell) |
(package private) boolean |
GetClosestRowBeforeTracker.isTargetTable(Cell kv) |
(package private) boolean |
GetClosestRowBeforeTracker.isTooFar(Cell kv,
Cell firstOnRow) |
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)
|
private Cell |
DefaultMemStore.maybeCloneWithAllocator(Cell cell) |
private DefaultMemStore.Member |
DefaultMemStore.memberOfPreviousRow(NavigableSet<Cell> set,
GetClosestRowBeforeTracker state,
Cell firstOnRow) |
private boolean |
HRegion.RegionScannerImpl.moreCellsInRow(Cell nextKv,
byte[] currentRow,
int offset,
short length)
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.
|
boolean |
ScanQueryMatcher.moreRowsMayExistAfter(Cell kv) |
private ScanQueryMatcher.MatchCode |
StoreScanner.optimize(ScanQueryMatcher.MatchCode qcode,
Cell cell) |
private void |
StoreScanner.parallelSeek(List<? extends KeyValueScanner> scanners,
Cell kv)
Seek storefiles in parallel to optimize IO latency as much as possible
|
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
private void |
StripeMultiFileWriter.BoundaryMultiWriter.prepareWriterFor(Cell cell) |
boolean |
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation,
Cell kv,
byte[] byteNow,
Get get) |
private boolean |
DefaultMemStore.removeFromCellSet(Cell e) |
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 |
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 |
NonLazyKeyValueScanner.requestSeek(Cell kv,
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 |
ReversedKeyValueHeap.requestSeek(Cell key,
boolean forward,
boolean useBloom) |
boolean |
DefaultMemStore.MemStoreScanner.reseek(Cell key)
Move forward on the sub-lists set previously by seek.
|
boolean |
KeyValueScanner.reseek(Cell key)
Reseek the scanner at or after the specified KeyValue.
|
boolean |
StoreScanner.reseek(Cell kv) |
boolean |
ReversedStoreScanner.reseek(Cell kv) |
boolean |
KeyValueHeap.reseek(Cell seekKey)
This function is identical to the
KeyValueHeap.seek(Cell) function except
that scanner.seek(seekKey) is changed to scanner.reseek(seekKey). |
boolean |
StoreFileScanner.reseek(Cell key) |
boolean |
ReversedKeyValueHeap.reseek(Cell seekKey) |
(package private) static boolean |
StoreFileScanner.reseekAtOrAfter(HFileScanner s,
Cell k) |
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 |
MemStore.rollback(Cell cell)
Remove n key from the memstore.
|
void |
Store.rollback(Cell cell)
Removes a Cell from the memstore.
|
void |
HStore.rollback(Cell cell) |
boolean |
DefaultMemStore.MemStoreScanner.seek(Cell key)
Set the scanner at the seek key.
|
boolean |
KeyValueScanner.seek(Cell key)
Seek the scanner at or after the specified KeyValue.
|
boolean |
StoreScanner.seek(Cell key) |
boolean |
ReversedStoreScanner.seek(Cell key) |
boolean |
KeyValueHeap.seek(Cell seekKey)
Seeks all scanners at or below the specified seek key.
|
boolean |
StoreFileScanner.seek(Cell key) |
boolean |
ReversedKeyValueHeap.seek(Cell seekKey) |
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 boolean |
DefaultMemStore.MemStoreScanner.seekInSubLists(Cell key)
(Re)initialize the iterators after a seek or a reseek.
|
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 kv) |
protected boolean |
ReversedStoreScanner.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 |
ReversedStoreScanner.seekToPreviousRow(Cell key) |
boolean |
StoreFileScanner.seekToPreviousRow(Cell originalKey) |
boolean |
ReversedKeyValueHeap.seekToPreviousRow(Cell seekKey) |
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> |
DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate) |
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. |
(package private) void |
HRegion.updateDeleteLatestVersionTimeStamp(Cell cell,
Get get,
int count,
byte[] byteNow) |
private long |
DefaultMemStore.upsert(Cell cell,
long readpoint)
Inserts the specified KeyValue into MemStore and deletes any existing
versions of the same row/family/qualifier as the specified KeyValue.
|
private boolean |
DefaultMemStore.walkForwardInSingleRow(SortedSet<Cell> set,
Cell firstOnRow,
GetClosestRowBeforeTracker state) |
Modifier and Type | Method and Description |
---|---|
boolean |
CellSkipListSet.addAll(Collection<? extends Cell> c) |
private void |
HRegion.addFamilyMapToWALEdit(Map<byte[],List<Cell>> familyMap,
WALEdit walEdit)
Append the given map of family->edits to a WALEdit data structure.
|
private long |
HRegion.applyFamilyMapToMemstore(Map<byte[],List<Cell>> familyMap,
long mvccNum,
boolean isInReplay)
Atomically apply the given map of family->edits to the memstore.
|
private List<Cell> |
HRegion.applyIncrementsToColumnFamily(Increment increment,
byte[] columnFamilyName,
List<Cell> sortedIncrements,
long now,
long mvccNum,
List<Cell> allKVs,
IsolationLevel isolation)
Apply increments to a column family.
|
private List<Cell> |
HRegion.applyIncrementsToColumnFamily(Increment increment,
byte[] columnFamilyName,
List<Cell> sortedIncrements,
long now,
long mvccNum,
List<Cell> allKVs,
IsolationLevel isolation)
Apply increments to a column family.
|
void |
Region.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now)
Check the collection of families for valid timestamps
|
void |
HRegion.checkTimestamps(Map<byte[],List<Cell>> familyMap,
long now) |
(package private) void |
HRegion.delete(NavigableMap<byte[],List<Cell>> familyMap,
Durability durability)
This is used only by unit tests.
|
private List<Cell> |
HRegion.doGet(Store store,
byte[] row,
Map.Entry<byte[],List<Cell>> family,
TimeRange tr)
Run a Get against passed in
store on passed row , etc. |
private List<Cell> |
HRegion.getIncrementCurrentValue(Increment increment,
byte[] columnFamily,
List<Cell> increments,
IsolationLevel isolation)
Do a specific Get on passed
columnFamily and column qualifiers
from incrementCoordinates only. |
private Cell |
DefaultMemStore.MemStoreScanner.getNext(Iterator<Cell> it)
Lock on 'this' must be held by caller.
|
private Cell |
DefaultMemStore.getNextRow(Cell key,
NavigableSet<Cell> set) |
private void |
DefaultMemStore.getRowKeyAtOrBefore(NavigableSet<Cell> set,
GetClosestRowBeforeTracker state) |
private void |
DefaultMemStore.getRowKeyBefore(NavigableSet<Cell> set,
GetClosestRowBeforeTracker state) |
private DefaultMemStore.Member |
DefaultMemStore.memberOfPreviousRow(NavigableSet<Cell> set,
GetClosestRowBeforeTracker state,
Cell firstOnRow) |
boolean |
InternalScanner.next(List<Cell> results)
Grab the next row's worth of values.
|
boolean |
StoreScanner.next(List<Cell> outResult) |
boolean |
KeyValueHeap.next(List<Cell> result)
Gets the next row of keys from the top-most scanner.
|
boolean |
HRegion.RegionScannerImpl.next(List<Cell> outResults) |
boolean |
InternalScanner.next(List<Cell> result,
ScannerContext scannerContext)
Grab the next row's worth of values.
|
boolean |
StoreScanner.next(List<Cell> outResult,
ScannerContext scannerContext)
Get the next row of values from this Store.
|
boolean |
KeyValueHeap.next(List<Cell> result,
ScannerContext scannerContext) |
boolean |
HRegion.RegionScannerImpl.next(List<Cell> outResults,
ScannerContext scannerContext) |
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,
byte[] currentRow,
int offset,
short length)
Fetches records with currentRow into results list, until next row, batchLimit (if not -1) is
reached, or remainingResultSize (if not -1) is reaced
|
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
boolean |
RegionCoprocessorHost.preGet(Get get,
List<Cell> results) |
void |
Region.prepareDeleteTimestamps(Mutation mutation,
Map<byte[],List<Cell>> familyCellMap,
byte[] now)
Set up correct timestamps in the KVs in Delete object.
|
void |
HRegion.prepareDeleteTimestamps(Mutation mutation,
Map<byte[],List<Cell>> familyMap,
byte[] byteNow) |
private void |
HRegion.put(byte[] row,
byte[] family,
List<Cell> edits)
Add updates first to the wal and then add values to memstore.
|
private void |
HRegion.recordMutationWithoutWal(Map<byte[],List<Cell>> familyMap)
Update counters for number of puts without wal and the size of possible data loss.
|
private void |
HRegion.removeNonExistentColumnFamilyForReplay(Map<byte[],List<Cell>> familyMap)
During replay, there could exist column families which are removed between region server
failure and replay
|
(package private) void |
HRegion.rewriteCellTags(Map<byte[],List<Cell>> familyMap,
Mutation m)
Possibly rewrite incoming cell tags.
|
private void |
HRegion.rollbackMemstore(List<Cell> memstoreCells)
Remove all the keys listed in the map from the memstore.
|
private static List<Cell> |
HRegion.sort(List<Cell> cells,
Comparator<Cell> comparator) |
private static List<Cell> |
HRegion.sort(List<Cell> cells,
Comparator<Cell> comparator) |
void |
Region.updateCellTimestamps(Iterable<List<Cell>> values,
byte[] now)
Replace any cell timestamps set to HConstants#LATEST_TIMESTAMP with the
provided current timestamp.
|
void |
HRegion.updateCellTimestamps(Iterable<List<Cell>> cellItr,
byte[] now) |
long |
DefaultMemStore.upsert(Iterable<Cell> cells,
long readpoint)
Update or insert the specified KeyValues.
|
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.
|
long |
HStore.upsert(Iterable<Cell> cells,
long readpoint) |
private boolean |
DefaultMemStore.walkForwardInSingleRow(SortedSet<Cell> set,
Cell firstOnRow,
GetClosestRowBeforeTracker state) |
Constructor and Description |
---|
DefaultMemStore.Member(NavigableSet<Cell> s,
Cell kv) |
Constructor and Description |
---|
CellSkipListSet(ConcurrentNavigableMap<Cell,Cell> m) |
CellSkipListSet(ConcurrentNavigableMap<Cell,Cell> m) |
DefaultMemStore.Member(NavigableSet<Cell> s,
Cell kv) |
Modifier and Type | Method and Description |
---|---|
void |
Compactor.CellSink.append(Cell cell) |
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 ArrayList<Cell> |
WALEdit.cells |
Modifier and Type | Method and Description |
---|---|
protected Cell |
WALCellCodec.CompressedKvDecoder.parseCell() |
protected Cell |
SecureWALCellCodec.EncryptedKvDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
ArrayList<Cell> |
WALEdit.getCells() |
Modifier and Type | Method and Description |
---|---|
WALEdit |
WALEdit.add(Cell cell) |
static org.apache.hadoop.hbase.protobuf.generated.WALProtos.BulkLoadDescriptor |
WALEdit.getBulkLoadDescriptor(Cell cell)
Deserialized and returns a BulkLoadDescriptor from the passed in Cell
|
static org.apache.hadoop.hbase.protobuf.generated.WALProtos.CompactionDescriptor |
WALEdit.getCompaction(Cell kv)
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
|
static org.apache.hadoop.hbase.protobuf.generated.WALProtos.FlushDescriptor |
WALEdit.getFlushDescriptor(Cell cell) |
static org.apache.hadoop.hbase.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) |
void |
WALCellCodec.CompressedKvEncoder.write(Cell cell) |
void |
WALCellCodec.EnsureKvEncoder.write(Cell cell) |
void |
SecureWALCellCodec.EncryptedKvEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
void |
WALEdit.setCells(ArrayList<Cell> cells)
This is not thread safe.
|
Modifier and Type | Method and Description |
---|---|
private boolean |
ReplicationSink.isNewRowOrType(Cell previousCell,
Cell cell) |
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 |
---|---|
void |
RowResultGenerator.putBack(Cell kv) |
void |
ScannerResultGenerator.putBack(Cell kv) |
abstract void |
ResultGenerator.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) |
Cell |
AccessControlFilter.transformCell(Cell v) |
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.
|
Filter.ReturnCode |
AccessControlFilter.filterKeyValue(Cell cell) |
static List<Permission> |
AccessControlLists.getCellPermissionsForUser(User user,
Cell cell) |
private static Pair<String,TablePermission> |
AccessControlLists.parsePermissionRecord(byte[] entryName,
Cell kv) |
Cell |
AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Cell |
AccessControlFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
private static void |
AccessController.addCellPermissions(byte[] perms,
Map<byte[],List<Cell>> familyMap) |
void |
AccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c,
Get get,
List<Cell> result) |
(package private) void |
AccessController.updateACL(RegionCoprocessorEnvironment e,
Map<byte[],List<Cell>> familyMap)
Writes all table ACLs for the tables in the given Map up into ZooKeeper
znodes.
|
Modifier and Type | Method and Description |
---|---|
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Cell |
VisibilityLabelFilter.transformCell(Cell v) |
Cell |
VisibilityController.DeleteVersionVisibilityExpressionFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
protected List<List<Cell>> |
DefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths() |
Modifier and Type | Method and Description |
---|---|
void |
VisibilityScanDeleteTracker.add(Cell delCell) |
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.
|
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.filterKeyValue(Cell cell) |
Filter.ReturnCode |
VisibilityController.DeleteVersionVisibilityExpressionFilter.filterKeyValue(Cell cell) |
DeleteTracker.DeleteResult |
VisibilityScanDeleteTracker.isDeleted(Cell cell) |
static boolean |
VisibilityUtils.isVisibilityTagsPresent(Cell cell) |
Cell |
VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx,
RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
void |
VisibilityController.prePrepareTimeStampForDeleteVersion(ObserverContext<RegionCoprocessorEnvironment> ctx,
Mutation delete,
Cell cell,
byte[] byteNow,
Get get) |
Cell |
VisibilityLabelFilter.transformCell(Cell v) |
Cell |
VisibilityController.DeleteVersionVisibilityExpressionFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
protected Pair<Map<String,Integer>,Map<String,List<Integer>>> |
DefaultVisibilityLabelServiceImpl.extractLabelsAndAuths(List<List<Cell>> labelDetails) |
void |
VisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
Modifier and Type | Method and Description |
---|---|
static 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 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 |
CollectionBackedScanner.next() |
Cell |
CollectionBackedScanner.peek() |
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Binary search for keys in indexes.
|
boolean |
CollectionBackedScanner.reseek(Cell seekCell) |
boolean |
CollectionBackedScanner.seek(Cell seekCell) |
Modifier and Type | Method and Description |
---|---|
static int |
Bytes.binarySearch(byte[][] arr,
Cell key,
org.apache.hadoop.io.RawComparator<Cell> comparator)
Binary search for keys in indexes.
|
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 |
---|---|
private static Map<String,Object> |
WALPrettyPrinter.toStringMap(Cell cell) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.