Uses of Class
org.apache.hadoop.hbase.client.AsyncConnectionImpl
Package
Description
Provides HBase Client
-
Uses of AsyncConnectionImpl in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final AsyncConnectionImpl
AsyncBatchRpcRetryingCaller.conn
private final AsyncConnectionImpl
AsyncClientScanner.conn
private final AsyncConnectionImpl
AsyncNonMetaRegionLocator.conn
private final AsyncConnectionImpl
AsyncRegionLocator.conn
protected final AsyncConnectionImpl
AsyncRpcRetryingCaller.conn
private final AsyncConnectionImpl
AsyncRpcRetryingCallerFactory.conn
protected final AsyncConnectionImpl
AsyncScanSingleRegionRpcRetryingCaller.conn
private final AsyncConnectionImpl
AsyncTableRegionLocatorImpl.conn
private final AsyncConnectionImpl
RawAsyncTableImpl.conn
private final AsyncConnectionImpl
RegionCoprocessorRpcChannelImpl.conn
private final AsyncConnectionImpl
RawAsyncHBaseAdmin.connection
ModifierConstructorDescriptionAsyncAdminRequestRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, int priority, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, ServerName serverName, AsyncAdminRequestRetryingCaller.Callable<T> callable) AsyncBatchRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, TableName tableName, List<? extends Row> actions, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncClientScanner
(Scan scan, AdvancedScanResultConsumer consumer, TableName tableName, AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncMasterRequestRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, AsyncMasterRequestRpcRetryingCaller.Callable<T> callable, int priority, long pauseNs, long pauseNsForServerOverloaded, int maxRetries, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt) (package private)
(package private)
AsyncRegionLocator
(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer) AsyncRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, int priority, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncRpcRetryingCallerFactory
(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer) AsyncScanSingleRegionRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, Scan scan, ScanMetrics scanMetrics, long scannerId, ScanResultCache resultCache, AdvancedScanResultConsumer consumer, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, HRegionLocation loc, boolean isRegionServerRemote, int priority, long scannerLeaseTimeoutPeriodNs, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncServerRequestRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, ServerName serverName, AsyncServerRequestRpcRetryingCaller.Callable<T> callable) AsyncSingleRequestRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, AsyncSingleRequestRpcRetryingCaller.Callable<T> callable, int priority, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long operationTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) AsyncTableRegionLocatorImpl
(TableName tableName, AsyncConnectionImpl conn) (package private)
RawAsyncHBaseAdmin
(AsyncConnectionImpl connection, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer, AsyncAdminBuilderBase builder) (package private)
RawAsyncTableImpl
(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncTableBuilderBase<?> builder) (package private)
RegionCoprocessorRpcChannelImpl
(AsyncConnectionImpl conn, TableName tableName, RegionInfo region, byte[] row, long rpcTimeoutNs, long operationTimeoutNs) -
Uses of AsyncConnectionImpl in org.apache.hadoop.hbase.client.trace
Modifier and TypeMethodDescription(package private) static void
ConnectionSpanBuilder.populateConnectionAttributes
(Map<io.opentelemetry.api.common.AttributeKey<?>, Object> attributes, AsyncConnectionImpl conn) Static utility method that performs the primary logic of this builder.ModifierConstructorDescription