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 with type parameters of type MetricsConnectionModifier and TypeFieldDescriptionprivate final Optional<MetricsConnection>AsyncConnectionImpl.metricsprivate static final ConcurrentMap<String,MetricsConnection> MetricsConnection.METRICS_INSTANCESMethods in org.apache.hadoop.hbase.client that return MetricsConnectionModifier and TypeMethodDescription(package private) static MetricsConnectionMetricsConnection.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 TypeMethodDescription(package private) static voidAsyncRegionLocatorHelper.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> voidConnectionUtils.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> voidConnectionUtils.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) -
Uses of MetricsConnection in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as MetricsConnectionModifier and TypeFieldDescriptionprotected final MetricsConnectionAbstractRpcClient.metricsprotected final MetricsConnectionRpcConnection.metricsMethods in org.apache.hadoop.hbase.ipc with parameters of type MetricsConnectionModifier and TypeMethodDescriptionstatic RpcClientRpcClientFactory.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 RpcClientRpcClientFactory.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 RpcClientImplprotected final InetSocketAddressRpcConnection.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 clusterclusterIdBlockingRpcClient(org.apache.hadoop.conf.Configuration conf, String clusterId, SocketAddress localAddr, MetricsConnection metrics, Map<String, byte[]> connectionAttributes) Construct an IPC client for the clusterclusterIdwith 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) protectedRpcConnection(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)