Package org.apache.hadoop.hbase.client
Class AsyncNonMetaRegionLocator
java.lang.Object
org.apache.hadoop.hbase.client.AsyncNonMetaRegionLocator
The asynchronous locator for regions other than meta.
-
Nested Class Summary
Modifier and TypeClassDescriptionprivate static final class
private static final class
private static final class
-
Field Summary
Modifier and TypeFieldDescriptionprivate final ConcurrentMap<TableName,
AsyncNonMetaRegionLocator.TableCache> private final AsyncConnectionImpl
private static final int
private static final int
(package private) static String
private final int
private static final org.slf4j.Logger
(package private) static final String
private final int
private CatalogReplicaMode
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescription(package private) void
(package private) void
(package private) void
clearCache
(ServerName serverName) (package private) void
clearCache
(TableName tableName) private void
complete
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) private HRegionLocation
(package private) int
getNumberOfCachedRegionLocations
(TableName tableName) (package private) RegionLocations
getRegionLocationInCache
(TableName tableName, byte[] row) (package private) CompletableFuture<RegionLocations>
getRegionLocations
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) private CompletableFuture<RegionLocations>
getRegionLocationsInternal
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) getTableCache
(TableName tableName) private RegionLocations
locateInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) private void
locateInMeta
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req) private RegionLocations
locateRowBeforeInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private RegionLocations
locateRowInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private boolean
onScanNext
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, Result result) private void
private void
private void
private void
(package private) void
updateCachedLocationOnError
(HRegionLocation loc, Throwable exception) private void
-
Field Details
-
LOG
-
MAX_CONCURRENT_LOCATE_REQUEST_PER_TABLE
- See Also:
-
DEFAULT_MAX_CONCURRENT_LOCATE_REQUEST_PER_TABLE
- See Also:
-
LOCATE_PREFETCH_LIMIT
-
DEFAULT_LOCATE_PREFETCH_LIMIT
- See Also:
-
conn
-
maxConcurrentLocateRequestPerTable
-
locatePrefetchLimit
-
metaReplicaMode
-
metaReplicaSelector
-
cache
-
-
Constructor Details
-
AsyncNonMetaRegionLocator
-
-
Method Details
-
getTableCache
-
complete
private void complete(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) -
onScanNext
private boolean onScanNext(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, Result result) -
recordCacheHit
-
recordCacheMiss
-
locateRowInCache
private RegionLocations locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) -
locateRowBeforeInCache
private RegionLocations locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) -
locateInMeta
-
locateInCache
private RegionLocations locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) -
getRegionLocationsInternal
private CompletableFuture<RegionLocations> getRegionLocationsInternal(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) -
getRegionLocations
CompletableFuture<RegionLocations> getRegionLocations(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) -
recordClearRegionCache
-
removeLocationFromCache
-
updateMetaReplicaSelector
-
addLocationToCache
-
getCachedLocation
-
updateCachedLocationOnError
-
clearCache
-
clearCache
void clearCache() -
clearCache
-
getRegionLocationInCache
-
getNumberOfCachedRegionLocations
-