Uses of Interface
org.apache.hadoop.hbase.client.ServiceCaller
Packages that use ServiceCaller
-
Uses of ServiceCaller in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as ServiceCallerModifier and TypeFieldDescriptionprivate final ServiceCaller<S,
R> RawAsyncTableImpl.CoprocessorServiceBuilderImpl.callable
Methods in org.apache.hadoop.hbase.client that return ServiceCallerModifier and TypeMethodDescriptionAsyncTable.PartialResultCoprocessorCallback.getNextCallable
(R response, RegionInfo region) Subclasses should implement this to tell AsyncTable whether the given response is "final" or whether the AsyncTable should send another request to the coprocessor to fetch more results from the given region.NoopPartialResultCoprocessorCallback.getNextCallable
(R response, RegionInfo region) Methods in org.apache.hadoop.hbase.client with parameters of type ServiceCallerModifier and TypeMethodDescription<S,
R> CompletableFuture<R> AsyncAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) Execute the given coprocessor call on the master.<S,
R> CompletableFuture<R> AsyncAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) Execute the given coprocessor call on the given region server.<S,
R> CompletableFuture<R> AsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) <S,
R> CompletableFuture<R> AsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) <S,
R> CompletableFuture<R> AsyncTable.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, byte[] row) Execute the given coprocessor call on the region which contains the givenrow
.<S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> AsyncTable.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.CoprocessorCallback<R> callback) Execute a coprocessor call on the regions which are covered by a range.<S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> AsyncTable.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback) Similar to above.<S,
R> CompletableFuture<R> AsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, byte[] row) <S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> AsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.CoprocessorCallback<R> callback) <S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> AsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback) <S,
R> CompletableFuture<R> RawAsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) <S,
R> CompletableFuture<R> RawAsyncHBaseAdmin.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, ServerName serverName) <S,
R> CompletableFuture<R> RawAsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, byte[] row) <S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> RawAsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.CoprocessorCallback<R> callback) <S,
R> AsyncTable.CoprocessorServiceBuilder<S, R> RawAsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback) private <S,
R> CompletableFuture<R> RawAsyncTableImpl.coprocessorService
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, RegionInfo region, byte[] row) static <S,
R> CompletableFuture<Map<ServerName, Object>> AsyncAdminClientUtils.coprocessorServiceOnAllRegionServers
(AsyncAdmin asyncAdmin, Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable) Execute the given coprocessor call on all region servers.private <S,
R> void RawAsyncTableImpl.coprocessorServiceUntilComplete
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, RegionInfo region, io.opentelemetry.api.trace.Span span) private <S,
R> void RawAsyncTableImpl.onLocateComplete
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback, byte[] endKey, boolean endKeyInclusive, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, HRegionLocation loc, Throwable error) Constructors in org.apache.hadoop.hbase.client with parameters of type ServiceCallerModifierConstructorDescriptionCoprocessorServiceBuilderImpl
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback)