Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
Modifier and Type | Method and Description |
---|---|
<S,R> CompletableFuture<R> |
RawAsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable) |
<S,R> CompletableFuture<R> |
AsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable) |
<S,R> CompletableFuture<R> |
AsyncAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable)
Execute the given coprocessor call on the master.
|
<S,R> CompletableFuture<R> |
RawAsyncTable.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
byte[] row)
Execute the given coprocessor call on the region which contains the given
row . |
<S,R> void |
RawAsyncTable.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
byte[] startKey,
boolean startKeyInclusive,
byte[] endKey,
boolean endKeyInclusive,
RawAsyncTable.CoprocessorCallback<R> callback)
Execute the given coprocessor call on the regions which are covered by the range from
startKey and endKey . |
default <S,R> void |
RawAsyncTable.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
byte[] startKey,
byte[] endKey,
RawAsyncTable.CoprocessorCallback<R> callback)
Execute the given coprocessor call on the regions which are covered by the range from
startKey inclusive and endKey exclusive. |
<S,R> CompletableFuture<R> |
RawAsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
ServerName serverName) |
<S,R> CompletableFuture<R> |
AsyncHBaseAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
ServerName serverName) |
<S,R> CompletableFuture<R> |
AsyncAdmin.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
RawAsyncTable.CoprocessorCallable<S,R> callable,
ServerName serverName)
Execute the given coprocessor call on the given region server.
|
Copyright © 2007–2017 The Apache Software Foundation. All rights reserved.