| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.thrift2.client | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Field and Description | 
|---|---|
| private Batch.Callback<T> | AsyncProcessTask. callback | 
| private Batch.Callback<T> | AsyncProcessTask.Builder. callback | 
| private Batch.Callback<CResult> | AsyncRequestFutureImpl. callback | 
| Modifier and Type | Method and Description | 
|---|---|
| Batch.Callback<T> | AsyncProcessTask. getCallback() | 
| Modifier and Type | Method and Description | 
|---|---|
| <R> void | HTable. batchCallback(List<? extends Row> actions,
             Object[] results,
             Batch.Callback<R> callback) | 
| default <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 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) | 
| default <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  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), all
 the invocations to the same region server will be batched into one call. | 
| <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) | 
| default <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  Servicesubclass for each table
 region spanning the range from thestartKeyrow toendKeyrow (inclusive), and
 invokes the passedBatch.Call.call(T)method
 with eachServiceinstance. | 
| static <R> void | HTable. doBatchWithCallback(List<? extends Row> actions,
                   Object[] results,
                   Batch.Callback<R> callback,
                   ClusterConnection connection,
                   ExecutorService pool,
                   TableName tableName) | 
| static <T> AsyncProcessTask.Builder<T> | AsyncProcessTask. newBuilder(Batch.Callback<T> callback) | 
| <R> void | HTable. processBatchCallback(List<? extends Row> list,
                    Object[] results,
                    Batch.Callback<R> callback)Process a mixed batch of Get, Put and Delete actions. | 
| Constructor and Description | 
|---|
| AsyncProcessTask(ExecutorService pool,
                TableName tableName,
                RowAccess<? extends Row> rows,
                AsyncProcessTask.SubmittedRows size,
                Batch.Callback<T> callback,
                CancellableRegionServerCallable callable,
                boolean needResults,
                int rpcTimeout,
                int operationTimeout,
                Object[] results) | 
| Builder(Batch.Callback<T> callback) | 
| Modifier and Type | Method and Description | 
|---|---|
| <R> void | ThriftTable. 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–2021 The Apache Software Foundation. All rights reserved.