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

Packages that use org.apache.hadoop.hbase.ExtendedCell
Package
Description
 
Provides HBase MapReduce Input/OutputFormats, a table indexing MapReduce job, and utility methods.
 
 
  • Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase

    Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ByteBufferExtendedCell
    This class is a server side extension to the Cell interface.
    class 
    org.apache.hadoop.hbase.ByteBufferKeyOnlyKeyValue
    This is a key only Cell implementation which is identical to KeyValue.KeyOnlyKeyValue with respect to key serialization but have its data in the form of Byte buffer (onheap and offheap).
    class 
    org.apache.hadoop.hbase.ByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.IndividualBytesFieldCell
     
    class 
    org.apache.hadoop.hbase.KeyValue
    An HBase Key/Value.
    static class 
    org.apache.hadoop.hbase.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 
    org.apache.hadoop.hbase.NoTagsByteBufferKeyValue
    An extension of the ByteBufferKeyValue where the tags length is always 0
    class 
    org.apache.hadoop.hbase.NoTagsKeyValue
    An extension of the KeyValue where the tags length is always 0
    class 
    org.apache.hadoop.hbase.SizeCachedByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.SizeCachedKeyValue
    This class is an extension to KeyValue where rowLen and keyLen are cached.
    class 
    org.apache.hadoop.hbase.SizeCachedNoTagsByteBufferKeyValue
    This Cell is an implementation of ByteBufferExtendedCell where the data resides in off heap/ on heap ByteBuffer
    class 
    org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
    This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.ExtendedCell
    ExtendedCellBuilder.build()
     
    org.apache.hadoop.hbase.ExtendedCell
    ExtendedCellBuilderImpl.build()
     
    org.apache.hadoop.hbase.ExtendedCell
    ByteBufferKeyValue.deepClone()
     
    default org.apache.hadoop.hbase.ExtendedCell
    ExtendedCell.deepClone()
    Does a deep copy of the contents to a new memory area and returns it as a new cell.
    org.apache.hadoop.hbase.ExtendedCell
    KeyValue.deepClone()
     
    org.apache.hadoop.hbase.ExtendedCell
    NoTagsByteBufferKeyValue.deepClone()
     
    org.apache.hadoop.hbase.ExtendedCell
    NoTagsKeyValue.deepClone()
     
    protected abstract org.apache.hadoop.hbase.ExtendedCell
    ExtendedCellBuilderImpl.innerBuild()
     
  • Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.KeyValue
    ExtendedCellSerialization.ExtendedCellDeserializer.deserialize(org.apache.hadoop.hbase.ExtendedCell ignore)
     
    void
    ExtendedCellSerialization.ExtendedCellSerializer.serialize(org.apache.hadoop.hbase.ExtendedCell kv)
     
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellDeserializer
    ExtendedCellSerialization.getDeserializer(Class<org.apache.hadoop.hbase.ExtendedCell> t)
     
    org.apache.hadoop.hbase.mapreduce.ExtendedCellSerialization.ExtendedCellSerializer
    ExtendedCellSerialization.getSerializer(Class<org.apache.hadoop.hbase.ExtendedCell> c)
     
  • Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.regionserver

    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.ByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset
    class 
    org.apache.hadoop.hbase.regionserver.NoTagByteBufferChunkKeyValue
    ByteBuffer based cell which has the chunkid at the 0th offset and with no tags
  • Uses of org.apache.hadoop.hbase.ExtendedCell in org.apache.hadoop.hbase.util

    Classes in org.apache.hadoop.hbase.util that implement org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.util.MapReduceExtendedCell
    A wrapper for a cell to be used with mapreduce, as the output value class for mappers/reducers.
    Methods in org.apache.hadoop.hbase.util that return org.apache.hadoop.hbase.ExtendedCell in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.ExtendedCell
    MapReduceExtendedCell.deepClone()