Uses of Class
org.apache.hadoop.hbase.client.MetricsConnection
Packages that use MetricsConnection
Package
Description
Provides HBase Client
Tools to help define network clients and servers.
-
Uses of MetricsConnection in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as MetricsConnectionModifier and TypeFieldDescriptionprivate final MetricsConnection
ConnectionImplementation.metrics
private final MetricsConnection
MetaCache.metrics
private final MetricsConnection
RpcRetryingCallerFactory.metrics
private final MetricsConnection
RpcRetryingCallerImpl.metrics
Fields in org.apache.hadoop.hbase.client with type parameters of type MetricsConnectionModifier and TypeFieldDescriptionprivate final Optional<MetricsConnection>
AsyncConnectionImpl.metrics
private static final ConcurrentMap<String,
MetricsConnection> MetricsConnection.METRICS_INSTANCES
Methods in org.apache.hadoop.hbase.client that return MetricsConnectionModifier and TypeMethodDescriptionClusterConnection.getConnectionMetrics()
Returns the MetricsConnection instance associated with this connection.ConnectionImplementation.getConnectionMetrics()
(package private) static MetricsConnection
MetricsConnection.getMetricsConnection
(org.apache.hadoop.conf.Configuration conf, String scope, Supplier<ThreadPoolExecutor> batchPool, Supplier<ThreadPoolExecutor> metaPool) Methods in org.apache.hadoop.hbase.client that return types with arguments of type MetricsConnectionModifier and TypeMethodDescription(package private) Optional<MetricsConnection>
AsyncConnectionImpl.getConnectionMetrics()
Methods in org.apache.hadoop.hbase.client with parameters of type MetricsConnectionModifier and TypeMethodDescriptionstatic RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, RetryingCallerInterceptor interceptor, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, ConnectionConfiguration connectionConf, ServerStatisticTracker stats, MetricsConnection metrics) static RpcRetryingCallerFactory
RpcRetryingCallerFactory.instantiate
(org.apache.hadoop.conf.Configuration configuration, MetricsConnection metrics) (package private) static void
AsyncRegionLocatorHelper.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) Method parameters in org.apache.hadoop.hbase.client with type arguments of type MetricsConnectionModifier and TypeMethodDescriptionprivate 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) Constructors in org.apache.hadoop.hbase.client with parameters of type MetricsConnectionModifierConstructorDescriptionMetaCache
(MetricsConnection metrics) RpcRetryingCallerFactory
(org.apache.hadoop.conf.Configuration conf, ConnectionConfiguration connectionConf, RetryingCallerInterceptor interceptor, MetricsConnection metrics) RpcRetryingCallerImpl
(long pause, long pauseForServerOverloaded, int retries, RetryingCallerInterceptor interceptor, int startLogErrorsCnt, int rpcTimeout, MetricsConnection metricsConnection) -
Uses of MetricsConnection in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as MetricsConnectionModifier and TypeFieldDescriptionprotected final MetricsConnection
AbstractRpcClient.metrics
protected final MetricsConnection
RpcConnection.metrics
Methods in org.apache.hadoop.hbase.ipc with parameters of type MetricsConnectionModifier and TypeMethodDescriptionstatic RpcClient
RpcClientFactory.createClient
(org.apache.hadoop.conf.Configuration conf, String clusterId, SocketAddress localAddr, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImplstatic 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 RpcClientImplstatic RpcClient
RpcClientFactory.createClient
(org.apache.hadoop.conf.Configuration conf, String clusterId, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) Creates a new RpcClient by the class defined in the configuration or falls back to RpcClientImplprotected final InetSocketAddress
RpcConnection.getRemoteInetAddress
(MetricsConnection metrics) Constructors in org.apache.hadoop.hbase.ipc with parameters of type MetricsConnectionModifierConstructorDescriptionAbstractRpcClient
(org.apache.hadoop.conf.Configuration conf, String clusterId, SocketAddress localAddr, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) Construct an IPC client for the clusterclusterId
BlockingRpcClient
(org.apache.hadoop.conf.Configuration conf, String clusterId, SocketAddress localAddr, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) Construct an IPC client for the clusterclusterId
with the default SocketFactory This method is called with reflection by the RpcClientFactory to create an instanceNettyRpcClient
(org.apache.hadoop.conf.Configuration configuration, String clusterId, SocketAddress localAddress, MetricsConnection metrics) NettyRpcClient
(org.apache.hadoop.conf.Configuration configuration, String clusterId, SocketAddress localAddress, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) protected
RpcConnection
(org.apache.hadoop.conf.Configuration conf, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer timeoutTimer, ConnectionId remoteId, String clusterId, boolean isSecurityEnabled, Codec codec, org.apache.hadoop.io.compress.CompressionCodec compressor, CellBlockBuilder cellBlockBuilder, MetricsConnection metrics, Map<String, byte[]> connectionAttributes)