Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.mapred |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.mapreduce |
Provides HBase MapReduce
Input/OutputFormats, a table indexing MapReduce job, and utility methods.
|
org.apache.hadoop.hbase.rest.client |
Modifier and Type | Method and Description |
---|---|
Put |
Put.add(byte[] family,
byte[] qualifier,
byte[] value)
Deprecated.
Since 1.0.0. Use
addColumn(byte[], byte[], byte[]) |
Put |
Put.add(byte[] family,
byte[] qualifier,
long ts,
byte[] value)
Deprecated.
Since 1.0.0. Use
addColumn(byte[], byte[], long, byte[]) |
Put |
Put.add(byte[] family,
ByteBuffer qualifier,
long ts,
ByteBuffer value)
Deprecated.
Since 1.0.0. Use
addColumn(byte[], ByteBuffer, long, ByteBuffer) |
Put |
Put.add(Cell kv)
Add the specified KeyValue to this Put operation.
|
Put |
Put.addColumn(byte[] family,
byte[] qualifier,
byte[] value)
Add the specified column and value to this Put operation.
|
Put |
Put.addColumn(byte[] family,
byte[] qualifier,
long ts,
byte[] value)
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
|
Put |
Put.addColumn(byte[] family,
ByteBuffer qualifier,
long ts,
ByteBuffer value)
Add the specified column and value, with the specified timestamp as
its version to this Put operation.
|
Put |
Put.addImmutable(byte[] family,
byte[] qualifier,
byte[] value)
|
Put |
Put.addImmutable(byte[] family,
byte[] qualifier,
byte[] value,
org.apache.hadoop.hbase.Tag[] tag)
This expects that the underlying arrays won't change.
|
Put |
Put.addImmutable(byte[] family,
byte[] qualifier,
long ts,
byte[] value)
|
Put |
Put.addImmutable(byte[] family,
byte[] qualifier,
long ts,
byte[] value,
org.apache.hadoop.hbase.Tag[] tag)
This expects that the underlying arrays won't change.
|
Put |
Put.addImmutable(byte[] family,
ByteBuffer qualifier,
long ts,
ByteBuffer value)
|
Put |
Put.addImmutable(byte[] family,
ByteBuffer qualifier,
long ts,
ByteBuffer value,
org.apache.hadoop.hbase.Tag[] tag)
This expects that the underlying arrays won't change.
|
Put |
Put.setACL(Map<String,org.apache.hadoop.hbase.security.access.Permission> perms) |
Put |
Put.setACL(String user,
org.apache.hadoop.hbase.security.access.Permission perms) |
Put |
Put.setAttribute(String name,
byte[] value) |
Put |
Put.setCellVisibility(org.apache.hadoop.hbase.security.visibility.CellVisibility expression) |
Put |
Put.setClusterIds(List<UUID> clusterIds) |
Put |
Put.setDurability(Durability d) |
Put |
Put.setFamilyCellMap(NavigableMap<byte[],List<Cell>> map) |
Put |
Put.setFamilyMap(NavigableMap<byte[],List<org.apache.hadoop.hbase.KeyValue>> map)
Deprecated.
|
Put |
Put.setId(String id) |
Put |
Put.setTTL(long ttl) |
Put |
Put.setWriteToWAL(boolean write)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
List<Put> |
HTableMultiplexer.put(byte[] tableName,
List<Put> puts)
Deprecated.
|
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
Modifier and Type | Method and Description |
---|---|
void |
RowMutations.add(Put p)
Add a
Put operation to the list of mutations |
boolean |
Table.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put)
Atomically checks if a row/family/qualifier value matches the expected
value.
|
boolean |
Table.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
Put put)
Atomically checks if a row/family/qualifier value matches the expected
value.
|
boolean |
HTableMultiplexer.put(byte[] tableName,
Put put)
Deprecated.
|
boolean |
HTableMultiplexer.put(byte[] tableName,
Put put,
int retry)
Deprecated.
|
void |
Table.put(Put put)
Puts some data in the table.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put)
The put request will be buffered by its corresponding buffer queue.
|
boolean |
HTableMultiplexer.put(TableName tableName,
Put put,
int retry)
The put request will be buffered by its corresponding buffer queue.
|
Modifier and Type | Method and Description |
---|---|
List<Put> |
HTableMultiplexer.put(byte[] tableName,
List<Put> puts)
Deprecated.
|
void |
Table.put(List<Put> puts)
Puts some data in the table, in batch.
|
List<Put> |
HTableMultiplexer.put(TableName tableName,
List<Put> puts)
The puts request will be buffered by their corresponding buffer queue.
|
Constructor and Description |
---|
Put(Put putToCopy)
Copy constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
IdentityTableReduce.reduce(ImmutableBytesWritable key,
Iterator<Put> values,
org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Put> output,
org.apache.hadoop.mapred.Reporter reporter)
No aggregation, output pairs of (key, record)
|
void |
IdentityTableReduce.reduce(ImmutableBytesWritable key,
Iterator<Put> values,
org.apache.hadoop.mapred.OutputCollector<ImmutableBytesWritable,Put> output,
org.apache.hadoop.mapred.Reporter reporter)
No aggregation, output pairs of (key, record)
|
Modifier and Type | Method and Description |
---|---|
protected void |
TsvImporterMapper.populatePut(byte[] lineBytes,
org.apache.hadoop.hbase.mapreduce.ImportTsv.TsvParser.ParsedLine parsed,
Put put,
int i) |
Modifier and Type | Method and Description |
---|---|
protected void |
PutSortReducer.reduce(ImmutableBytesWritable row,
Iterable<Put> puts,
org.apache.hadoop.mapreduce.Reducer.Context context) |
protected void |
PutCombiner.reduce(K row,
Iterable<Put> vals,
org.apache.hadoop.mapreduce.Reducer.Context context) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.hadoop.hbase.rest.model.CellSetModel |
RemoteHTable.buildModelFromPut(Put put) |
boolean |
RemoteHTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
byte[] value,
Put put) |
boolean |
RemoteHTable.checkAndPut(byte[] row,
byte[] family,
byte[] qualifier,
CompareFilter.CompareOp compareOp,
byte[] value,
Put put) |
void |
RemoteHTable.put(Put put) |
Modifier and Type | Method and Description |
---|---|
void |
RemoteHTable.put(List<Put> puts) |
Copyright © 2007–2016 The Apache Software Foundation. All rights reserved.