Uses of Class
org.apache.hadoop.hbase.RegionLocations
Package
Description
Provides HBase Client
-
Uses of RegionLocations in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprivate RegionLocations
ClientMetaTableAccessor.CollectRegionLocationsVisitor.current
Modifier and TypeMethodDescriptionstatic RegionLocations
CatalogFamilyFormat.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>
ClientMetaTableAccessor.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 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) 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
AsyncMetaRegionLocator.getRegionLocationInCache()
(package private) RegionLocations
AsyncNonMetaRegionLocator.getRegionLocationInCache
(TableName tableName, byte[] row) (package private) RegionLocations
AsyncRegionLocator.getRegionLocationInCache
(TableName tableName, byte[] row) private RegionLocations
AsyncNonMetaRegionLocator.locateInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) private RegionLocations
AsyncNonMetaRegionLocator.locateRowBeforeInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private RegionLocations
AsyncNonMetaRegionLocator.locateRowInCache
(AsyncNonMetaRegionLocator.TableCache tableCache, 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).ShortCircuitConnectionRegistry.getMetaRegionLocations()
ZKConnectionRegistry.getMetaRegionLocations()
Deprecated.AsyncClusterConnection.getRegionLocations
(TableName tableName, byte[] row, boolean reload) Return all the replicas for a region.AsyncClusterConnectionImpl.getRegionLocations
(TableName tableName, byte[] row, boolean reload) (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) Modifier and TypeMethodDescriptionAsyncRegionLocationCache.add
(RegionLocations locs) Add the given locations to the cache, merging with existing if necessary.private void
AsyncRegionLocationCache.cleanProblematicOverlappedRegions
(RegionLocations locations) 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) 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 TypeMethodDescriptionprivate 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, 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.