Uses of Interface
org.apache.hadoop.hbase.Cell

Packages that use Cell
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.client Provides HBase Client 
org.apache.hadoop.hbase.client.coprocessor Provides client classes for invoking Coprocessor RPC protocols 
org.apache.hadoop.hbase.codec   
org.apache.hadoop.hbase.codec.prefixtree   
org.apache.hadoop.hbase.codec.prefixtree.decode   
org.apache.hadoop.hbase.codec.prefixtree.encode   
org.apache.hadoop.hbase.codec.prefixtree.scanner   
org.apache.hadoop.hbase.coprocessor Table of Contents 
org.apache.hadoop.hbase.filter Provides row-level filters applied to HRegion scan results during calls to ResultScanner.next()
org.apache.hadoop.hbase.io   
org.apache.hadoop.hbase.io.encoding   
org.apache.hadoop.hbase.mapreduce Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility 
org.apache.hadoop.hbase.protobuf Holds classes generated from protobuf src/main/protobuf definition files. 
org.apache.hadoop.hbase.regionserver   
org.apache.hadoop.hbase.regionserver.wal   
org.apache.hadoop.hbase.rest HBase REST 
org.apache.hadoop.hbase.security.access   
org.apache.hadoop.hbase.security.visibility   
org.apache.hadoop.hbase.thrift Provides an HBase Thrift service. 
 

Uses of Cell in org.apache.hadoop.hbase
 

Classes in org.apache.hadoop.hbase that implement Cell
 class KeyValue
          An HBase Key/Value.
 class NoTagsKeyValue
          An extension of the KeyValue where the tags length is always 0
 

Methods in org.apache.hadoop.hbase that return Cell
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()
           
 

Methods in org.apache.hadoop.hbase with parameters of type Cell
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 CellComparator.compare(Cell a, Cell b)
           
 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
static int CellComparator.compareFamilies(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.
static int CellComparator.compareStatic(Cell a, Cell b)
           
static int CellComparator.compareStatic(Cell a, Cell b, boolean onlyKey)
           
static int CellComparator.compareTimestamps(Cell left, Cell right)
          Compares cell's timestamps in DESCENDING order.
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 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.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.matchingTimestamp(Cell a, Cell b)
           
static boolean CellUtil.matchingValue(Cell left, byte[] buf)
           
static boolean CellUtil.matchingValue(Cell left, Cell right)
           
 

Method parameters in org.apache.hadoop.hbase with type arguments of type Cell
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)
           
 

Constructors in org.apache.hadoop.hbase with parameters of type Cell
KeyValue(Cell c)
           
 

Uses of Cell in org.apache.hadoop.hbase.client
 

Fields in org.apache.hadoop.hbase.client with type parameters of type Cell
protected  NavigableMap<byte[],List<Cell>> Mutation.familyMap
           
 

Methods in org.apache.hadoop.hbase.client that return Cell
 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.
 

Methods in org.apache.hadoop.hbase.client that return types with arguments of type Cell
 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.
 

Methods in org.apache.hadoop.hbase.client with parameters of type Cell
 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.
 Increment Increment.add(Cell cell)
          Add the specified KeyValue to this 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.
 

Method parameters in org.apache.hadoop.hbase.client with type arguments of type Cell
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
 

Uses of Cell in org.apache.hadoop.hbase.client.coprocessor
 

Methods in org.apache.hadoop.hbase.client.coprocessor with parameters of type Cell
 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)
           
 

Uses of Cell in org.apache.hadoop.hbase.codec
 

Methods in org.apache.hadoop.hbase.codec that return Cell
 Cell BaseDecoder.current()
           
protected  Cell KeyValueCodec.KeyValueDecoder.parseCell()
           
protected  Cell KeyValueCodecWithTags.KeyValueDecoder.parseCell()
           
protected abstract  Cell BaseDecoder.parseCell()
           
 

Methods in org.apache.hadoop.hbase.codec with parameters of type Cell
 void KeyValueCodec.KeyValueEncoder.write(Cell cell)
           
abstract  void BaseEncoder.write(Cell cell)
           
 void KeyValueCodecWithTags.KeyValueEncoder.write(Cell cell)
           
 

Uses of Cell in org.apache.hadoop.hbase.codec.prefixtree
 

Methods in org.apache.hadoop.hbase.codec.prefixtree that return Cell
 Cell PrefixTreeSeeker.get()
          Currently unused.
 

Uses of Cell in org.apache.hadoop.hbase.codec.prefixtree.decode
 

Classes in org.apache.hadoop.hbase.codec.prefixtree.decode that implement Cell
 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.
 

Methods in org.apache.hadoop.hbase.codec.prefixtree.decode that return Cell
 Cell PrefixTreeArrayScanner.current()
          CellScanner
 

Methods in org.apache.hadoop.hbase.codec.prefixtree.decode with parameters of type Cell
 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)
           
 

Uses of Cell in org.apache.hadoop.hbase.codec.prefixtree.encode
 

Methods in org.apache.hadoop.hbase.codec.prefixtree.encode with parameters of type Cell
 void PrefixTreeEncoder.write(Cell cell)
           
 void PrefixTreeEncoder.writeWithRepeatRow(Cell cell)
          Add a Cell to the output stream but repeat the previous row.
 

Uses of Cell in org.apache.hadoop.hbase.codec.prefixtree.scanner
 

Methods in org.apache.hadoop.hbase.codec.prefixtree.scanner with parameters of type Cell
 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.
 

Uses of Cell in org.apache.hadoop.hbase.coprocessor
 

Methods in org.apache.hadoop.hbase.coprocessor that return Cell
 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)
           
 

Methods in org.apache.hadoop.hbase.coprocessor with parameters of type Cell
 T ColumnInterpreter.getValue(byte[] colFamily, byte[] colQualifier, Cell c)
          TODO: when removing ColumnInterpreter.getValue(byte[], byte[], KeyValue), this method should be made abstract
 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)
           
 

Method parameters in org.apache.hadoop.hbase.coprocessor with type arguments of type Cell
 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)
           
 

Uses of Cell in org.apache.hadoop.hbase.filter
 

Methods in org.apache.hadoop.hbase.filter that return 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 MultipleColumnPrefixFilter.getNextCellHint(Cell kv)
           
 Cell ColumnPrefixFilter.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 ColumnPaginationFilter.getNextCellHint(Cell kv)
           
 Cell ColumnRangeFilter.getNextCellHint(Cell kv)
           
 Cell FuzzyRowFilter.getNextCellHint(Cell currentCell)
           
 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.transformCell(Cell v)
          Give the filter a chance to transform the passed KeyValue.
 Cell KeyOnlyFilter.transformCell(Cell kv)
           
 Cell SkipFilter.transformCell(Cell v)
           
 Cell FilterList.transformCell(Cell v)
           
 Cell WhileMatchFilter.transformCell(Cell v)
           
 Cell FilterWrapper.transformCell(Cell v)
           
 Cell FilterBase.transformCell(Cell v)
          By default no transformation takes place
 

Methods in org.apache.hadoop.hbase.filter with parameters of type Cell
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 ValueFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode PrefixFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode SingleColumnValueFilter.filterKeyValue(Cell c)
           
 Filter.ReturnCode TimestampsFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode SkipFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode MultipleColumnPrefixFilter.filterKeyValue(Cell kv)
           
 Filter.ReturnCode FamilyFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode InclusiveStopFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode ColumnPrefixFilter.filterKeyValue(Cell kv)
           
 Filter.ReturnCode FilterList.filterKeyValue(Cell v)
           
 Filter.ReturnCode FirstKeyValueMatchingQualifiersFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode QualifierFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode WhileMatchFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode FilterWrapper.filterKeyValue(Cell v)
           
 Filter.ReturnCode ColumnCountGetFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode ColumnPaginationFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode RowFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode DependentColumnFilter.filterKeyValue(Cell c)
           
 Filter.ReturnCode ColumnRangeFilter.filterKeyValue(Cell kv)
           
 Filter.ReturnCode RandomRowFilter.filterKeyValue(Cell v)
           
 Filter.ReturnCode FuzzyRowFilter.filterKeyValue(Cell c)
           
 Filter.ReturnCode FirstKeyOnlyFilter.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  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 MultipleColumnPrefixFilter.getNextCellHint(Cell kv)
           
 Cell ColumnPrefixFilter.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 ColumnPaginationFilter.getNextCellHint(Cell kv)
           
 Cell ColumnRangeFilter.getNextCellHint(Cell kv)
           
 Cell FuzzyRowFilter.getNextCellHint(Cell currentCell)
           
 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.transformCell(Cell v)
          Give the filter a chance to transform the passed KeyValue.
 Cell KeyOnlyFilter.transformCell(Cell kv)
           
 Cell SkipFilter.transformCell(Cell v)
           
 Cell FilterList.transformCell(Cell v)
           
 Cell WhileMatchFilter.transformCell(Cell v)
           
 Cell FilterWrapper.transformCell(Cell v)
           
 Cell FilterBase.transformCell(Cell v)
          By default no transformation takes place
 

Method parameters in org.apache.hadoop.hbase.filter with type arguments of type Cell
abstract  void Filter.filterRowCells(List<Cell> kvs)
          Chance to alter the list of Cells to be submitted.
 void SingleColumnValueExcludeFilter.filterRowCells(List<Cell> kvs)
           
 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 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.
 FilterWrapper.FilterRowRetCode FilterWrapper.filterRowCellsWithRet(List<Cell> kvs)
           
 

Uses of Cell in org.apache.hadoop.hbase.io
 

Methods in org.apache.hadoop.hbase.io with parameters of type Cell
 void CellOutputStream.write(Cell cell)
          Implementation must copy the entire state of the Cell.
 

Uses of Cell in org.apache.hadoop.hbase.io.encoding
 

Methods in org.apache.hadoop.hbase.io.encoding that return types with arguments of type Cell
 Iterator<Cell> EncodedDataBlock.getIterator(int headerSize)
          Provides access to compressed value.
 

Uses of Cell in org.apache.hadoop.hbase.mapreduce
 

Methods in org.apache.hadoop.hbase.mapreduce that return Cell
 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
 

Methods in org.apache.hadoop.hbase.mapreduce that return types with arguments of type Cell
 org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,Cell> HFileOutputFormat2.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
           
 

Methods in org.apache.hadoop.hbase.mapreduce with parameters of type Cell
protected  void Import.Importer.addPutToKv(Put put, Cell kv)
           
static Cell Import.filterKv(Filter filter, Cell kv)
          Attempt to filter out the keyvalue
 

Uses of Cell in org.apache.hadoop.hbase.protobuf
 

Methods in org.apache.hadoop.hbase.protobuf that return Cell
static Cell ProtobufUtil.toCell(CellProtos.Cell cell)
           
 

Methods in org.apache.hadoop.hbase.protobuf with parameters of type Cell
static CellProtos.Cell ProtobufUtil.toCell(Cell kv)
           
 

Uses of Cell in org.apache.hadoop.hbase.regionserver
 

Methods in org.apache.hadoop.hbase.regionserver that return Cell
 Cell ScanQueryMatcher.getNextKeyHint(Cell kv)
           
 Cell RegionCoprocessorHost.postMutationBeforeWAL(RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell)
           
 

Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type Cell
 List<Cell> HRegion.get(Get get, boolean withCoprocessor)
           
 

Methods in org.apache.hadoop.hbase.regionserver with parameters of type Cell
 void ScanDeleteTracker.add(Cell cell)
          Add the specified KeyValue to the list of deletes to check against for this row operation.
 void DeleteTracker.add(Cell cell)
          Add the specified cell to the list of deletes to check against for this row operation.
 int ScanQueryMatcher.compareKeyForNextColumn(byte[] nextIndexed, Cell kv)
           
 int ScanQueryMatcher.compareKeyForNextRow(byte[] nextIndexed, Cell kv)
           
 Cell ScanQueryMatcher.getNextKeyHint(Cell kv)
           
 DeleteTracker.DeleteResult ScanDeleteTracker.isDeleted(Cell cell)
          Check if the specified KeyValue buffer has been deleted by a previously seen delete.
 DeleteTracker.DeleteResult DeleteTracker.isDeleted(Cell cell)
          Check if the specified cell 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)
           
 

Method parameters in org.apache.hadoop.hbase.regionserver with type arguments of type Cell
 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 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 StoreScanner.next(List<Cell> outResult, int limit)
          Get the next row of values from this Store.
 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.
 

Uses of Cell in org.apache.hadoop.hbase.regionserver.wal
 

Methods in org.apache.hadoop.hbase.regionserver.wal that return types with arguments of type Cell
 ArrayList<Cell> WALEdit.getCells()
           
 

Methods in org.apache.hadoop.hbase.regionserver.wal with parameters of type Cell
 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)
           
 

Uses of Cell in org.apache.hadoop.hbase.rest
 

Methods in org.apache.hadoop.hbase.rest that return Cell
 Cell RowResultGenerator.next()
           
 Cell ScannerResultGenerator.next()
           
 

Methods in org.apache.hadoop.hbase.rest with parameters of type Cell
abstract  void ResultGenerator.putBack(Cell kv)
           
 void RowResultGenerator.putBack(Cell kv)
           
 void ScannerResultGenerator.putBack(Cell kv)
           
 

Uses of Cell in org.apache.hadoop.hbase.security.access
 

Methods in org.apache.hadoop.hbase.security.access that return Cell
 Cell AccessController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell)
           
 

Methods in org.apache.hadoop.hbase.security.access with parameters of type Cell
 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)
           
 

Method parameters in org.apache.hadoop.hbase.security.access with type arguments of type Cell
 void AccessController.preGetOp(ObserverContext<RegionCoprocessorEnvironment> c, Get get, List<Cell> result)
           
 

Uses of Cell in org.apache.hadoop.hbase.security.visibility
 

Methods in org.apache.hadoop.hbase.security.visibility that return Cell
 Cell VisibilityController.postMutationBeforeWAL(ObserverContext<RegionCoprocessorEnvironment> ctx, RegionObserver.MutationType opType, Mutation mutation, Cell oldCell, Cell newCell)
           
 

Methods in org.apache.hadoop.hbase.security.visibility that return types with arguments of type Cell
protected  List<List<Cell>> DefaultVisibilityLabelServiceImpl.getExistingLabelsWithAuths()
           
 

Methods in org.apache.hadoop.hbase.security.visibility with parameters of type Cell
 void VisibilityScanDeleteTracker.add(Cell delCell)
           
 boolean VisibilityExpEvaluator.evaluate(Cell cell)
          Evaluates whether the passed cell passes Scan/Get Authorization.
static Byte VisibilityUtils.extractAndPartitionTags(Cell cell, List<Tag> visTags, List<Tag> nonVisTags)
          Extracts and partitions the visibility tags and nonVisibility Tags
static Byte VisibilityUtils.extractVisibilityTags(Cell cell, List<Tag> tags)
          Extract the visibility tags of the given Cell into the given List
 DeleteTracker.DeleteResult 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)
           
 

Method parameters in org.apache.hadoop.hbase.security.visibility with type arguments of type Cell
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)
           
 

Uses of Cell in org.apache.hadoop.hbase.thrift
 

Methods in org.apache.hadoop.hbase.thrift with parameters of type Cell
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 © 2007–2015 The Apache Software Foundation. All rights reserved.