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 SummaryNested ClassesModifier and TypeClassDescriptionprivate static final classprivate static final classprivate static final class
- 
Field SummaryFieldsModifier and TypeFieldDescriptionprivate final ConcurrentMap<TableName,AsyncNonMetaRegionLocator.TableCache> private final AsyncConnectionImplprivate static final intprivate static final int(package private) static Stringprivate final intprivate static final org.slf4j.Logger(package private) static final Stringprivate final intprivate CatalogReplicaModeprivate final org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer
- 
Constructor SummaryConstructorsConstructorDescriptionAsyncNonMetaRegionLocator(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer) 
- 
Method SummaryModifier and TypeMethodDescription(package private) void(package private) void(package private) voidclearCache(ServerName serverName) (package private) voidclearCache(TableName tableName) private voidcomplete(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) private HRegionLocationprivate org.apache.hbase.thirdparty.io.netty.util.TimerTaskgetInvalidateMetaCacheTask(long metaCacheInvalidateInterval) (package private) intgetNumberOfCachedRegionLocations(TableName tableName) (package private) RegionLocationsgetRegionLocationInCache(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 voidinvalidateCache(CompletableFuture<Void> future, Iterator<TableName> tbnIter, AsyncAdmin admin) private CompletableFuture<Void>private RegionLocationslocateInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) private voidlocateInMeta(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req) private RegionLocationslocateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private RegionLocationslocateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private booleanonScanNext(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, Result result) private voidprivate voidprivate voidprivate void(package private) voidupdateCachedLocationOnError(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
- 
retryTimer
 
- 
- 
Constructor Details- 
AsyncNonMetaRegionLocatorAsyncNonMetaRegionLocator(AsyncConnectionImpl conn, org.apache.hbase.thirdparty.io.netty.util.HashedWheelTimer retryTimer) 
 
- 
- 
Method Details- 
getTableCache
- 
completeprivate void complete(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) 
- 
onScanNextprivate boolean onScanNext(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, Result result) 
- 
recordCacheHit
- 
recordCacheMiss
- 
locateRowInCacheprivate RegionLocations locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) 
- 
locateRowBeforeInCacheprivate RegionLocations locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) 
- 
locateInMeta
- 
locateInCacheprivate RegionLocations locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) 
- 
getRegionLocationsInternalprivate CompletableFuture<RegionLocations> getRegionLocationsInternal(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) 
- 
getRegionLocationsCompletableFuture<RegionLocations> getRegionLocations(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) 
- 
recordClearRegionCache
- 
removeLocationFromCache
- 
updateMetaReplicaSelector
- 
addLocationToCache
- 
getCachedLocation
- 
updateCachedLocationOnError
- 
clearCache
- 
clearCachevoid clearCache()
- 
clearCache
- 
getRegionLocationInCache
- 
getNumberOfCachedRegionLocations
- 
getInvalidateMetaCacheTaskprivate org.apache.hbase.thirdparty.io.netty.util.TimerTask getInvalidateMetaCacheTask(long metaCacheInvalidateInterval) 
- 
invalidateTableCache
- 
invalidateCacheprivate void invalidateCache(CompletableFuture<Void> future, Iterator<TableName> tbnIter, AsyncAdmin admin) 
 
-