Uses of Class
org.apache.hadoop.hbase.KeyValue
Packages that use KeyValue
Package
Description
Provides HBase Client
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
- 
Uses of KeyValue in org.apache.hadoop.hbaseSubclasses of KeyValue in org.apache.hadoop.hbaseModifier and TypeClassDescriptionstatic classA 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.classAn extension of the KeyValue where the tags length is always 0classThis class is an extension to KeyValue where rowLen and keyLen are cached.classThis class is an extension to ContentSizeCachedKeyValue where there are no tags in Cell.Fields in org.apache.hadoop.hbase declared as KeyValueMethods in org.apache.hadoop.hbase that return KeyValueModifier and TypeMethodDescriptionKeyValue.clone()Clones a KeyValue.static KeyValueKeyValueUtil.copyToNewKeyValue(Cell cell) copy the cell to create a new keyvaluestatic KeyValueCreate a KeyValue readinglengthfrominstatic KeyValueCreate a KeyValue reading frominstatic KeyValuestatic KeyValueKeyValueTestUtil.create(String row, String family, String qualifier, long timestamp, KeyValue.Type type, String value) static KeyValueCreate a KeyValue readinglengthfrominstatic KeyValueWhere to read bytes from.static KeyValueKeyValueUtil.createFirstOnRow(byte[] row) Create a KeyValue that is smaller than all other possible KeyValues for the given row.static KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.createFirstOnRow(byte[] row, int roffset, short rlength) Create a KeyValue that is smaller than all other possible KeyValues for the given row.static KeyValueKeyValueUtil.createFirstOnRow(byte[] row, long ts) Creates a KeyValue that is smaller than all other KeyValues that are older than the passed timestamp.KeyValue.createKeyOnly(boolean lenAsVal) Creates a new KeyValue that only contains the key portion (the value is set to be null).static KeyValueKeyValueUtil.createKeyValueFromInputStream(InputStream in, boolean withTags) Create a KeyValue reading from the raw InputStream.static KeyValueKeyValueUtil.createKeyValueFromKey(byte[] b) Returns a KeyValue made of a byte array that holds the key-only part.static KeyValueKeyValueUtil.createKeyValueFromKey(byte[] b, int o, int l) Return a KeyValue made of a byte array that holds the key-only part.static KeyValueKeyValueUtil.createKeyValueFromKey(ByteBuffer bb) Return a KeyValue made of a byte buffer that holds the key-only part.static KeyValueKeyValueUtil.createLastOnRow(byte[] row) Creates a KeyValue that is last on the specified row id.static KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.ensureKeyValue(Cell cell) Deprecated.without any replacement.static KeyValueKeyValueUtil.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 KeyValueKeyValueUtil.previousKey(KeyValue in) Decrement the timestamp.KeyValue.shallowCopy()Creates a shallow copy of this KeyValue, reusing the data byte buffer.static KeyValueKeyValueUtil.toNewKeyCell(Cell cell) Copies the key to a new KeyValueMethods in org.apache.hadoop.hbase that return types with arguments of type KeyValueModifier and TypeMethodDescriptionKeyValueUtil.ensureKeyValues(List<Cell> cells) Deprecated.KeyValueTestUtil.rewindThenToList(ByteBuffer bb, boolean includesMemstoreTS, boolean useTags) Methods in org.apache.hadoop.hbase with parameters of type KeyValueModifier and TypeMethodDescriptionstatic voidKeyValueUtil.appendToByteBuffer(ByteBuffer bb, KeyValue kv, boolean includeMvccVersion) protected intCellComparatorImpl.compareFamilies(KeyValue left, int leftFamilyPosition, int leftFamilyLength, ByteBufferKeyValue right, int rightFamilyPosition, int rightFamilyLength) This method will be overridden when we compare cells inner store to bypass family comparing.protected intCellComparatorImpl.compareFamilies(KeyValue left, int leftFamilyPosition, int leftFamilyLength, KeyValue right, int rightFamilyPosition, int rightFamilyLength) This method will be overridden when we compare cells inner store to bypass family comparing.protected intInnerStoreCellComparator.compareFamilies(KeyValue left, int leftFamilyPosition, int leftFamilyLength, ByteBufferKeyValue right, int rightFamilyPosition, int rightFamilyLength) protected intInnerStoreCellComparator.compareFamilies(KeyValue left, int leftFamilyPosition, int leftFamilyLength, KeyValue right, int rightFamilyPosition, int rightFamilyLength) private intCellComparatorImpl.compareKeyValues(KeyValue left, KeyValue right) private intCellComparatorImpl.compareKVVsBBKV(KeyValue left, ByteBufferKeyValue right) (package private) static intCellComparatorImpl.compareQualifiers(ByteBufferKeyValue left, KeyValue right) (package private) static intCellComparatorImpl.compareQualifiers(KeyValue left, ByteBufferKeyValue right) (package private) static intCellComparatorImpl.compareQualifiers(KeyValue left, KeyValue right) protected static StringKeyValueTestUtil.getFamilyString(KeyValue kv) protected static StringKeyValueTestUtil.getQualifierString(KeyValue kv) protected static StringKeyValueTestUtil.getRowString(KeyValue kv) protected static StringKeyValueTestUtil.getTimestampString(KeyValue kv) protected static StringKeyValueTestUtil.getTypeString(KeyValue kv) protected static StringKeyValueTestUtil.getValueString(KeyValue kv) static intKeyValueUtil.lengthWithMvccVersion(KeyValue kv, boolean includeMvccVersion) static longKeyValue.oswrite(KeyValue kv, OutputStream out, boolean withTags) Deprecated.As of release 2.0.0, this will be removed in HBase 3.0.0.static KeyValueKeyValueUtil.previousKey(KeyValue in) Decrement the timestamp.protected static StringKeyValueTestUtil.toStringWithPadding(KeyValue kv, int maxRowLength, int maxFamilyLength, int maxQualifierLength, int maxTimestampLength, boolean includeMeta) static longKeyValue.write(KeyValue kv, DataOutput out) Write out a KeyValue in the manner in which we used to when KeyValue was a Writable.static longKeyValueUtil.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 KeyValueModifier and TypeMethodDescriptionstatic ByteBufferKeyValueTestUtil.toByteBufferAndRewind(Iterable<? extends KeyValue> kvs, boolean includeMemstoreTS) static StringKeyValueTestUtil.toStringWithPadding(Collection<? extends KeyValue> kvs, boolean includeMeta) toStringstatic intKeyValueUtil.totalLengthWithMvccVersion(Iterable<? extends KeyValue> kvs, boolean includeMvccVersion) 
- 
Uses of KeyValue in org.apache.hadoop.hbase.clientMethods in org.apache.hadoop.hbase.client that return KeyValueModifier and TypeMethodDescription(package private) KeyValueMutation.createPutKeyValue(byte[] family, byte[] qualifier, long ts, byte[] value) Create a KeyValue with this objects row key and the Put identifier.(package private) KeyValueMutation.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) KeyValueMutation.createPutKeyValue(byte[] family, ByteBuffer qualifier, long ts, ByteBuffer value, Tag[] tags) Create a KeyValue with this objects row key and the Put identifier.
- 
Uses of KeyValue in org.apache.hadoop.hbase.mapreduceFields in org.apache.hadoop.hbase.mapreduce declared as KeyValueMethods in org.apache.hadoop.hbase.mapreduce that return KeyValueModifier and TypeMethodDescriptionCellSerialization.CellDeserializer.deserialize(Cell ignore) ExtendedCellSerialization.ExtendedCellDeserializer.deserialize(ExtendedCell ignore) KeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) Methods in org.apache.hadoop.hbase.mapreduce with parameters of type KeyValueModifier and TypeMethodDescriptionKeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) intImport.KeyValueWritableComparablePartitioner.getPartition(Import.KeyValueWritableComparable key, KeyValue value, int numPartitions) Deprecated.voidMethod parameters in org.apache.hadoop.hbase.mapreduce with type arguments of type KeyValueModifier and TypeMethodDescriptionKeyValueSerialization.getDeserializer(Class<KeyValue> t) Deprecated.KeyValueSerialization.getSerializer(Class<KeyValue> c) Deprecated.protected voidImport.KeyValueReducer.reduce(Import.KeyValueWritableComparable row, Iterable<KeyValue> kvs, org.apache.hadoop.mapreduce.Reducer<Import.KeyValueWritableComparable, KeyValue, ImmutableBytesWritable, KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context) Deprecated.protected voidKeyValueSortReducer.reduce(ImmutableBytesWritable row, Iterable<KeyValue> kvs, org.apache.hadoop.mapreduce.Reducer<ImmutableBytesWritable, KeyValue, ImmutableBytesWritable, KeyValue>.org.apache.hadoop.mapreduce.Reducer.Context context) Deprecated.Constructors in org.apache.hadoop.hbase.mapreduce with parameters of type KeyValue
- 
Uses of KeyValue in org.apache.hadoop.hbase.regionserverMethods in org.apache.hadoop.hbase.regionserver that return KeyValueMethods in org.apache.hadoop.hbase.regionserver with parameters of type KeyValueModifier and TypeMethodDescriptionfinal Iterator<HStoreFile>DefaultStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey) StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey) Gets initial, full list of candidate store files to check for row-key-before.StripeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)for details on this methods.DefaultStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) Updates the candidate list for finding row key before.StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<HStoreFile> candidateFiles, KeyValue targetKey, Cell candidate) SeeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)andStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)for details on this methods.
- 
Uses of KeyValue in org.apache.hadoop.hbase.security.accessMethods in org.apache.hadoop.hbase.security.access with parameters of type KeyValueModifier and TypeMethodDescriptionbooleanTablePermission.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.