| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.mapreduce | Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods. | 
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.security.access | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | KeyValue.KeyOnlyKeyValueA 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  | NoTagsKeyValueAn extension of the KeyValue where the tags length is always 0 | 
| class  | SizeCachedKeyValueThis class is an extension to KeyValue where rowLen and keyLen are cached. | 
| class  | SizeCachedNoTagsKeyValueThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell. | 
| Modifier and Type | Field and Description | 
|---|---|
| static KeyValue | KeyValue. LOWESTKEYLowest possible key. | 
| Modifier and Type | Method and Description | 
|---|---|
| KeyValue | KeyValue. clone()Clones a KeyValue. | 
| static KeyValue | KeyValueUtil. copyToNewKeyValue(Cell cell)copy the cell to create a new keyvalue | 
| static KeyValue | KeyValueUtil. create(DataInput in) | 
| static KeyValue | KeyValue. create(DataInput in) | 
| static KeyValue | KeyValueUtil. create(int length,
      DataInput in)Create a KeyValue reading  lengthfromin | 
| static KeyValue | KeyValue. create(int length,
      DataInput in)Create a KeyValue reading  lengthfromin | 
| 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 | KeyValueUtil. createFirstOnRow(byte[] row)Create a KeyValue that is smaller than all other possible KeyValues
 for the given row. | 
| static 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 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 KeyValue | KeyValueUtil. createFirstOnRow(byte[] row,
                byte[] f,
                byte[] q,
                long ts) | 
| static 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 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 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 KeyValue | KeyValueUtil. createFirstOnRow(byte[] row,
                long ts)Creates a KeyValue that is smaller than all other KeyValues that
 are older than the passed 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 | KeyValueUtil. createKeyValueFromInputStream(InputStream in,
                             boolean withTags)Create a KeyValue reading from the raw InputStream. | 
| static KeyValue | KeyValueUtil. createKeyValueFromKey(byte[] b) | 
| static KeyValue | KeyValueUtil. createKeyValueFromKey(byte[] b,
                     int o,
                     int l) | 
| static KeyValue | KeyValueUtil. createKeyValueFromKey(ByteBuffer bb) | 
| static KeyValue | KeyValueUtil. createLastOnRow(byte[] row)Creates a KeyValue that is last on the specified row id. | 
| static 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 KeyValue | KeyValueUtil. ensureKeyValue(Cell cell)Deprecated. 
 without any replacement. | 
| 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. | 
| static KeyValue | KeyValueUtil. toNewKeyCell(Cell cell)Copies the key to a new KeyValue | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<KeyValue> | KeyValueUtil. ensureKeyValues(List<Cell> cells)Deprecated.  | 
| static List<KeyValue> | KeyValueTestUtil. rewindThenToList(ByteBuffer bb,
                boolean includesMemstoreTS,
                boolean useTags) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | KeyValueUtil. appendToByteBuffer(ByteBuffer bb,
                  KeyValue kv,
                  boolean includeMvccVersion) | 
| 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) | 
| static long | KeyValue. oswrite(KeyValue kv,
       OutputStream out,
       boolean withTags)Deprecated. 
 As of release 2.0.0, this will be removed in HBase 3.0.0.
             Instead use  write(OutputStream, boolean) | 
| 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 | KeyValueUtil. write(KeyValue kv,
     DataOutput out)Write out a KeyValue in the manner in which we used to when KeyValue was a
 Writable. | 
| 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) KeyValue | Mutation. createPutKeyValue(byte[] family,
                 byte[] qualifier,
                 long ts,
                 byte[] value) | 
| (package private) KeyValue | Mutation. createPutKeyValue(byte[] family,
                 byte[] qualifier,
                 long ts,
                 byte[] value,
                 Tag[] tags)Create a KeyValue with this objects row key and the Put identifier. | 
| (package private) KeyValue | Mutation. createPutKeyValue(byte[] family,
                 ByteBuffer qualifier,
                 long ts,
                 ByteBuffer value,
                 Tag[] tags) | 
| Modifier and Type | Field and Description | 
|---|---|
| private KeyValue | Import.KeyValueWritableComparable. kv | 
| Modifier and Type | Method and Description | 
|---|---|
| KeyValue | CellSerialization.CellDeserializer. deserialize(Cell ignore) | 
| KeyValue | KeyValueSerialization.KeyValueDeserializer. deserialize(KeyValue ignore) | 
| Modifier and Type | Method and Description | 
|---|---|
| KeyValue | KeyValueSerialization.KeyValueDeserializer. deserialize(KeyValue ignore) | 
| int | Import.KeyValueWritableComparablePartitioner. getPartition(Import.KeyValueWritableComparable key,
            KeyValue value,
            int numPartitions)Deprecated.  | 
| void | KeyValueSerialization.KeyValueSerializer. serialize(KeyValue kv) | 
| Modifier and Type | Method and Description | 
|---|---|
| KeyValueSerialization.KeyValueDeserializer | KeyValueSerialization. getDeserializer(Class<KeyValue> t)Deprecated.  | 
| KeyValueSerialization.KeyValueSerializer | KeyValueSerialization. getSerializer(Class<KeyValue> c)Deprecated.  | 
| protected void | KeyValueSortReducer. reduce(ImmutableBytesWritable row,
      Iterable<KeyValue> kvs,
      org.apache.hadoop.mapreduce.Reducer.Context context)Deprecated.  | 
| protected void | Import.KeyValueReducer. reduce(Import.KeyValueWritableComparable row,
      Iterable<KeyValue> kvs,
      org.apache.hadoop.mapreduce.Reducer.Context context)Deprecated.  | 
| Constructor and Description | 
|---|
| KeyValueWritableComparable(KeyValue kv) | 
| Modifier and Type | Method and Description | 
|---|---|
| KeyValue | StoreScanner. next() | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | TablePermission. implies(TableName table,
       KeyValue kv,
       Permission.Action action)Checks if this permission grants access to perform the given action on
 the given table and key value. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.