Uses of Class
org.apache.hadoop.hbase.client.MultiAction
-
Uses of MultiAction in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate MultiAction
DelayingRunner.actions
private final MultiAction
AsyncRequestFutureImpl.SingleServerRequestRunnable.multiAction
private MultiAction
MultiServerCallable.multiAction
Modifier and TypeMethodDescriptionDelayingRunner.getActions()
(package private) MultiAction
MultiServerCallable.getMulti()
Modifier and TypeMethodDescriptionprivate MultiServerCallable
AsyncRequestFutureImpl.createCallable
(ServerName server, TableName tableName, MultiAction multi) Create a callable.(package private) AsyncRequestFutureImpl<CResult>.SingleServerRequestRunnable
AsyncRequestFutureImpl.createSingleServerRequest
(MultiAction multiAction, int numAttempt, ServerName server, Set<CancellableRegionServerCallable> callsInProgress) private void
AsyncRequestFutureImpl.failAll
(MultiAction actions, ServerName server, int numAttempt, Throwable throwable) Fail all the actions from this multiaction after an OperationTimeoutExceededExceptionprivate Collection<? extends Runnable>
AsyncRequestFutureImpl.getNewMultiActionRunnable
(ServerName server, MultiAction multiAction, int numAttempt) private void
AsyncRequestFutureImpl.receiveGlobalFailure
(MultiAction rsActions, ServerName server, int numAttempt, Throwable t, boolean clearServerCache) Resubmit all the actions from this multiaction after a failure.private void
AsyncRequestFutureImpl.receiveMultiAction
(MultiAction multiAction, ServerName server, MultiResponse responses, int numAttempt) Called when we receive the result of a server query.void
MultiServerCallable.reset
(ServerName location, MultiAction multiAction) Modifier and TypeMethodDescription(package private) static void
AsyncProcess.addAction
(ServerName server, byte[] regionName, Action action, Map<ServerName, MultiAction> actionsByServer, long nonceGroup) Helper that is used when grouping the actions per region server.private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions
(int index, Map<ServerName, MultiAction> actionsByServer, List<Action> unknownReplicaActions) Add replica actions to action map by server.private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain
(Action action, Map<ServerName, MultiAction> actionsByServer) (package private) void
AsyncRequestFutureImpl.sendMultiAction
(Map<ServerName, MultiAction> actionsByServer, int numAttempt, List<Action> actionsForReplicaThread, boolean reuseThread) Send a multi action structure to the servers, after a delay depending on the attempt number.(package private) <CResult> AsyncRequestFuture
AsyncProcess.submitMultiActions
(AsyncProcessTask task, List<Action> retainedActions, long nonceGroup, List<Exception> locationErrors, List<Integer> locationErrorRows, Map<ServerName, MultiAction> actionsByServer) ModifierConstructorDescription(package private)
MultiServerCallable
(ClusterConnection connection, TableName tableName, ServerName location, MultiAction multi, org.apache.hbase.thirdparty.com.google.protobuf.RpcController rpcController, int rpcTimeout, RetryingTimeTracker tracker, int priority, Map<String, byte[]> requestAttributes) (package private)
SingleServerRequestRunnable
(MultiAction multiAction, int numAttempt, ServerName server, Set<CancellableRegionServerCallable> callsInProgress)