Package | Description |
---|---|
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.ipc |
Tools to help define network clients and servers.
|
Modifier and Type | Field and Description |
---|---|
private MetricsConnection |
MetaCache.metrics |
private MetricsConnection |
ConnectionImplementation.metrics |
Modifier and Type | Field and Description |
---|---|
private Optional<MetricsConnection> |
AsyncConnectionImpl.metrics |
Modifier and Type | Method and Description |
---|---|
MetricsConnection |
ClusterConnection.getConnectionMetrics() |
MetricsConnection |
ConnectionImplementation.getConnectionMetrics() |
Modifier and Type | Method and Description |
---|---|
(package private) Optional<MetricsConnection> |
AsyncConnectionImpl.getConnectionMetrics() |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
AsyncRegionLocatorHelper.updateCachedLocationOnError(HRegionLocation loc,
Throwable exception,
Function<HRegionLocation,HRegionLocation> cachedLocationSupplier,
Consumer<HRegionLocation> addToCache,
Consumer<HRegionLocation> removeFromCache,
MetricsConnection metrics) |
Modifier and Type | Method and Description |
---|---|
private static <T> void |
ConnectionUtils.connect(CompletableFuture<T> srcFuture,
CompletableFuture<T> dstFuture,
Optional<MetricsConnection> metrics)
Connect the two futures, if the src future is done, then mark the dst future as done.
|
private static <T> void |
ConnectionUtils.sendRequestsToSecondaryReplicas(Function<Integer,CompletableFuture<T>> requestReplica,
RegionLocations locs,
CompletableFuture<T> future,
Optional<MetricsConnection> metrics) |
(package private) static <T> CompletableFuture<T> |
ConnectionUtils.timelineConsistentRead(AsyncRegionLocator locator,
TableName tableName,
Query query,
byte[] row,
RegionLocateType locateType,
Function<Integer,CompletableFuture<T>> requestReplica,
long rpcTimeoutNs,
long primaryCallTimeoutNs,
org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer,
Optional<MetricsConnection> metrics) |
(package private) static void |
ConnectionUtils.updateStats(Optional<ServerStatisticTracker> optStats,
Optional<MetricsConnection> optMetrics,
ServerName serverName,
MultiResponse resp) |
Constructor and Description |
---|
MetaCache(MetricsConnection metrics) |
Modifier and Type | Field and Description |
---|---|
protected MetricsConnection |
AbstractRpcClient.metrics |
Modifier and Type | Method and Description |
---|---|
static RpcClient |
RpcClientFactory.createClient(org.apache.hadoop.conf.Configuration conf,
String clusterId,
MetricsConnection metrics)
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
|
static RpcClient |
RpcClientFactory.createClient(org.apache.hadoop.conf.Configuration conf,
String clusterId,
SocketAddress localAddr,
MetricsConnection metrics)
Creates a new RpcClient by the class defined in the configuration or falls back to
RpcClientImpl
|
Constructor and Description |
---|
AbstractRpcClient(org.apache.hadoop.conf.Configuration conf,
String clusterId,
SocketAddress localAddr,
MetricsConnection metrics)
Construct an IPC client for the cluster
clusterId |
BlockingRpcClient(org.apache.hadoop.conf.Configuration conf,
String clusterId,
SocketAddress localAddr,
MetricsConnection metrics)
Construct an IPC client for the cluster
clusterId with the default SocketFactory This
method is called with reflection by the RpcClientFactory to create an instance |
NettyRpcClient(org.apache.hadoop.conf.Configuration configuration,
String clusterId,
SocketAddress localAddress,
MetricsConnection metrics) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.