Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
Modifier and Type | Method and Description |
---|---|
ServiceCaller<S,R> |
NoopPartialResultCoprocessorCallback.getNextCallable(R response,
RegionInfo region) |
ServiceCaller<S,R> |
AsyncTable.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.
|
Modifier and Type | Method and Description |
---|---|
<S,R> CompletableFuture<R> |
AsyncAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable)
Execute the given coprocessor call on the master.
|
<S,R> AsyncTable.CoprocessorServiceBuilder<S,R> |
AsyncTable.coprocessorService(Function<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.
|
default <S,R> AsyncTable.CoprocessorServiceBuilder<S,R> |
AsyncTable.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
AsyncTable.PartialResultCoprocessorCallback<S,R> callback)
Similar to above.
|
<S,R> CompletableFuture<R> |
AsyncTable.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
byte[] row)
Execute the given coprocessor call on the region which contains the given
row . |
<S,R> CompletableFuture<R> |
AsyncAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
ServerName serverName)
Execute the given coprocessor call on the given region server.
|
static <S,R> CompletableFuture<Map<ServerName,Object>> |
AsyncAdminClientUtils.coprocessorServiceOnAllRegionServers(AsyncAdmin asyncAdmin,
Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable)
Execute the given coprocessor call on all region servers.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.