Uses of Class
org.apache.hadoop.hbase.client.Action
Packages that use Action
-
Uses of Action in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client with type parameters of type ActionModifier and TypeFieldDescriptionprivate final IdentityHashMap<Action,List<RetriesExhaustedException.ThrowableWithExtraContext>> AsyncBatchRpcRetryingCaller.action2Errorsprivate final IdentityHashMap<Action,CompletableFuture<T>> AsyncBatchRpcRetryingCaller.action2FutureAsyncBatchRpcRetryingCaller.actionsfinal ConcurrentLinkedQueue<Action>AsyncBatchRpcRetryingCaller.RegionRequest.actionsMultiAction.actionsA map of regions to lists of puts/gets/deletes for that region.AsyncRequestFutureImpl.ReplicaCallIssuingRunnable.initialActionsMethods in org.apache.hadoop.hbase.client with parameters of type ActionModifier and TypeMethodDescriptionvoidAdd an Action to this container based on it's regionName.voidAsyncBatchRpcRetryingCaller.ServerRequest.addAction(HRegionLocation loc, Action action) (package private) static voidAsyncProcess.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 voidAsyncBatchRpcRetryingCaller.addError(Action action, Throwable error, ServerName serverName) private voidAsyncRequestFutureImpl.ReplicaCallIssuingRunnable.addReplicaActionsAgain(Action action, Map<ServerName, MultiAction> actionsByServer) intprivate voidAsyncBatchRpcRetryingCaller.failOne(Action action, int tries, Throwable error, long currentTime, String extras) private RegionLocationsAsyncRequestFutureImpl.findAllLocationsOrFail(Action action, boolean useCache) private HRegionLocationAsyncRequestFutureImpl.getReplicaLocationOrFail(Action action) private voidAsyncRequestFutureImpl.manageLocationError(Action action, Exception ex) private voidAsyncBatchRpcRetryingCaller.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 voidAsyncProcess.setNonce(NonceGenerator ng, Row r, Action action) private voidSets the non-error result from a particular action.Method parameters in org.apache.hadoop.hbase.client with type arguments of type ActionModifier and TypeMethodDescriptionvoidvoidAdd an Action to this container based on it's regionName.private voidAsyncBatchRpcRetryingCaller.addError(Iterable<Action> actions, Throwable error, ServerName serverName) private voidAsyncRequestFutureImpl.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 voidprivate voidAsyncBatchRpcRetryingCaller.failAll(Stream<Action> actions, int tries, Throwable error, ServerName serverName) private voidAsyncBatchRpcRetryingCaller.groupAndSend(Stream<Action> actions, int tries) (package private) voidAsyncRequestFutureImpl.groupAndSendMultiAction(List<Action> currentActions, int numAttempt) Group a list of actions per region servers, and send them.private voidAsyncBatchRpcRetryingCaller.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 voidAsyncRequestFutureImpl.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) voidAsyncRequestFutureImpl.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 voidAsyncRequestFutureImpl.startWaitingForReplicaCalls(List<Action> actionsForReplicaThread) Starts waiting to issue replica calls on a different thread; or issues them immediately.(package private) <CResult> AsyncRequestFutureAsyncProcess.submitMultiActions(AsyncProcessTask task, List<Action> retainedActions, long nonceGroup, List<Exception> locationErrors, List<Integer> locationErrorRows, Map<ServerName, MultiAction> actionsByServer) private voidAsyncBatchRpcRetryingCaller.tryResubmit(Stream<Action> actions, int tries, boolean immediately, Throwable error) Constructors in org.apache.hadoop.hbase.client with parameters of type ActionModifierConstructorDescriptionCreates an action for a particular replica from original action.Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type ActionModifierConstructorDescriptionAsyncRequestFutureImpl(AsyncProcessTask task, List<Action> actions, long nonceGroup, AsyncProcess asyncProcess) DelayingRunner(long sleepTime, Map.Entry<byte[], List<Action>> e) ReplicaCallIssuingRunnable(List<Action> initialActions, long startTime)