Uses of Class
org.apache.hadoop.hbase.client.Action
-
Uses of Action in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final IdentityHashMap<Action,
List<RetriesExhaustedException.ThrowableWithExtraContext>> AsyncBatchRpcRetryingCaller.action2Errors
private final IdentityHashMap<Action,
CompletableFuture<T>> AsyncBatchRpcRetryingCaller.action2Future
AsyncBatchRpcRetryingCaller.actions
final ConcurrentLinkedQueue<Action>
AsyncBatchRpcRetryingCaller.RegionRequest.actions
MultiAction.actions
A map of regions to lists of puts/gets/deletes for that region.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.initialActions
Modifier and TypeMethodDescriptionvoid
Add an Action to this container based on it's regionName.void
AsyncBatchRpcRetryingCaller.ServerRequest.addAction
(HRegionLocation loc, Action action) (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
AsyncBatchRpcRetryingCaller.addError
(Action action, Throwable error, ServerName serverName) private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain
(Action action, Map<ServerName, MultiAction> actionsByServer) int
private void
AsyncBatchRpcRetryingCaller.failOne
(Action action, int tries, Throwable error, long currentTime, String extras) private RegionLocations
AsyncRequestFutureImpl.findAllLocationsOrFail
(Action action, boolean useCache) private HRegionLocation
AsyncRequestFutureImpl.getReplicaLocationOrFail
(Action action) private void
AsyncRequestFutureImpl.manageLocationError
(Action action, Exception ex) private void
AsyncBatchRpcRetryingCaller.onComplete
(Action action, AsyncBatchRpcRetryingCaller.RegionRequest regionReq, int tries, ServerName serverName, MultiResponse.RegionResult regionResult, List<Action> failedActions, Throwable regionException, org.apache.commons.lang3.mutable.MutableBoolean retryImmediately) AsyncBatchRpcRetryingCaller.removeErrors
(Action action) private void
AsyncProcess.setNonce
(NonceGenerator ng, Row r, Action action) private void
Sets the non-error result from a particular action.Modifier and TypeMethodDescriptionvoid
void
Add an Action to this container based on it's regionName.private void
AsyncBatchRpcRetryingCaller.addError
(Iterable<Action> actions, Throwable error, ServerName serverName) private void
AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActions
(int index, Map<ServerName, MultiAction> actionsByServer, List<Action> unknownReplicaActions) Add replica actions to action map by server.(package private) <CResult> AsyncRequestFutureImpl<CResult>
AsyncProcess.createAsyncRequestFuture
(AsyncProcessTask task, List<Action> actions, long nonceGroup) private void
private void
AsyncBatchRpcRetryingCaller.failAll
(Stream<Action> actions, int tries, Throwable error, ServerName serverName) private void
AsyncBatchRpcRetryingCaller.groupAndSend
(Stream<Action> actions, int tries) (package private) void
AsyncRequestFutureImpl.groupAndSendMultiAction
(List<Action> currentActions, int numAttempt) Group a list of actions per region servers, and send them.private void
AsyncBatchRpcRetryingCaller.onComplete
(Action action, AsyncBatchRpcRetryingCaller.RegionRequest regionReq, int tries, ServerName serverName, MultiResponse.RegionResult regionResult, List<Action> failedActions, Throwable regionException, org.apache.commons.lang3.mutable.MutableBoolean retryImmediately) private void
AsyncRequestFutureImpl.resubmit
(ServerName oldServer, List<Action> toReplay, int numAttempt, int failureCount, Throwable throwable) Log as much info as possible, and, if there is something to replay, submit it again after a back off sleep.(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.private void
AsyncRequestFutureImpl.startWaitingForReplicaCalls
(List<Action> actionsForReplicaThread) Starts waiting to issue replica calls on a different thread; or issues them immediately.(package private) <CResult> AsyncRequestFuture
AsyncProcess.submitMultiActions
(AsyncProcessTask task, List<Action> retainedActions, long nonceGroup, List<Exception> locationErrors, List<Integer> locationErrorRows, Map<ServerName, MultiAction> actionsByServer) private void
AsyncBatchRpcRetryingCaller.tryResubmit
(Stream<Action> actions, int tries, boolean immediately, Throwable error) ModifierConstructorDescriptionCreates an action for a particular replica from original action.ModifierConstructorDescriptionAsyncRequestFutureImpl
(AsyncProcessTask task, List<Action> actions, long nonceGroup, AsyncProcess asyncProcess) DelayingRunner
(long sleepTime, Map.Entry<byte[], List<Action>> e) ReplicaCallIssuingRunnable
(List<Action> initialActions, long startTime)