Uses of Class
org.apache.hadoop.hbase.KeyValue

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

    Subclasses of org.apache.hadoop.hbase.KeyValue in in org.apache.hadoop.hbase
    Modifier and Type
    Class
    Description
    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.NoTagsKeyValue
    An extension of the KeyValue where the tags length is always 0
    class 
    org.apache.hadoop.hbase.SizeCachedKeyValue
    This class is an extension to KeyValue where rowLen and keyLen are cached.
    class 
    org.apache.hadoop.hbase.SizeCachedNoTagsKeyValue
    This class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.
    Fields in org.apache.hadoop.hbase declared as org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Field
    Description
    static final org.apache.hadoop.hbase.KeyValue
    KeyValue.LOWESTKEY
    Lowest possible key.
    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.KeyValue
    KeyValue.clone()
    Clones a KeyValue.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.copyToNewKeyValue(org.apache.hadoop.hbase.Cell cell)
    copy the cell to create a new keyvalue
    static org.apache.hadoop.hbase.KeyValue
    KeyValue.create(int length, DataInput in)
    Create a KeyValue reading length from in
    static org.apache.hadoop.hbase.KeyValue
    KeyValue.create(DataInput in)
    Create a KeyValue reading from in
    static org.apache.hadoop.hbase.KeyValue
    KeyValueTestUtil.create(String row, String family, String qualifier, long timestamp, String value)
     
    static org.apache.hadoop.hbase.KeyValue
    KeyValueTestUtil.create(String row, String family, String qualifier, long timestamp, org.apache.hadoop.hbase.KeyValue.Type type, String value)
     
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.create(int length, DataInput in)
    Create a KeyValue reading length from in
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.create(DataInput in)
    Where to read bytes from.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row)
    Create a KeyValue that is smaller than all other possible KeyValues for the given row.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row, byte[] family, byte[] qualifier)
    Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row,family,qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] buffer, byte[] row, byte[] family, byte[] qualifier)
    Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row, byte[] f, byte[] q, long ts)
    Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] buffer, int boffset, byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength)
    Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength)
    Create a KeyValue for the specified row, family and qualifier that would be smaller than all other possible KeyValues that have the same row, family, qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row, int roffset, short rlength)
    Create a KeyValue that is smaller than all other possible KeyValues for the given row.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createFirstOnRow(byte[] row, long ts)
    Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.
    org.apache.hadoop.hbase.KeyValue
    KeyValue.createKeyOnly(boolean lenAsVal)
    Creates a new KeyValue that only contains the key portion (the value is set to be null).
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createKeyValueFromInputStream(InputStream in, boolean withTags)
    Create a KeyValue reading from the raw InputStream.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createKeyValueFromKey(byte[] b)
    Returns a KeyValue made of a byte array that holds the key-only part.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createKeyValueFromKey(byte[] b, int o, int l)
    Return a KeyValue made of a byte array that holds the key-only part.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createKeyValueFromKey(ByteBuffer bb)
    Return a KeyValue made of a byte buffer that holds the key-only part.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createLastOnRow(byte[] row)
    Creates a KeyValue that is last on the specified row id.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.createLastOnRow(byte[] row, int roffset, int rlength, byte[] family, int foffset, int flength, byte[] qualifier, int qoffset, int qlength)
    Create a KeyValue for the specified row, family and qualifier that would be larger than or equal to all other possible KeyValues that have the same row, family, qualifier.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.ensureKeyValue(org.apache.hadoop.hbase.Cell cell)
    Deprecated.
    without any replacement.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.nextShallowCopy(ByteBuffer bb, boolean includesMvccVersion, boolean includesTags)
    Creates a new KeyValue object positioned in the supplied ByteBuffer and sets the ByteBuffer's position to the start of the next KeyValue.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.previousKey(org.apache.hadoop.hbase.KeyValue in)
    Decrement the timestamp.
    org.apache.hadoop.hbase.KeyValue
    KeyValue.shallowCopy()
    Creates a shallow copy of this KeyValue, reusing the data byte buffer.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.toNewKeyCell(org.apache.hadoop.hbase.Cell cell)
    Copies the key to a new KeyValue
    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    static List<org.apache.hadoop.hbase.KeyValue>
    KeyValueUtil.ensureKeyValues(List<org.apache.hadoop.hbase.Cell> cells)
    Deprecated.
    static List<org.apache.hadoop.hbase.KeyValue>
    KeyValueTestUtil.rewindThenToList(ByteBuffer bb, boolean includesMemstoreTS, boolean useTags)
     
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    static void
    KeyValueUtil.appendToByteBuffer(ByteBuffer bb, org.apache.hadoop.hbase.KeyValue kv, boolean includeMvccVersion)
     
    protected int
    CellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.KeyValue left, int leftFamilyPosition, int leftFamilyLength, org.apache.hadoop.hbase.ByteBufferKeyValue right, int rightFamilyPosition, int rightFamilyLength)
    This method will be overridden when we compare cells inner store to bypass family comparing.
    protected int
    CellComparatorImpl.compareFamilies(org.apache.hadoop.hbase.KeyValue left, int leftFamilyPosition, int leftFamilyLength, org.apache.hadoop.hbase.KeyValue right, int rightFamilyPosition, int rightFamilyLength)
    This method will be overridden when we compare cells inner store to bypass family comparing.
    protected int
    InnerStoreCellComparator.compareFamilies(org.apache.hadoop.hbase.KeyValue left, int leftFamilyPosition, int leftFamilyLength, org.apache.hadoop.hbase.ByteBufferKeyValue right, int rightFamilyPosition, int rightFamilyLength)
     
    protected int
    InnerStoreCellComparator.compareFamilies(org.apache.hadoop.hbase.KeyValue left, int leftFamilyPosition, int leftFamilyLength, org.apache.hadoop.hbase.KeyValue right, int rightFamilyPosition, int rightFamilyLength)
     
    protected static String
    KeyValueTestUtil.getFamilyString(org.apache.hadoop.hbase.KeyValue kv)
     
    protected static String
    KeyValueTestUtil.getQualifierString(org.apache.hadoop.hbase.KeyValue kv)
     
    protected static String
    KeyValueTestUtil.getRowString(org.apache.hadoop.hbase.KeyValue kv)
     
    protected static String
    KeyValueTestUtil.getTimestampString(org.apache.hadoop.hbase.KeyValue kv)
     
    protected static String
    KeyValueTestUtil.getTypeString(org.apache.hadoop.hbase.KeyValue kv)
     
    protected static String
    KeyValueTestUtil.getValueString(org.apache.hadoop.hbase.KeyValue kv)
     
    static int
    KeyValueUtil.lengthWithMvccVersion(org.apache.hadoop.hbase.KeyValue kv, boolean includeMvccVersion)
     
    static long
    KeyValue.oswrite(org.apache.hadoop.hbase.KeyValue kv, OutputStream out, boolean withTags)
    Deprecated.
    As of release 2.0.0, this will be removed in HBase 3.0.0.
    static org.apache.hadoop.hbase.KeyValue
    KeyValueUtil.previousKey(org.apache.hadoop.hbase.KeyValue in)
    Decrement the timestamp.
    protected static String
    KeyValueTestUtil.toStringWithPadding(org.apache.hadoop.hbase.KeyValue kv, int maxRowLength, int maxFamilyLength, int maxQualifierLength, int maxTimestampLength, boolean includeMeta)
     
    static long
    KeyValue.write(org.apache.hadoop.hbase.KeyValue kv, DataOutput out)
    Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
    static long
    KeyValueUtil.write(org.apache.hadoop.hbase.KeyValue kv, DataOutput out)
    Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.
    Method parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    static ByteBuffer
    KeyValueTestUtil.toByteBufferAndRewind(Iterable<? extends org.apache.hadoop.hbase.KeyValue> kvs, boolean includeMemstoreTS)
     
    static String
    KeyValueTestUtil.toStringWithPadding(Collection<? extends org.apache.hadoop.hbase.KeyValue> kvs, boolean includeMeta)
    toString
    static int
    KeyValueUtil.totalLengthWithMvccVersion(Iterable<? extends org.apache.hadoop.hbase.KeyValue> kvs, boolean includeMvccVersion)
     
  • Uses of org.apache.hadoop.hbase.KeyValue in org.apache.hadoop.hbase.mapreduce

    Methods in org.apache.hadoop.hbase.mapreduce that return org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.KeyValue
    CellSerialization.CellDeserializer.deserialize(org.apache.hadoop.hbase.Cell ignore)
     
    org.apache.hadoop.hbase.KeyValue
    ExtendedCellSerialization.ExtendedCellDeserializer.deserialize(org.apache.hadoop.hbase.ExtendedCell ignore)
     
    org.apache.hadoop.hbase.KeyValue
    KeyValueSerialization.KeyValueDeserializer.deserialize(org.apache.hadoop.hbase.KeyValue ignore)
     
    Methods in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.KeyValue
    KeyValueSerialization.KeyValueDeserializer.deserialize(org.apache.hadoop.hbase.KeyValue ignore)
     
    int
    Import.KeyValueWritableComparablePartitioner.getPartition(org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable key, org.apache.hadoop.hbase.KeyValue value, int numPartitions)
    Deprecated.
     
    void
    KeyValueSerialization.KeyValueSerializer.serialize(org.apache.hadoop.hbase.KeyValue kv)
     
    Method parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueDeserializer
    KeyValueSerialization.getDeserializer(Class<org.apache.hadoop.hbase.KeyValue> t)
    Deprecated.
     
    org.apache.hadoop.hbase.mapreduce.KeyValueSerialization.KeyValueSerializer
    KeyValueSerialization.getSerializer(Class<org.apache.hadoop.hbase.KeyValue> c)
    Deprecated.
     
    protected void
    Import.KeyValueReducer.reduce(org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable row, Iterable<org.apache.hadoop.hbase.KeyValue> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.mapreduce.Import.KeyValueWritableComparable,org.apache.hadoop.hbase.KeyValue,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context)
    Deprecated.
     
    protected void
    KeyValueSortReducer.reduce(org.apache.hadoop.hbase.io.ImmutableBytesWritable row, Iterable<org.apache.hadoop.hbase.KeyValue> kvs, org.apache.hadoop.mapreduce.Reducer<org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.KeyValue,org.apache.hadoop.hbase.io.ImmutableBytesWritable,org.apache.hadoop.hbase.KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context)
    Deprecated.
     
    Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type org.apache.hadoop.hbase.KeyValue in in
    Modifier
    Constructor
    Description
     
    KeyValueWritableComparable(org.apache.hadoop.hbase.KeyValue kv)
     
  • Uses of org.apache.hadoop.hbase.KeyValue in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.KeyValue
    StoreScanner.next()
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.KeyValue in in
    Modifier and Type
    Method
    Description
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StoreFileManager.getCandidateFilesForRowKeyBefore(org.apache.hadoop.hbase.KeyValue targetKey)
    Gets initial, full list of candidate store files to check for row-key-before.
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StripeStoreFileManager.getCandidateFilesForRowKeyBefore(org.apache.hadoop.hbase.KeyValue targetKey)
    See StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) for details on this methods.
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate)
    Updates the candidate list for finding row key before.
    Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile>
    StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<org.apache.hadoop.hbase.regionserver.HStoreFile> candidateFiles, org.apache.hadoop.hbase.KeyValue targetKey, org.apache.hadoop.hbase.Cell candidate)
    See StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell) for details on this methods.