Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.rest.client | |
org.apache.hadoop.hbase.util |
Modifier and Type | Field and Description |
---|---|
private Batch.Callback<CResult> |
AsyncProcess.AsyncRequestFutureImpl.callback |
Modifier and Type | Method and Description |
---|---|
<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> 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[] |
HTablePool.PooledHTable.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
HTablePool.PooledHTable.batchCallback(List, Object[], org.apache.hadoop.hbase.client.coprocessor.Batch.Callback)
instead. |
<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> void |
HTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback)
Same as
Table.batch(List, Object[]) , but with a 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 |
HTablePool.PooledHTable.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
<R> void |
HTableWrapper.batchCallback(List<? extends Row> actions,
Object[] results,
Batch.Callback<R> callback) |
<R extends com.google.protobuf.Message> |
HTable.batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback)
Creates an instance of the given
Service subclass for each table
region spanning the range from the startKey row to endKey row (inclusive), all
the invocations to the same region server will be batched into one call. |
<R extends com.google.protobuf.Message> |
Table.batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback)
Creates an instance of the given
Service subclass for each table
region spanning the range from the startKey row to endKey row (inclusive), all
the invocations to the same region server will be batched into one call. |
<R extends com.google.protobuf.Message> |
HTablePool.PooledHTable.batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback) |
<R extends com.google.protobuf.Message> |
HTableWrapper.batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor methodDescriptor,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback) |
<T extends com.google.protobuf.Service,R> |
HTable.coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
Batch.Callback<R> callback)
Creates an instance of the given
Service subclass for each table
region spanning the range from the startKey row to endKey row (inclusive), and
invokes the passed Batch.Call.call(T) method
with each Service instance. |
<T extends com.google.protobuf.Service,R> |
Table.coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
Batch.Callback<R> callback)
Creates an instance of the given
Service subclass for each table
region spanning the range from the startKey row to endKey row (inclusive), and
invokes the passed Batch.Call.call(T) method
with each Service instance. |
<T extends com.google.protobuf.Service,R> |
HTablePool.PooledHTable.coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
Batch.Callback<R> callback) |
<T extends com.google.protobuf.Service,R> |
HTableWrapper.coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
Batch.Callback<R> callback) |
protected <CResult> AsyncProcess.AsyncRequestFutureImpl<CResult> |
AsyncProcess.createAsyncRequestFuture(TableName tableName,
List<Action<Row>> actions,
long nonceGroup,
ExecutorService pool,
Batch.Callback<CResult> callback,
Object[] results,
boolean needResults) |
<R> void |
ConnectionManager.HConnectionImplementation.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
ConnectionAdapter.processBatchCallback(List<? extends Row> list,
byte[] tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<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 |
ConnectionManager.HConnectionImplementation.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
<R> void |
ConnectionAdapter.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
Deprecated.
|
<R> void |
HConnection.processBatchCallback(List<? extends Row> list,
TableName tableName,
ExecutorService pool,
Object[] results,
Batch.Callback<R> callback)
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submit(ExecutorService pool,
TableName tableName,
List<? extends Row> rows,
boolean atLeastOne,
Batch.Callback<CResult> callback,
boolean needResults)
Extract from the rows list what we can submit.
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submit(TableName tableName,
List<? extends Row> rows,
boolean atLeastOne,
Batch.Callback<CResult> callback,
boolean needResults)
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitAll(ExecutorService pool,
TableName tableName,
List<? extends Row> rows,
Batch.Callback<CResult> callback,
Object[] results)
Submit immediately the list of rows, whatever the server status.
|
<CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitAll(TableName tableName,
List<? extends Row> rows,
Batch.Callback<CResult> callback,
Object[] results)
|
(package private) <CResult> AsyncProcess.AsyncRequestFuture |
AsyncProcess.submitMultiActions(TableName tableName,
List<Action<Row>> retainedActions,
long nonceGroup,
Batch.Callback<CResult> callback,
Object[] results,
boolean needResults,
List<Exception> locationErrors,
List<Integer> locationErrorRows,
Map<ServerName,MultiAction<Row>> actionsByServer,
ExecutorService pool) |
Constructor and Description |
---|
AsyncProcess.AsyncRequestFutureImpl(TableName tableName,
List<Action<Row>> actions,
long nonceGroup,
ExecutorService pool,
boolean needResults,
Object[] results,
Batch.Callback<CResult> callback) |
Modifier and Type | Method and Description |
---|---|
<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) |
<R extends com.google.protobuf.Message> |
RemoteHTable.batchCoprocessorService(com.google.protobuf.Descriptors.MethodDescriptor method,
com.google.protobuf.Message request,
byte[] startKey,
byte[] endKey,
R responsePrototype,
Batch.Callback<R> callback) |
<T extends com.google.protobuf.Service,R> |
RemoteHTable.coprocessorService(Class<T> service,
byte[] startKey,
byte[] endKey,
Batch.Call<T,R> callable,
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.