Uses of Class
org.apache.hadoop.hbase.RegionLocations
Package
Description
Provides HBase Client
-
Uses of RegionLocations in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionstatic RegionLocations
MetaTableAccessor.getRegionLocations
(Result r) Returns an HRegionLocationList extracted from the result.RegionLocations.mergeLocations
(RegionLocations other) Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum.RegionLocations.remove
(int replicaId) Removes location of the given replicaId from the listRegionLocations.remove
(HRegionLocation location) Removes the given location from the listRegionLocations.removeByServer
(ServerName serverName) Returns a new RegionLocations with the locations removed (set to null) which have the destination server as given.RegionLocations.removeElementsWithNullLocation()
Set the element to null if its getServerName method returns null.RegionLocations.updateLocation
(HRegionLocation location, boolean checkForEquals, boolean force) Updates the location with new only if the new location has a higher seqNum than the old one or force is true.Modifier and TypeMethodDescriptionprivate static Optional<RegionLocations>
AsyncMetaTableAccessor.getRegionLocations
(Result r) Returns an HRegionLocationList extracted from the result.Modifier and TypeMethodDescriptionRegionLocations.mergeLocations
(RegionLocations other) Merges this RegionLocations list with the given list assuming same range, and keeping the most up to date version of the HRegionLocation entries from either list according to seqNum. -
Uses of RegionLocations in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprivate final RegionLocations
AsyncNonMetaRegionLocator.RegionLocationsFutureResult.result
Modifier and TypeFieldDescriptionprivate final Map<AsyncNonMetaRegionLocator.LocateRequest,
CompletableFuture<RegionLocations>> AsyncNonMetaRegionLocator.TableCache.allRequests
private final ConcurrentNavigableMap<byte[],
RegionLocations> AsyncRegionLocationCache.cache
private final ConcurrentMap<TableName,
ConcurrentNavigableMap<byte[], RegionLocations>> MetaCache.cachedRegionLocations
Map of table to tableHRegionLocation
s.private final CompletableFuture<RegionLocations>
AsyncNonMetaRegionLocator.RegionLocationsFutureResult.future
private final AtomicReference<RegionLocations>
AsyncMetaRegionLocator.metaRegionLocations
private final AtomicReference<CompletableFuture<RegionLocations>>
AsyncMetaRegionLocator.metaRelocateFuture
Modifier and TypeMethodDescriptionAsyncRegionLocationCache.add
(RegionLocations locs) Add the given locations to the cache, merging with existing if necessary.(package private) static RegionLocations
AsyncRegionLocatorHelper.createRegionLocations
(HRegionLocation loc) private RegionLocations
AsyncRequestFutureImpl.findAllLocationsOrFail
(Action action, boolean useCache) AsyncRegionLocationCache.findForBeforeRow
(byte[] row, int replicaId) Finds the RegionLocations for the region with the greatest startKey strictly less than the given rowAsyncRegionLocationCache.findForRow
(byte[] row, int replicaId) Finds the RegionLocations for the region with the greatest startKey less than or equal to the given rowAsyncRegionLocationCache.get
(byte[] startKey) Gets the RegionLocations for a given region's startKey.(package private) RegionLocations
ConnectionImplementation.getCachedLocation
(TableName tableName, byte[] row) Search the cache for a location that fits our table and row key.MetaCache.getCachedLocation
(TableName tableName, byte[] row) Search the cache for a location that fits our table and row key.(package private) RegionLocations
AsyncNonMetaRegionLocator.getRegionLocationInCache
(TableName tableName, byte[] row) static RegionLocations
RegionAdminServiceCallable.getRegionLocations
(ClusterConnection connection, TableName tableName, byte[] row, boolean useCache, int replicaId) (package private) static RegionLocations
RpcRetryingCallerWithReadReplicas.getRegionLocations
(boolean useCache, int replicaId, ClusterConnection cConnection, TableName tableName, byte[] row) protected final RegionLocations
ScannerCallable.getRegionLocationsForPrepare
(byte[] row) Fetch region locations for the row.private RegionLocations
AsyncNonMetaRegionLocator.locateInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) private RegionLocations
ConnectionImplementation.locateMeta
(TableName tableName, boolean useCache, int replicaId) ClusterConnection.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry) Gets the locations of the region in the specified table, tableName, for a given row.ClusterConnection.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) Gets the locations of the region in the specified table, tableName, for a given row.ConnectionImplementation.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry) ConnectionImplementation.locateRegion
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) private RegionLocations
ConnectionImplementation.locateRegionInMeta
(TableName tableName, byte[] row, boolean useCache, boolean retry, int replicaId) Search the hbase:meta table for the HRegionLocation info that contains the table and row we're seeking.private RegionLocations
AsyncNonMetaRegionLocator.locateRowBeforeInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private RegionLocations
AsyncNonMetaRegionLocator.locateRowInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) ClusterConnection.relocateRegion
(TableName tableName, byte[] row, int replicaId) Find the location of the region of tableName that row lives in, ignoring any value that might be in the cache.ConnectionImplementation.relocateRegion
(TableName tableName, byte[] row, int replicaId) (package private) static RegionLocations
AsyncRegionLocatorHelper.removeRegionLocation
(RegionLocations oldLocs, int replicaId) Create a newRegionLocations
based on the givenoldLocs
, and remove the location for the givenreplicaId
.(package private) static RegionLocations
AsyncRegionLocatorHelper.replaceRegionLocation
(RegionLocations oldLocs, HRegionLocation loc) Create a newRegionLocations
based on the givenoldLocs
, and replace the location for the givenreplicaId
with the givenloc
.private static RegionLocations
AbstractRpcBasedConnectionRegistry.transformMetaRegionLocations
(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsResponse resp) Simple helper to transform the result of getMetaRegionLocations() rpc.Modifier and TypeMethodDescriptionAsyncRegionLocationCache.getAll()
Returns all cached RegionLocationsAbstractRpcBasedConnectionRegistry.getMetaRegionLocations()
ConnectionRegistry.getMetaRegionLocations()
Get the location of meta region(s).RegionServerRegistry.getMetaRegionLocations()
ZKConnectionRegistry.getMetaRegionLocations()
Deprecated.(package private) CompletableFuture<RegionLocations>
AsyncMetaRegionLocator.getRegionLocations
(int replicaId, boolean reload) Get the region locations for meta region.(package private) CompletableFuture<RegionLocations>
AsyncNonMetaRegionLocator.getRegionLocations
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) (package private) CompletableFuture<RegionLocations>
AsyncRegionLocator.getRegionLocations
(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs) private CompletableFuture<RegionLocations>
AsyncNonMetaRegionLocator.getRegionLocationsInternal
(TableName tableName, byte[] row, int replicaId, RegionLocateType locateType, boolean reload) private ConcurrentNavigableMap<byte[],
RegionLocations> MetaCache.getTableLocations
(TableName tableName) Returns Map of cached locations for passedtableName
.
Despite being Concurrent, writes to the map should be synchronized because we have cases where we need to make multiple updates atomically.private List<RegionLocations>
HRegionLocator.listRegionLocations()
Modifier and TypeMethodDescriptionAsyncRegionLocationCache.add
(RegionLocations locs) Add the given locations to the cache, merging with existing if necessary.private void
RpcRetryingCallerWithReadReplicas.addCallsForReplica
(ResultBoundedCompletionService<Result> cs, RegionLocations rl, int min, int max) Creates the calls and submit themprivate void
MetaCache.addToCachedServers
(RegionLocations locations) void
ClusterConnection.cacheLocation
(TableName tableName, RegionLocations location) void
ConnectionImplementation.cacheLocation
(TableName tableName, RegionLocations location) Put a newly discovered HRegionLocation into the cache.void
MetaCache.cacheLocation
(TableName tableName, RegionLocations locations) Put a newly discovered HRegionLocation into the cache.(package private) static void
MetaCacheUtil.cleanProblematicOverlappedRegions
(RegionLocations locations, ConcurrentNavigableMap<byte[], RegionLocations> cache) When caching a location, the region may have been the result of a merge.AsyncNonMetaRegionLocator.TableCache.clearCompletedRequests
(RegionLocations locations) private void
AsyncNonMetaRegionLocator.complete
(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) protected final HRegionLocation
ScannerCallable.getLocationForReplica
(RegionLocations locs) AsyncRegionLocator.getRegionNames
(RegionLocations locs) private boolean
AsyncRegionLocationCache.isEqual
(RegionLocations locs1, RegionLocations locs2) (package private) static boolean
AsyncRegionLocatorHelper.isGood
(RegionLocations locs, int replicaId) (package private) static RegionLocations
AsyncRegionLocatorHelper.removeRegionLocation
(RegionLocations oldLocs, int replicaId) Create a newRegionLocations
based on the givenoldLocs
, and remove the location for the givenreplicaId
.(package private) static RegionLocations
AsyncRegionLocatorHelper.replaceRegionLocation
(RegionLocations oldLocs, HRegionLocation loc) Create a newRegionLocations
based on the givenoldLocs
, and replace the location for the givenreplicaId
with the givenloc
.private static <T> void
ConnectionUtils.sendRequestsToSecondaryReplicas
(Function<Integer, CompletableFuture<T>> requestReplica, RegionLocations locs, CompletableFuture<T> future, Optional<MetricsConnection> metrics) private boolean
AsyncNonMetaRegionLocator.TableCache.tryComplete
(AsyncNonMetaRegionLocator.LocateRequest req, CompletableFuture<RegionLocations> future, RegionLocations locations, List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) Modifier and TypeMethodDescription(package private) static void
MetaCacheUtil.cleanProblematicOverlappedRegions
(RegionLocations locations, ConcurrentNavigableMap<byte[], RegionLocations> cache) When caching a location, the region may have been the result of a merge.private void
ZKConnectionRegistry.getMetaRegionLocation
(CompletableFuture<RegionLocations> future, List<String> metaReplicaZNodes) Deprecated.private boolean
AsyncNonMetaRegionLocator.TableCache.tryComplete
(AsyncNonMetaRegionLocator.LocateRequest req, CompletableFuture<RegionLocations> future, RegionLocations locations, List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) private static void
ZKConnectionRegistry.tryComplete
(org.apache.commons.lang3.mutable.MutableInt remaining, Collection<HRegionLocation> locs, CompletableFuture<RegionLocations> future) Deprecated.ModifierConstructorDescriptionRegionLocationsFutureResult
(CompletableFuture<RegionLocations> future, RegionLocations result, Throwable e) ModifierConstructorDescriptionRegionLocationsFutureResult
(CompletableFuture<RegionLocations> future, RegionLocations result, Throwable e) -
Uses of RegionLocations in org.apache.hadoop.hbase.master.janitor
Modifier and TypeMethodDescriptionprivate void
ReportMakingVisitor.checkServer
(RegionLocations locations) Run through referenced servers and save off unknown and the dead.