Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
Modifier and Type | Field and Description |
---|---|
private MultiAction<T> |
DelayingRunner.actions |
private MultiAction<Row> |
AsyncProcess.AsyncRequestFutureImpl.SingleServerRequestRunnable.multiAction |
private MultiAction<R> |
MultiServerCallable.multiAction |
Modifier and Type | Method and Description |
---|---|
MultiAction<T> |
DelayingRunner.getActions() |
(package private) MultiAction<R> |
MultiServerCallable.getMulti() |
Modifier and Type | Method and Description |
---|---|
protected MultiServerCallable<Row> |
AsyncProcess.createCallable(ServerName server,
TableName tableName,
MultiAction<Row> multi)
Create a callable.
|
private Collection<? extends Runnable> |
AsyncProcess.AsyncRequestFutureImpl.getNewMultiActionRunnable(ServerName server,
MultiAction<Row> multiAction,
int numAttempt) |
private void |
AsyncProcess.AsyncRequestFutureImpl.receiveGlobalFailure(MultiAction<Row> rsActions,
ServerName server,
int numAttempt,
Throwable t)
Resubmit all the actions from this multiaction after a failure.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.receiveMultiAction(MultiAction<Row> multiAction,
ServerName server,
MultiResponse responses,
int numAttempt)
Called when we receive the result of a server query.
|
Modifier and Type | Method and Description |
---|---|
private static void |
AsyncProcess.addAction(ServerName server,
byte[] regionName,
Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer,
long nonceGroup)
Helper that is used when grouping the actions per region server.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions(int index,
Map<ServerName,MultiAction<Row>> actionsByServer,
List<Action<Row>> unknownReplicaActions)
Add replica actions to action map by server.
|
private void |
AsyncProcess.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain(Action<Row> action,
Map<ServerName,MultiAction<Row>> actionsByServer) |
private void |
AsyncProcess.AsyncRequestFutureImpl.sendMultiAction(Map<ServerName,MultiAction<Row>> actionsByServer,
int numAttempt,
List<Action<Row>> actionsForReplicaThread,
boolean reuseThread)
Send a multi action structure to the servers, after a delay depending on the attempt
number.
|
(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.SingleServerRequestRunnable(MultiAction<Row> multiAction,
int numAttempt,
ServerName server,
Set<MultiServerCallable<Row>> callsInProgress) |
MultiServerCallable(ClusterConnection connection,
TableName tableName,
ServerName location,
RpcControllerFactory rpcFactory,
MultiAction<R> multi) |
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.