Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.client.coprocessor |
Provides client classes for invoking Coprocessor RPC protocols
Overview
Example Usage
|
Modifier and Type | Field and Description |
---|---|
private AsyncTable.CoprocessorCallback<R> |
RawAsyncTableImpl.CoprocessorServiceBuilderImpl.callback |
Modifier and Type | Method and Description |
---|---|
<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.
|
<S,R> AsyncTable.CoprocessorServiceBuilder<S,R> |
RawAsyncTableImpl.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
AsyncTable.CoprocessorCallback<R> callback) |
<S,R> AsyncTable.CoprocessorServiceBuilder<S,R> |
AsyncTableImpl.coprocessorService(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
AsyncTable.CoprocessorCallback<R> callback) |
private <S,R> void |
RawAsyncTableImpl.onLocateComplete(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
AsyncTable.CoprocessorCallback<R> callback,
List<HRegionLocation> locs,
byte[] endKey,
boolean endKeyInclusive,
AtomicBoolean locateFinished,
AtomicInteger unfinishedRequest,
HRegionLocation loc,
Throwable error) |
Constructor and Description |
---|
CoprocessorServiceBuilderImpl(Function<com.google.protobuf.RpcChannel,S> stubMaker,
ServiceCaller<S,R> callable,
AsyncTable.CoprocessorCallback<R> callback) |
Modifier and Type | Class and Description |
---|---|
private static class |
AsyncAggregationClient.AbstractAggregationCallback<T> |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.