Modifier and Type | Class and Description |
---|---|
class |
KeyValue
An HBase Key/Value.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
byte[] tags,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
byte type,
byte[] value,
long memstoreTS) |
static Cell |
CellUtil.createCell(byte[] row,
byte[] family,
byte[] qualifier,
long timestamp,
KeyValue.Type type,
byte[] value,
byte[] tags) |
Cell |
CellScanner.current() |
Modifier and Type | Method and Description |
---|---|
protected static int |
KeyValueUtil.appendKeyToByteArrayWithoutValue(Cell cell,
byte[] output,
int offset) |
static int |
KeyValueUtil.appendToByteArray(Cell cell,
byte[] output,
int offset)
copy key and value
|
static boolean |
CellComparator.areKeyLengthsEqual(Cell a,
Cell b)
lengths
|
static boolean |
CellComparator.areRowLengthsEqual(Cell a,
Cell b) |
static KeyValue |
KeyValue.cloneAndAddTags(Cell c,
List<Tag> newTags)
Create a new KeyValue by copying existing cell and adding new tags
|
static byte[] |
CellUtil.cloneFamily(Cell cell) |
static byte[] |
CellUtil.cloneQualifier(Cell cell) |
static byte[] |
CellUtil.cloneRow(Cell cell)
get individual arrays for tests
|
static byte[] |
CellUtil.cloneValue(Cell cell) |
int |
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 |
CellComparator.compare(Cell a,
Cell b) |
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.compareStatic(Cell a,
Cell b) |
static int |
CellComparator.compareStatic(Cell a,
Cell b,
boolean onlyKey) |
static int |
CellUtil.copyFamilyTo(Cell cell,
byte[] destination,
int destinationOffset) |
static ByteBuffer |
KeyValueUtil.copyKeyToNewByteBuffer(Cell cell) |
static int |
CellUtil.copyQualifierTo(Cell cell,
byte[] destination,
int destinationOffset) |
static int |
CellUtil.copyRowTo(Cell cell,
byte[] destination,
int destinationOffset)
copyTo
|
static int |
CellUtil.copyTagTo(Cell cell,
byte[] destination,
int destinationOffset)
Copies the tags info into the tag portion of the cell
|
static byte[] |
KeyValueUtil.copyToNewByteArray(Cell cell) |
static ByteBuffer |
KeyValueUtil.copyToNewByteBuffer(Cell cell) |
static KeyValue |
KeyValueUtil.copyToNewKeyValue(Cell cell)
copy key only
|
static int |
CellUtil.copyValueTo(Cell cell,
byte[] destination,
int destinationOffset) |
static CellScanner |
CellUtil.createCellScanner(Cell[] cellArray) |
static KeyValue |
KeyValueUtil.createFirstKeyInIncrementedRow(Cell in)
Increment the row bytes and clear the other fields
|
static KeyValue |
KeyValueUtil.createFirstKeyInNextRow(Cell in)
Append single byte 0x00 to the end of the input row key
|
static KeyValue |
KeyValueUtil.ensureKeyValue(Cell cell) |
static boolean |
CellComparator.equals(Cell a,
Cell b)
equals
|
static boolean |
CellComparator.equalsFamily(Cell a,
Cell b) |
static boolean |
CellComparator.equalsIgnoreMvccVersion(Cell a,
Cell b)
special case for KeyValue.equals
|
static boolean |
CellComparator.equalsQualifier(Cell a,
Cell b) |
static boolean |
CellComparator.equalsRow(Cell a,
Cell b) |
static boolean |
CellComparator.equalsTimestamp(Cell a,
Cell b) |
static boolean |
CellComparator.equalsType(Cell a,
Cell b) |
static int |
CellUtil.estimatedSizeOf(Cell cell) |
static ByteRange |
CellUtil.fillFamilyRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillQualifierRange(Cell cell,
ByteRange range) |
static ByteRange |
CellUtil.fillRowRange(Cell cell,
ByteRange range)
ByteRange
|
static ByteRange |
CellUtil.fillTagRange(Cell cell,
ByteRange range) |
static ByteBuffer |
CellUtil.getQualifierBufferShallowCopy(Cell cell) |
static byte |
CellUtil.getRowByte(Cell cell,
int index)
misc
|
static byte[] |
CellUtil.getTagArray(Cell cell)
Returns tag value in a new byte array.
|
static ByteBuffer |
CellUtil.getValueBufferShallowCopy(Cell cell) |
static int |
CellComparator.hashCode(Cell cell)
Returns a hash code that is always the same for two Cells having a matching equals(..) result.
|
static boolean |
CellUtil.isDelete(Cell cell) |
static boolean |
CellUtil.isDeleteColumns(Cell cell) |
static boolean |
CellUtil.isDeleteColumnVersion(Cell cell) |
static boolean |
CellUtil.isDeleteFamily(Cell cell) |
static int |
KeyValueUtil.keyLength(Cell cell) |
static int |
KeyValueUtil.length(Cell cell)
length
|
static boolean |
CellUtil.matchingColumn(Cell left,
byte[] fam,
byte[] qual) |
static boolean |
CellUtil.matchingColumn(Cell left,
Cell right) |
static boolean |
CellUtil.matchingFamily(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingFamily(Cell left,
Cell right) |
static boolean |
CellUtil.matchingQualifier(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingQualifier(Cell left,
Cell right) |
static boolean |
CellUtil.matchingRow(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingRow(Cell left,
Cell right) |
static boolean |
CellUtil.matchingValue(Cell left,
byte[] buf) |
static boolean |
CellUtil.matchingValue(Cell left,
Cell right) |
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) |
Constructor and Description |
---|
KeyValue(Cell c) |
Modifier and Type | Field and Description |
---|---|
protected NavigableMap<byte[],List<Cell>> |
Mutation.familyMap |
Modifier and Type | Method and Description |
---|---|
Cell |
Result.current() |
Cell |
Result.getColumnLatestCell(byte[] family,
byte[] qualifier)
The Cell for the most recent timestamp for a given column.
|
Cell |
Result.getColumnLatestCell(byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
The Cell for the most recent timestamp for a given column.
|
Cell[] |
Result.rawCells()
Return the array of Cells backing this Result instance.
|
Modifier and Type | Method and Description |
---|---|
List<Cell> |
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 |
---|---|
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.
|
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.
|
static Result |
Result.create(Cell[] cells)
Instantiate a Result with the specified array of KeyValues.
|
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) |
void |
Mutation.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map)
Method for setting the put's familyMap
|
Modifier and Type | Method and Description |
---|---|
BigDecimal |
BigDecimalColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Long |
LongColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell kv) |
Double |
DoubleColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c) |
Modifier and Type | Method and Description |
---|---|
Cell |
BaseDecoder.current() |
protected Cell |
KeyValueCodecWithTags.KeyValueDecoder.parseCell() |
protected Cell |
KeyValueCodec.KeyValueDecoder.parseCell() |
protected abstract Cell |
BaseDecoder.parseCell() |
Modifier and Type | Method and Description |
---|---|
void |
KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell) |
abstract void |
BaseEncoder.write(Cell cell) |
void |
KeyValueCodec.KeyValueEncoder.write(Cell cell) |
Modifier and Type | Method and Description |
---|---|
Cell |
PrefixTreeSeeker.get()
Currently unused.
|
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 |
---|---|
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.KeyValue)
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 |
---|---|
T |
ColumnInterpreter.getValue(byte[] colFamily,
byte[] colQualifier,
Cell c)
TODO: when removing
ColumnInterpreter.getValue(byte[], byte[], KeyValue) , this method should be made abstract |
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.
|
Modifier and Type | Method and Description |
---|---|
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 |
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
|
Modifier and Type | Method and Description |
---|---|
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
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 |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV)
Old filter wrapper descendants will implement KV getNextKeyHint(KV) so we should call it.
|
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentKV) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell kv) |
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
|
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterList.transformCell(Cell v) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
Filter.ReturnCode |
DependentColumnFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
ColumnCountGetFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
WhileMatchFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
MultipleColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
ValueFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FamilyFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPaginationFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
RowFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FilterBase.filterKeyValue(Cell ignored)
Filters that dont filter by key value can inherit this implementation that
includes all Cells.
|
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 |
ColumnRangeFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
FilterList.filterKeyValue(Cell v) |
Filter.ReturnCode |
SingleColumnValueFilter.filterKeyValue(Cell c) |
Filter.ReturnCode |
TimestampsFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
RandomRowFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FilterWrapper.filterKeyValue(Cell v) |
Filter.ReturnCode |
InclusiveStopFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FirstKeyOnlyFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
PrefixFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
SkipFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
ColumnPrefixFilter.filterKeyValue(Cell kv) |
Filter.ReturnCode |
QualifierFilter.filterKeyValue(Cell v) |
Filter.ReturnCode |
FuzzyRowFilter.filterKeyValue(Cell kv) |
Cell |
MultipleColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
ColumnPaginationFilter.getNextCellHint(Cell kv) |
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 |
FilterList.getNextCellHint(Cell currentKV) |
Cell |
FilterWrapper.getNextCellHint(Cell currentKV)
Old filter wrapper descendants will implement KV getNextKeyHint(KV) so we should call it.
|
Cell |
ColumnPrefixFilter.getNextCellHint(Cell kv) |
Cell |
FuzzyRowFilter.getNextCellHint(Cell currentKV) |
Cell |
WhileMatchFilter.transformCell(Cell v) |
Cell |
KeyOnlyFilter.transformCell(Cell kv) |
Cell |
FilterBase.transformCell(Cell v)
By default no transformation takes place
|
abstract Cell |
Filter.transformCell(Cell v)
Give the filter a chance to transform the passed KeyValue.
|
Cell |
FilterList.transformCell(Cell v) |
Cell |
FilterWrapper.transformCell(Cell v) |
Cell |
SkipFilter.transformCell(Cell v) |
Modifier and Type | Method and Description |
---|---|
void |
DependentColumnFilter.filterRowCells(List<Cell> kvs) |
void |
FilterBase.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
abstract void |
Filter.filterRowCells(List<Cell> kvs)
Chance to alter the list of Cells to be submitted.
|
void |
FilterList.filterRowCells(List<Cell> ignored)
Filters that never filter by modifying the returned List of Cells can
inherit this implementation that does nothing.
|
void |
FilterWrapper.filterRowCells(List<Cell> kvs) |
void |
SingleColumnValueExcludeFilter.filterRowCells(List<Cell> kvs) |
FilterWrapper.FilterRowRetCode |
FilterWrapper.filterRowCellsWithRet(List<Cell> kvs) |
Modifier and Type | Method and Description |
---|---|
void |
CellOutputStream.write(Cell cell)
Implementation must copy the entire state of the Cell.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Cell> |
EncodedDataBlock.getIterator(int headerSize)
Provides access to compressed value.
|
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,
String visExpression) |
static Cell |
Import.filterKv(Filter filter,
Cell kv)
Attempt to filter out the keyvalue
|
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) |
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 | Method and Description |
---|---|
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
Cell |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
Modifier and Type | Method and Description |
---|---|
List<Cell> |
HRegion.get(Get get,
boolean withCoprocessor) |
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.
|
void |
ScanDeleteTracker.add(Cell cell)
Add the specified KeyValue to the list of deletes to check against for
this row operation.
|
Cell |
ScanQueryMatcher.getNextKeyHint(Cell kv) |
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 |
RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType,
Mutation mutation,
Cell oldCell,
Cell newCell) |
boolean |
RegionCoprocessorHost.prePrepareTimeStampForDeleteVersion(Mutation mutation,
Cell kv,
byte[] byteNow,
Get get) |
Modifier and Type | Method and Description |
---|---|
boolean |
StoreScanner.next(List<Cell> outResult) |
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,
int limit)
Get the next row of values from this Store.
|
boolean |
InternalScanner.next(List<Cell> result,
int limit)
Grab the next row's worth of values with a limit on the number of values
to return.
|
boolean |
KeyValueHeap.next(List<Cell> result,
int limit)
Gets the next row of keys from the top-most scanner.
|
boolean |
RegionScanner.nextRaw(List<Cell> result)
Grab the next row's worth of values with the default limit on the number of values
to return.
|
boolean |
RegionScanner.nextRaw(List<Cell> result,
int limit)
Grab the next row's worth of values with a limit on the number of values
to return.
|
void |
RegionCoprocessorHost.postGet(Get get,
List<Cell> results) |
boolean |
RegionCoprocessorHost.preGet(Get get,
List<Cell> results) |
long |
Store.upsert(Iterable<Cell> cells,
long readpoint)
Adds or replaces the specified KeyValues.
|
long |
HStore.upsert(Iterable<Cell> cells,
long readpoint) |
long |
MemStore.upsert(Iterable<Cell> cells,
long readpoint)
Update or insert the specified KeyValues.
|
Modifier and Type | Method and Description |
---|---|
ArrayList<Cell> |
WALEdit.getCells() |
Modifier and Type | Method and Description |
---|---|
WALEdit |
WALEdit.add(Cell cell)
Adds a Cell to this edit
|
static WALProtos.CompactionDescriptor |
WALEdit.getCompaction(Cell kv)
Deserialized and returns a CompactionDescriptor is the KeyValue contains one.
|
void |
WALCellCodec.EnsureKvEncoder.write(Cell cell) |
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) |
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.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 |
VisibilityController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> e,
Get get,
List<Cell> results) |
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.
|
Copyright © 2014 The Apache Software Foundation. All rights reserved.