Uses of Class
org.apache.hadoop.hbase.RegionLocations
Packages that use RegionLocations
Package
Description
Provides HBase Client
-
Uses of RegionLocations in org.apache.hadoop.hbase
Fields in org.apache.hadoop.hbase declared as RegionLocationsModifier and TypeFieldDescriptionprivate RegionLocationsClientMetaTableAccessor.CollectRegionLocationsVisitor.currentMethods in org.apache.hadoop.hbase that return RegionLocationsModifier and TypeMethodDescriptionstatic RegionLocationsCatalogFamilyFormat.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.Methods in org.apache.hadoop.hbase that return types with arguments of type RegionLocationsModifier and TypeMethodDescriptionprivate static Optional<RegionLocations>ClientMetaTableAccessor.getRegionLocations(Result r) Returns an HRegionLocationList extracted from the result.Methods in org.apache.hadoop.hbase with parameters of type RegionLocationsModifier 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
Fields in org.apache.hadoop.hbase.client declared as RegionLocationsModifier and TypeFieldDescriptionprivate final RegionLocationsAsyncNonMetaRegionLocator.RegionLocationsFutureResult.resultFields in org.apache.hadoop.hbase.client with type parameters of type RegionLocationsModifier and TypeFieldDescriptionprivate final Map<AsyncNonMetaRegionLocator.LocateRequest,CompletableFuture<RegionLocations>> AsyncNonMetaRegionLocator.TableCache.allRequestsprivate final ConcurrentNavigableMap<byte[],RegionLocations> AsyncRegionLocationCache.cacheprivate final CompletableFuture<RegionLocations>AsyncNonMetaRegionLocator.RegionLocationsFutureResult.futureprivate final AtomicReference<RegionLocations>AsyncMetaRegionLocator.metaRegionLocationsprivate final AtomicReference<CompletableFuture<RegionLocations>>AsyncMetaRegionLocator.metaRelocateFutureMethods in org.apache.hadoop.hbase.client that return RegionLocationsModifier and TypeMethodDescriptionAsyncRegionLocationCache.add(RegionLocations locs) Add the given locations to the cache, merging with existing if necessary.(package private) static RegionLocationsAsyncRegionLocatorHelper.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) RegionLocationsAsyncMetaRegionLocator.getRegionLocationInCache()(package private) RegionLocationsAsyncNonMetaRegionLocator.getRegionLocationInCache(TableName tableName, byte[] row) (package private) RegionLocationsAsyncRegionLocator.getRegionLocationInCache(TableName tableName, byte[] row) private RegionLocationsAsyncNonMetaRegionLocator.locateInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId, RegionLocateType locateType) private RegionLocationsAsyncNonMetaRegionLocator.locateRowBeforeInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) private RegionLocationsAsyncNonMetaRegionLocator.locateRowInCache(AsyncNonMetaRegionLocator.TableCache tableCache, byte[] row, int replicaId) (package private) static RegionLocationsAsyncRegionLocatorHelper.removeRegionLocation(RegionLocations oldLocs, int replicaId) Create a newRegionLocationsbased on the givenoldLocs, and remove the location for the givenreplicaId.(package private) static RegionLocationsAsyncRegionLocatorHelper.replaceRegionLocation(RegionLocations oldLocs, HRegionLocation loc) Create a newRegionLocationsbased on the givenoldLocs, and replace the location for the givenreplicaIdwith the givenloc.private static RegionLocationsAbstractRpcBasedConnectionRegistry.transformMetaRegionLocations(org.apache.hadoop.hbase.shaded.protobuf.generated.RegistryProtos.GetMetaRegionLocationsResponse resp) Simple helper to transform the result of getMetaRegionLocations() rpc.Methods in org.apache.hadoop.hbase.client that return types with arguments of type RegionLocationsModifier 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) Methods in org.apache.hadoop.hbase.client with parameters of type RegionLocationsModifier and TypeMethodDescriptionAsyncRegionLocationCache.add(RegionLocations locs) Add the given locations to the cache, merging with existing if necessary.private voidAsyncRegionLocationCache.cleanProblematicOverlappedRegions(RegionLocations locations) When caching a location, the region may have been the result of a merge.AsyncNonMetaRegionLocator.TableCache.clearCompletedRequests(RegionLocations locations) private voidAsyncNonMetaRegionLocator.complete(TableName tableName, AsyncNonMetaRegionLocator.LocateRequest req, RegionLocations locs, Throwable error) AsyncRegionLocator.getRegionNames(RegionLocations locs) private booleanAsyncRegionLocationCache.isEqual(RegionLocations locs1, RegionLocations locs2) (package private) static booleanAsyncRegionLocatorHelper.isGood(RegionLocations locs, int replicaId) (package private) static RegionLocationsAsyncRegionLocatorHelper.removeRegionLocation(RegionLocations oldLocs, int replicaId) Create a newRegionLocationsbased on the givenoldLocs, and remove the location for the givenreplicaId.(package private) static RegionLocationsAsyncRegionLocatorHelper.replaceRegionLocation(RegionLocations oldLocs, HRegionLocation loc) Create a newRegionLocationsbased on the givenoldLocs, and replace the location for the givenreplicaIdwith the givenloc.private static <T> voidConnectionUtils.sendRequestsToSecondaryReplicas(Function<Integer, CompletableFuture<T>> requestReplica, RegionLocations locs, CompletableFuture<T> future, Optional<MetricsConnection> metrics) private booleanAsyncNonMetaRegionLocator.TableCache.tryComplete(AsyncNonMetaRegionLocator.LocateRequest req, CompletableFuture<RegionLocations> future, RegionLocations locations, List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) Method parameters in org.apache.hadoop.hbase.client with type arguments of type RegionLocationsModifier and TypeMethodDescriptionprivate voidZKConnectionRegistry.getMetaRegionLocation(CompletableFuture<RegionLocations> future, List<String> metaReplicaZNodes) Deprecated.private booleanAsyncNonMetaRegionLocator.TableCache.tryComplete(AsyncNonMetaRegionLocator.LocateRequest req, CompletableFuture<RegionLocations> future, RegionLocations locations, List<AsyncNonMetaRegionLocator.RegionLocationsFutureResult> futureResultList) private static voidZKConnectionRegistry.tryComplete(org.apache.commons.lang3.mutable.MutableInt remaining, HRegionLocation[] locs, CompletableFuture<RegionLocations> future) Deprecated.Constructors in org.apache.hadoop.hbase.client with parameters of type RegionLocationsModifierConstructorDescriptionRegionLocationsFutureResult(CompletableFuture<RegionLocations> future, RegionLocations result, Throwable e) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type RegionLocationsModifierConstructorDescriptionRegionLocationsFutureResult(CompletableFuture<RegionLocations> future, RegionLocations result, Throwable e) -
Uses of RegionLocations in org.apache.hadoop.hbase.master.janitor
Methods in org.apache.hadoop.hbase.master.janitor with parameters of type RegionLocationsModifier and TypeMethodDescriptionprivate voidReportMakingVisitor.checkServer(RegionLocations locations) Run through referenced servers and save off unknown and the dead.