@InterfaceAudience.Private class AsyncRegionLocator extends Object
| Modifier and Type | Field and Description | 
|---|---|
private AsyncConnectionImpl | 
conn  | 
private static org.slf4j.Logger | 
LOG  | 
private AsyncMetaRegionLocator | 
metaRegionLocator  | 
private AsyncNonMetaRegionLocator | 
nonMetaRegionLocator  | 
private org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer | 
retryTimer  | 
| Constructor and Description | 
|---|
AsyncRegionLocator(AsyncConnectionImpl conn,
                  org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer)  | 
| Modifier and Type | Method and Description | 
|---|---|
(package private) void | 
clearCache()  | 
(package private) void | 
clearCache(ServerName serverName)  | 
(package private) void | 
clearCache(TableName tableName)  | 
(package private) AsyncNonMetaRegionLocator | 
getNonMetaRegionLocator()  | 
(package private) CompletableFuture<HRegionLocation> | 
getRegionLocation(TableName tableName,
                 byte[] row,
                 int replicaId,
                 RegionLocateType type,
                 boolean reload,
                 long timeoutNs)  | 
(package private) CompletableFuture<HRegionLocation> | 
getRegionLocation(TableName tableName,
                 byte[] row,
                 int replicaId,
                 RegionLocateType type,
                 long timeoutNs)  | 
(package private) CompletableFuture<HRegionLocation> | 
getRegionLocation(TableName tableName,
                 byte[] row,
                 RegionLocateType type,
                 boolean reload,
                 long timeoutNs)  | 
(package private) CompletableFuture<HRegionLocation> | 
getRegionLocation(TableName tableName,
                 byte[] row,
                 RegionLocateType type,
                 long timeoutNs)  | 
(package private) CompletableFuture<RegionLocations> | 
getRegionLocations(TableName tableName,
                  byte[] row,
                  RegionLocateType type,
                  boolean reload,
                  long timeoutNs)  | 
(package private) static List<String> | 
getRegionNames(HRegionLocation location)  | 
(package private) static List<String> | 
getRegionNames(RegionLocations locs)  | 
private boolean | 
isMeta(TableName tableName)  | 
private <T> CompletableFuture<T> | 
tracedLocationFuture(Supplier<CompletableFuture<T>> action,
                    Function<T,List<String>> getRegionNames,
                    Supplier<io.opentelemetry.api.trace.Span> spanSupplier)  | 
(package private) void | 
updateCachedLocationOnError(HRegionLocation loc,
                           Throwable exception)  | 
private <T> CompletableFuture<T> | 
withTimeout(CompletableFuture<T> future,
           long timeoutNs,
           Supplier<String> timeoutMsg)  | 
private static final org.slf4j.Logger LOG
private final org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer
private final AsyncConnectionImpl conn
private final AsyncMetaRegionLocator metaRegionLocator
private final AsyncNonMetaRegionLocator nonMetaRegionLocator
AsyncRegionLocator(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer)
private <T> CompletableFuture<T> withTimeout(CompletableFuture<T> future, long timeoutNs, Supplier<String> timeoutMsg)
private <T> CompletableFuture<T> tracedLocationFuture(Supplier<CompletableFuture<T>> action, Function<T,List<String>> getRegionNames, Supplier<io.opentelemetry.api.trace.Span> spanSupplier)
static List<String> getRegionNames(RegionLocations locs)
static List<String> getRegionNames(HRegionLocation location)
CompletableFuture<RegionLocations> getRegionLocations(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs)
CompletableFuture<HRegionLocation> getRegionLocation(TableName tableName, byte[] row, int replicaId, RegionLocateType type, boolean reload, long timeoutNs)
CompletableFuture<HRegionLocation> getRegionLocation(TableName tableName, byte[] row, int replicaId, RegionLocateType type, long timeoutNs)
CompletableFuture<HRegionLocation> getRegionLocation(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs)
CompletableFuture<HRegionLocation> getRegionLocation(TableName tableName, byte[] row, RegionLocateType type, long timeoutNs)
void updateCachedLocationOnError(HRegionLocation loc, Throwable exception)
void clearCache(TableName tableName)
void clearCache(ServerName serverName)
void clearCache()
AsyncNonMetaRegionLocator getNonMetaRegionLocator()
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.