Uses of Interface
org.apache.hadoop.hbase.client.coprocessor.Batch.Callback
Package
Description
Provides HBase Client
-
Uses of Batch.Callback in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate Batch.Callback<T>
AsyncProcessTask.Builder.callback
private final Batch.Callback<T>
AsyncProcessTask.callback
private final Batch.Callback<CResult>
AsyncRequestFutureImpl.callback
Modifier and TypeMethodDescription<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 asTable.batch(List, Object[])
, but with a callback.<R extends com.google.protobuf.Message>
voidHTable.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>
voidTable.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 givenService
subclass for each table region spanning the range from thestartKey
row toendKey
row (inclusive), all the invocations to the same region server will be batched into one call.<T extends com.google.protobuf.Service,
R>
voidHTable.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>
voidTable.coprocessorService
(Class<T> service, byte[] startKey, byte[] endKey, Batch.Call<T, R> callable, Batch.Callback<R> callback) Creates an instance of the givenService
subclass for each table region spanning the range from thestartKey
row toendKey
row (inclusive), and invokes the passedBatch.Call.call(T)
method with eachService
instance.static <R> void
HTable.doBatchWithCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback, ClusterConnection connection, ExecutorService pool, TableName tableName, Map<String, byte[]> requestAttributes) 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.ModifierConstructorDescription(package private)
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, Map<String, byte[]> requestAttributes) private
Builder
(Batch.Callback<T> callback) -
Uses of Batch.Callback in org.apache.hadoop.hbase.thrift2.client
Modifier and TypeMethodDescription<R> void
ThriftTable.batchCallback
(List<? extends Row> actions, Object[] results, Batch.Callback<R> callback) -
Uses of Batch.Callback in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescription<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