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

Packages that use KeyValue
org.apache.hadoop.hbase   
org.apache.hadoop.hbase.io.encoding   
org.apache.hadoop.hbase.util.test   
 

Uses of KeyValue in org.apache.hadoop.hbase
 

Subclasses of KeyValue in org.apache.hadoop.hbase
 class NoTagsKeyValue
          An extension of the KeyValue where the tags length is always 0
 

Fields in org.apache.hadoop.hbase declared as KeyValue
static KeyValue KeyValue.LOWESTKEY
          Lowest possible key.
 

Methods in org.apache.hadoop.hbase that return KeyValue
 KeyValue KeyValue.clone()
          Clones a KeyValue.
static KeyValue KeyValue.cloneAndAddTags(Cell c, List<Tag> newTags)
          Create a new KeyValue by copying existing cell and adding new tags
static KeyValue KeyValueUtil.copyToNewKeyValue(Cell cell)
          copy key only
static KeyValue KeyValue.create(DataInput in)
           
static KeyValue KeyValue.create(int length, DataInput in)
          Create a KeyValue reading length from in
static KeyValue KeyValueTestUtil.create(String row, String family, String qualifier, long timestamp, KeyValue.Type type, String value)
           
static KeyValue KeyValueTestUtil.create(String row, String family, String qualifier, long timestamp, String value)
           
static KeyValue KeyValue.createFirstDeleteFamilyOnRow(byte[] row, byte[] family)
          Create a Delete Family KeyValue for the specified row and family that would be smaller than all other possible Delete Family KeyValues that have the same row and family.
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 KeyValue.createFirstOnRow(byte[] row)
          Create a KeyValue that is smaller than all other possible KeyValues for the given row.
static KeyValue KeyValue.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 KeyValue KeyValue.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 KeyValue KeyValue.createFirstOnRow(byte[] row, byte[] f, byte[] q, long ts)
           
static KeyValue KeyValue.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 KeyValue KeyValue.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 KeyValue KeyValue.createFirstOnRow(byte[] row, int roffset, short rlength)
          Create a KeyValue that is smaller than all other possible KeyValues for the given row.
static KeyValue KeyValue.createFirstOnRow(byte[] row, long ts)
          Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.
 KeyValue KeyValue.createFirstOnRowColTS(long ts)
          Creates the first KV with the row/family/qualifier of this KV and the given timestamp.
 KeyValue KeyValue.createKeyOnly(boolean lenAsVal)
          Creates a new KeyValue that only contains the key portion (the value is set to be null).
static KeyValue KeyValue.createKeyValueFromKey(byte[] b)
           
static KeyValue KeyValue.createKeyValueFromKey(byte[] b, int o, int l)
           
static KeyValue KeyValue.createKeyValueFromKey(ByteBuffer bb)
           
static KeyValue KeyValue.createLastOnRow(byte[] row)
          Creates a KeyValue that is last on the specified row id.
static KeyValue KeyValue.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.
 KeyValue KeyValue.createLastOnRowCol()
          Similar to 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)
           
static KeyValue KeyValue.iscreate(InputStream in)
          Create a KeyValue reading from the raw InputStream.
static 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 KeyValue KeyValueUtil.previousKey(KeyValue in)
          Decrement the timestamp.
 KeyValue KeyValue.shallowCopy()
          Creates a shallow copy of this KeyValue, reusing the data byte buffer.
 

Methods in org.apache.hadoop.hbase that return types with arguments of type KeyValue
static List<KeyValue> KeyValueUtil.ensureKeyValues(List<Cell> cells)
           
static List<KeyValue> KeyValueTestUtil.rewindThenToList(ByteBuffer bb, boolean includesMemstoreTS, boolean useTags)
           
 

Methods in org.apache.hadoop.hbase with parameters of type KeyValue
static void KeyValueUtil.appendToByteBuffer(ByteBuffer bb, KeyValue kv, boolean includeMvccVersion)
           
 int KeyValue.RowOnlyComparator.compare(KeyValue left, KeyValue right)
           
 int KeyValue.KVComparator.compareRows(KeyValue left, KeyValue right)
           
 int KeyValue.KVComparator.compareTimestamps(KeyValue left, KeyValue right)
           
protected static String KeyValueTestUtil.getFamilyString(KeyValue kv)
           
protected static String KeyValueTestUtil.getQualifierString(KeyValue kv)
           
protected static String KeyValueTestUtil.getRowString(KeyValue kv)
           
protected static String KeyValueTestUtil.getTimestampString(KeyValue kv)
           
protected static String KeyValueTestUtil.getTypeString(KeyValue kv)
           
protected static String KeyValueTestUtil.getValueString(KeyValue kv)
           
static int KeyValueUtil.lengthWithMvccVersion(KeyValue kv, boolean includeMvccVersion)
           
 boolean KeyValue.matchingQualifier(KeyValue other)
           
 boolean KeyValue.matchingRow(KeyValue other)
           
 boolean KeyValue.KVComparator.matchingRowColumn(KeyValue left, KeyValue right)
          Compares the row and column of two keyvalues for equality
 boolean KeyValue.KVComparator.matchingRows(KeyValue left, KeyValue right)
          Compares the row of two keyvalues for equality
static long KeyValue.oswrite(KeyValue kv, OutputStream out)
          Deprecated. 
static long KeyValue.oswrite(KeyValue kv, OutputStream out, boolean withTags)
          Write out a KeyValue in the manner in which we used to when KeyValue was a Writable but do not require a DataOutput, just take plain OutputStream Named oswrite so does not clash with write(KeyValue, DataOutput)
static KeyValue KeyValueUtil.previousKey(KeyValue in)
          Decrement the timestamp.
protected static String KeyValueTestUtil.toStringWithPadding(KeyValue kv, int maxRowLength, int maxFamilyLength, int maxQualifierLength, int maxTimestampLength, boolean includeMeta)
           
static long KeyValue.write(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 KeyValue
static ByteBuffer KeyValueTestUtil.toByteBufferAndRewind(Iterable<? extends KeyValue> kvs, boolean includeMemstoreTS)
           
static String KeyValueTestUtil.toStringWithPadding(Collection<? extends KeyValue> kvs, boolean includeMeta)
          toString
static int KeyValueUtil.totalLengthWithMvccVersion(Iterable<? extends KeyValue> kvs, boolean includeMvccVersion)
           
 

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

Methods in org.apache.hadoop.hbase.io.encoding that return KeyValue
 KeyValue DataBlockEncoder.EncodedSeeker.getKeyValue()
           
 

Uses of KeyValue in org.apache.hadoop.hbase.util.test
 

Methods in org.apache.hadoop.hbase.util.test that return types with arguments of type KeyValue
 List<KeyValue> RedundantKVGenerator.generateTestKeyValues(int howMany)
          Generate test data useful to test encoders.
 List<KeyValue> RedundantKVGenerator.generateTestKeyValues(int howMany, boolean useTags)
          Generate test data useful to test encoders.
 

Method parameters in org.apache.hadoop.hbase.util.test with type arguments of type KeyValue
static ByteBuffer RedundantKVGenerator.convertKvToByteBuffer(List<KeyValue> keyValues, boolean includesMemstoreTS)
          Convert list of KeyValues to byte buffer.
 



Copyright © 2015 The Apache Software Foundation. All Rights Reserved.