Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.replication.regionserver | |
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.util |
Modifier and Type | Class and Description |
---|---|
class |
Append
Performs Append operations on a single row.
|
class |
Delete
Used to perform Delete operations on a single row.
|
class |
Get
Used to perform Get operations on a single row.
|
class |
Increment
Used to perform Increment operations on a single row.
|
class |
Mutation |
class |
Put
Used to perform Put operations for a single row.
|
class |
RegionCoprocessorServiceExec
Represents a coprocessor service method execution against a single region.
|
class |
RowMutations
Performs multiple mutations atomically on a single row.
|
Modifier and Type | Method and Description |
---|---|
Row |
Action.getAction() |
Row |
RetriesExhaustedWithDetailsException.getRow(int i) |
Modifier and Type | Method and Description |
---|---|
List<Row> |
BufferedMutatorImpl.getWriteBuffer()
Deprecated.
Going away when we drop public support for
HTableInterface .
Ó |
List<Row> |
HTable.getWriteBuffer()
Deprecated.
since 0.96. This is an internal buffer that should not be read nor write.
|
Modifier and Type | Method and Description |
---|---|
int |
Mutation.compareTo(Row d) |
int |
Increment.compareTo(Row i) |
int |
Get.compareTo(Row other) |
int |
RegionCoprocessorServiceExec.compareTo(Row o) |
int |
RowMutations.compareTo(Row i) |
Modifier and Type | Method and Description |
---|---|
Object[] |
HTableWrapper.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTableWrapper.batch(List, Object[]) instead. |
Object[] |
Table.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
Table.batch(List, Object[]) instead. |
Object[] |
HTable.batch(List<? extends Row> actions)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTable.batch(List, Object[]) instead. |
void |
HTableWrapper.batch(List<? extends Row> actions,
Object[] results) |
void |
Table.batch(List<? extends Row> actions,
Object[] results)
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations
The ordering of execution of the actions is not defined.
|
void |
HTable.batch(List<? extends Row> actions,
Object[] results)
Method that does a batch call on Deletes, Gets, Puts, Increments, Appends, RowMutations
The ordering of execution of the actions is not defined.
|
void |
HTable.batch(List<? extends Row> actions,
Object[] results,
int rpcTimeout) |
<R> Object[] |
HTableWrapper.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTableWrapper.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<R> Object[] |
Table.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to retrieve the
partially executed results. Use
Table.batchCallback(List, Object[],
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback) instead. |
<R> Object[] |
HTable.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback)
Deprecated.
If any exception is thrown by one of the actions, there is no way to
retrieve the partially executed results. Use
HTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<R> void |
HTableWrapper.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
<R> void |
Table.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback)
Same as
Table.batch(List, Object[]) , but with a callback. |
<R> void |
HTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback)
Same as
Table.batch(List, Object[]) , but with a callback. |
static void |
HTableUtil.bucketRsBatch(HTable htable,
List<Row> rows)
Deprecated.
Processes a List of Rows (Put, Delete) and writes them to an HTable instance in RegionServer buckets via the htable.batch method.
|
static String |
RetriesExhaustedWithDetailsException.getDesc(List<Throwable> exceptions,
List<? extends Row> actions,
List<String> hostnamePort) |
void |
HConnection.processBatch(List<? extends Row> actions,
byte[] tableName,
ExecutorService pool,
Object[] results)
Deprecated.
|
void |
HConnection.processBatch(List<? extends Row> actions,
TableName tableName,
ExecutorService pool,
Object[] results)
Deprecated.
since 0.96 - Use
Table.batch(java.util.List<? extends org.apache.hadoop.hbase.client.Row>, java.lang.Object[]) instead |
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
HTable.processBatchCallback(List<? extends Row> list,
Object[] results,
Batch.Callback<R> callback)
Process a mixed batch of Get, Put and Delete actions.
|
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
Constructor and Description |
---|
Action(Row action,
int originalIndex) |
Action(Row action,
int originalIndex,
int priority) |
Constructor and Description |
---|
RetriesExhaustedWithDetailsException(List<Throwable> exceptions,
List<Row> actions,
List<String> hostnameAndPort) |
Modifier and Type | Method and Description |
---|---|
protected void |
ReplicationSink.batch(TableName tableName,
Collection<List<Row>> allRows)
Do the changes and handle the pool
|
Modifier and Type | Method and Description |
---|---|
Object[] |
RemoteHTable.batch(List<? extends Row> actions) |
void |
RemoteHTable.batch(List<? extends Row> actions,
Object[] results) |
<R> Object[] |
RemoteHTable.batchCallback(List<? extends Row> actions,
Batch.Callback<R> callback) |
<R> void |
RemoteHTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
Modifier and Type | Method and Description |
---|---|
<R> void |
MultiHConnection.processBatchCallback(List<? extends Row> actions,
TableName tableName,
Object[] results,
Batch.Callback<R> callback)
Randomly pick a connection and process the batch of actions for a given table
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.