Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.filter |
Provides row-level filters applied to HRegion scan results during calls to
ResultScanner.next() . |
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 | |
org.apache.hadoop.hbase.util.test |
Modifier and Type | Class and Description |
---|---|
static class |
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 |
NoTagsKeyValue
An extension of the KeyValue where the tags length is always 0
|
Modifier and Type | Field and Description |
---|---|
static KeyValue |
KeyValue.LOWESTKEY
Lowest possible key.
|
Modifier and Type | Method and Description |
---|---|
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 |
KeyValueUtil.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 |
KeyValueUtil.createFirstOnRow(byte[] row)
Create a KeyValue that is smaller than all other possible KeyValues
for the given row.
|
static KeyValue |
KeyValue.createFirstOnRow(byte[] row)
Deprecated.
Since 0.99.2. Use
KeyValueUtil.createFirstOnRow(byte []) instead |
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 |
KeyValue.createFirstOnRow(byte[] row,
byte[] family,
byte[] qualifier)
Deprecated.
Since 0.99.2. Use
KeyValueUtil.createFirstOnRow(byte[], byte[], byte[])
instead |
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 |
KeyValue.createFirstOnRow(byte[] row,
int roffset,
int rlength,
byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Deprecated.
Since 0.99.2. Use
KeyValueUtil.createFirstOnRow(byte[], int, int,
byte[], int, int, byte[], int, int) instead |
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.
|
static KeyValue |
KeyValueUtil.createFirstOnRowColTS(Cell kv,
long ts)
Creates the first KV with the row/family/qualifier of this KV and the given
timestamp.
|
static KeyValue |
KeyValueUtil.createFirstOnRowColTS(KeyValue kv,
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 |
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.createLastOnRow(Cell kv)
Creates a keyValue for the specified keyvalue larger than or equal to all other possible
KeyValues that have the same row, family, qualifer.
|
static KeyValue |
KeyValueUtil.createLastOnRowCol(Cell kv)
Similar to
KeyValueUtil.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)
Deprecated.
without any replacement.
|
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.
|
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) |
int |
KeyValue.RowOnlyComparator.compare(KeyValue left,
KeyValue right) |
static KeyValue |
KeyValueUtil.createFirstOnRowColTS(KeyValue kv,
long ts)
Creates the first KV with the row/family/qualifier of this KV and the
given timestamp.
|
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)
Deprecated.
use
oswrite(KeyValue, OutputStream, boolean) instead |
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.
|
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 |
---|---|
KeyValue |
Result.getColumnLatest(byte[] family,
byte[] qualifier)
Deprecated.
Use
Result.getColumnLatestCell(byte[], byte[]) instead. |
KeyValue |
Result.getColumnLatest(byte[] family,
int foffset,
int flength,
byte[] qualifier,
int qoffset,
int qlength)
Deprecated.
|
KeyValue[] |
Result.raw()
Deprecated.
as of 0.96, use
Result.rawCells() |
Modifier and Type | Method and Description |
---|---|
List<KeyValue> |
Result.getColumn(byte[] family,
byte[] qualifier)
Deprecated.
Use
Result.getColumnCells(byte[], byte[]) instead. |
NavigableMap<byte[],List<KeyValue>> |
Mutation.getFamilyMap()
Deprecated.
use
Mutation.getFamilyCellMap() instead. |
List<KeyValue> |
Result.list()
Deprecated.
as of 0.96, use
Result.listCells() |
Modifier and Type | Method and Description |
---|---|
Put |
Put.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
|
Mutation |
Mutation.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
use
Mutation.setFamilyCellMap(NavigableMap) instead. |
Increment |
Increment.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
|
Delete |
Delete.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
|
Append |
Append.setFamilyMap(NavigableMap<byte[],List<KeyValue>> map)
Deprecated.
|
Constructor and Description |
---|
Result(KeyValue[] cells)
Deprecated.
Use
Result.create(List) instead. |
Constructor and Description |
---|
Result(List<KeyValue> kvs)
Deprecated.
Use
Result.create(List) instead. |
Modifier and Type | Method and Description |
---|---|
KeyValue |
FilterWrapper.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterBase.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterWrapper.transform(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.transform(KeyValue v)
Deprecated.
|
KeyValue |
FilterBase.transform(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.transform(KeyValue currentKV)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
FilterWrapper.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterBase.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.getNextKeyHint(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterWrapper.transform(KeyValue currentKV)
Deprecated.
|
KeyValue |
FilterList.transform(KeyValue v)
Deprecated.
|
KeyValue |
FilterBase.transform(KeyValue currentKV)
Deprecated.
|
abstract KeyValue |
Filter.transform(KeyValue currentKV)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordWriter<ImmutableBytesWritable,KeyValue> |
HFileOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
KeyValue |
KeyValueSerialization.KeyValueDeserializer.deserialize(KeyValue ignore) |
void |
KeyValueSerialization.KeyValueSerializer.serialize(KeyValue kv) |
Modifier and Type | Method and Description |
---|---|
KeyValueSerialization.KeyValueDeserializer |
KeyValueSerialization.getDeserializer(Class<KeyValue> t) |
KeyValueSerialization.KeyValueSerializer |
KeyValueSerialization.getSerializer(Class<KeyValue> c) |
protected void |
KeyValueSortReducer.reduce(ImmutableBytesWritable row,
Iterable<KeyValue> kvs,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Modifier and Type | Method and Description |
---|---|
KeyValue |
StoreScanner.next() |
Modifier and Type | Method and Description |
---|---|
protected long |
HStore.delete(KeyValue kv)
Adds a value to the memstore
|
Iterator<StoreFile> |
StripeStoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue)
for details on this methods. |
Iterator<StoreFile> |
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue targetKey)
Gets initial, full list of candidate store files to check for row-key-before.
|
Iterator<StoreFile> |
StripeStoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
See
StoreFileManager.getCandidateFilesForRowKeyBefore(KeyValue) and
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator, KeyValue, Cell)
for details on this methods. |
Iterator<StoreFile> |
StoreFileManager.updateCandidateFilesForRowKeyBefore(Iterator<StoreFile> candidateFiles,
KeyValue targetKey,
Cell candidate)
Updates the candidate list for finding row key before.
|
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.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
static ByteBuffer |
RedundantKVGenerator.convertKvToByteBuffer(List<KeyValue> keyValues,
boolean includesMemstoreTS)
Convert list of KeyValues to byte buffer.
|
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.