Uses of Class
org.apache.hadoop.hbase.HRegionLocation
-
Uses of HRegionLocation in org.apache.hadoop.hbase
Modifier and TypeFieldDescriptionprivate final CopyOnWriteArrayMap<Integer,
HRegionLocation> MetaRegionLocationCache.cachedMetaLocations
Cached meta region locations indexed by replica ID.Modifier and TypeMethodDescriptionRegionLocations.getDefaultRegionLocation()
private HRegionLocation
MetaRegionLocationCache.getMetaRegionLocation
(int replicaId) Gets the HRegionLocation for a given meta replica ID.static HRegionLocation
CatalogFamilyFormat.getRegionLocation
(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.static HRegionLocation
MetaTableAccessor.getRegionLocation
(Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic HRegionLocation
MetaTableAccessor.getRegionLocation
(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionRegionLocations.getRegionLocation()
Returns the first not-null region location in the listRegionLocations.getRegionLocation
(int replicaId) RegionLocations.getRegionLocationByRegionName
(byte[] regionName) Returns the region location from the list for matching regionName, which can be regionName or encodedRegionNameRegionLocations.getRegionLocations()
private HRegionLocation
RegionLocations.selectRegionLocation
(HRegionLocation oldLocation, HRegionLocation location, boolean checkForEquals, boolean force) Modifier and TypeMethodDescriptionMetaRegionLocationCache.getMetaRegionLocations()
Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.static CompletableFuture<Optional<HRegionLocation>>
ClientMetaTableAccessor.getRegionLocation
(AsyncTable<?> metaTable, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic CompletableFuture<Optional<HRegionLocation>>
ClientMetaTableAccessor.getRegionLocationWithEncodedName
(AsyncTable<?> metaTable, byte[] encodedRegionName) Returns the HRegionLocation from meta for the given encoded region namestatic CompletableFuture<List<HRegionLocation>>
ClientMetaTableAccessor.getTableHRegionLocations
(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName) Used to get all region locations for the specific tableRegionLocations.iterator()
Modifier and TypeMethodDescriptionint
HRegionLocation.compareTo
(HRegionLocation o) RegionLocations.remove
(HRegionLocation location) Removes the given location from the listprivate HRegionLocation
RegionLocations.selectRegionLocation
(HRegionLocation oldLocation, HRegionLocation location, boolean checkForEquals, boolean force) 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.ModifierConstructorDescriptionRegionLocations
(HRegionLocation... locations) Constructs the region location list. -
Uses of HRegionLocation in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionfinal HRegionLocation
AsyncBatchRpcRetryingCaller.RegionRequest.loc
final HRegionLocation
AsyncClientScanner.OpenScannerResponse.loc
private HRegionLocation
AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.loc
private final HRegionLocation
AsyncScanSingleRegionRpcRetryingCaller.loc
Modifier and TypeMethodDescriptionprivate HRegionLocation
AsyncNonMetaRegionLocator.getCachedLocation
(HRegionLocation loc) private HRegionLocation
AsyncMetaRegionLocator.getCacheLocation
(HRegionLocation loc) default HRegionLocation
RegionLocator.getRegionLocation
(byte[] row) Finds the region on which the given row is being served.default HRegionLocation
RegionLocator.getRegionLocation
(byte[] row, boolean reload) Finds the region on which the given row is being served.default HRegionLocation
RegionLocator.getRegionLocation
(byte[] row, int replicaId) Finds the region with the given replica id on which the given row is being served.RegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) Finds the region with the given replica id on which the given row is being served.RegionLocatorOverAsyncTableRegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) Modifier and TypeMethodDescriptionAsyncTableRegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.AsyncTableRegionLocatorImpl.getAllRegionLocations()
RegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.RegionLocatorOverAsyncTableRegionLocator.getAllRegionLocations()
private Pair<List<byte[]>,
List<HRegionLocation>> TableOverAsyncTable.getKeysAndRegionsInRange
(byte[] startKey, byte[] endKey, boolean includeEndKey) Get the corresponding start keys and regions for an arbitrary range of keys.private Pair<List<byte[]>,
List<HRegionLocation>> TableOverAsyncTable.getKeysAndRegionsInRange
(byte[] startKey, byte[] endKey, boolean includeEndKey, boolean reload) Get the corresponding start keys and regions for an arbitrary range of keys.ConnectionRegistryEndpoint.getMetaLocations()
Get the location of meta regions.(package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, int replicaId, RegionLocateType type, boolean reload, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, int replicaId, RegionLocateType type, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, RegionLocateType type, boolean reload, long timeoutNs) (package private) CompletableFuture<HRegionLocation>
AsyncRegionLocator.getRegionLocation
(TableName tableName, byte[] row, RegionLocateType type, long timeoutNs) default CompletableFuture<HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row) Finds the region on which the given row is being served.default CompletableFuture<HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row, boolean reload) Finds the region on which the given row is being served.default CompletableFuture<HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row, int replicaId) Finds the region with the givenreplicaId
on which the given row is being served.AsyncTableRegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) Finds the region with the givenreplicaId
on which the given row is being served.AsyncTableRegionLocatorImpl.getRegionLocation
(byte[] row, int replicaId, boolean reload) (package private) CompletableFuture<HRegionLocation>
RawAsyncHBaseAdmin.getRegionLocation
(byte[] regionNameOrEncodedRegionName) Get the region location for the passed region name.default CompletableFuture<List<HRegionLocation>>
AsyncTableRegionLocator.getRegionLocations
(byte[] row) Find all the replicas for the region on which the given row is being served.AsyncTableRegionLocator.getRegionLocations
(byte[] row, boolean reload) Find all the replicas for the region on which the given row is being served.AsyncTableRegionLocatorImpl.getRegionLocations
(byte[] row, boolean reload) default List<HRegionLocation>
RegionLocator.getRegionLocations
(byte[] row) Find all the replicas for the region on which the given row is being served.RegionLocator.getRegionLocations
(byte[] row, boolean reload) Find all the replicas for the region on which the given row is being served.RegionLocatorOverAsyncTableRegionLocator.getRegionLocations
(byte[] row, boolean reload) private CompletableFuture<List<HRegionLocation>>
RawAsyncHBaseAdmin.getTableHRegionLocations
(TableName tableName) List all region locations for the specific table.Modifier and TypeMethodDescriptionvoid
AsyncBatchRpcRetryingCaller.ServerRequest.addAction
(HRegionLocation loc, Action action) private void
AsyncMetaRegionLocator.addLocationToCache
(HRegionLocation loc) (package private) void
AsyncNonMetaRegionLocator.addLocationToCache
(HRegionLocation loc) private void
AsyncRegionReplicationRetryingCaller.call
(HRegionLocation loc) private void
AsyncSingleRequestRpcRetryingCaller.call
(HRegionLocation loc) AsyncSingleRequestRpcRetryingCaller.Callable.call
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) (package private) static <REQ,
PREQ, PRESP, RESP>
CompletableFuture<RESP>ConnectionUtils.call
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, REQ req, ConnectionUtils.Converter<PREQ, byte[], REQ> reqConvert, ConnectionUtils.RpcCall<PRESP, PREQ> rpcCall, ConnectionUtils.Converter<RESP, HBaseRpcController, PRESP> respConverter) AsyncClientScanner.callOpenScanner
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) SimpleRequestController.RequestHeapSizeChecker.canTakeOperation
(HRegionLocation loc, long heapSizeOfRow) SimpleRequestController.RequestRowsChecker.canTakeOperation
(HRegionLocation loc, long heapSizeOfRow) SimpleRequestController.RowChecker.canTakeOperation
(HRegionLocation loc, long heapSizeOfRow) SimpleRequestController.SubmittedSizeChecker.canTakeOperation
(HRegionLocation loc, long heapSizeOfRow) SimpleRequestController.TaskCountChecker.canTakeOperation
(HRegionLocation loc, long heapSizeOfRow) 1) check the regions is allowed.RequestController.Checker.canTakeRow
(HRegionLocation loc, Row row) Checks the data whether it is valid to submit.(package private) static boolean
AsyncRegionLocatorHelper.canUpdateOnError
(HRegionLocation loc, HRegionLocation oldLoc) (package private) static RegionLocations
AsyncRegionLocatorHelper.createRegionLocations
(HRegionLocation loc) private HRegionLocation
AsyncNonMetaRegionLocator.getCachedLocation
(HRegionLocation loc) private HRegionLocation
AsyncMetaRegionLocator.getCacheLocation
(HRegionLocation loc) AsyncRegionLocator.getRegionNames
(HRegionLocation location) AsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.location
(HRegionLocation loc) private static <REQ,
RESP> CompletableFuture<RESP> RawAsyncTableImpl.mutate
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, REQ req, ConnectionUtils.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest, byte[], REQ> reqConvert, ConnectionUtils.Converter<RESP, HBaseRpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse> respConverter) private <RES,
RESP> CompletableFuture<RESP> RawAsyncTableImpl.mutateRow
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, RowMutations mutation, ConnectionUtils.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MultiRequest, byte[], RowMutations> reqConvert, Function<RES, RESP> respConverter) private <REQ,
RESP> CompletableFuture<RESP> RawAsyncTableImpl.noncedMutate
(long nonceGroup, long nonce, HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, REQ req, RawAsyncTableImpl.NoncedConverter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest, byte[], REQ> reqConvert, ConnectionUtils.Converter<RESP, HBaseRpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse> respConverter) void
SimpleRequestController.RequestHeapSizeChecker.notifyFinal
(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) void
SimpleRequestController.RequestRowsChecker.notifyFinal
(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) void
SimpleRequestController.RowChecker.notifyFinal
(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) Add the final ReturnCode to the checker.void
SimpleRequestController.SubmittedSizeChecker.notifyFinal
(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) void
SimpleRequestController.TaskCountChecker.notifyFinal
(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) private void
AsyncRegionReplicationRetryingCaller.onComplete
(HRegionLocation loc) void
CatalogReplicaLoadBalanceSelector.onError
(HRegionLocation loc) This method is called when input location is stale, i.e, when clients run into org.apache.hadoop.hbase.NotServingRegionException.void
CatalogReplicaLoadBalanceSimpleSelector.onError
(HRegionLocation loc) When a client runs into RegionNotServingException, it will call this method to update Selector's internal state.private <S,
R> void RawAsyncTableImpl.onLocateComplete
(Function<org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.PartialResultCoprocessorCallback<S, R> callback, byte[] endKey, boolean endKeyInclusive, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, HRegionLocation loc, Throwable error) boolean
AsyncRegionLocationCache.remove
(HRegionLocation loc) Removes the location from the cache if it exists and can be removed.private void
AsyncMetaRegionLocator.removeLocationFromCache
(HRegionLocation loc) private void
AsyncNonMetaRegionLocator.removeLocationFromCache
(HRegionLocation loc) (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 CompletableFuture<org.apache.hbase.thirdparty.com.google.protobuf.Message>
RegionCoprocessorRpcChannelImpl.rpcCall
(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype, HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) private static void
ZKConnectionRegistry.tryComplete
(org.apache.commons.lang3.mutable.MutableInt remaining, HRegionLocation[] locs, CompletableFuture<RegionLocations> future) Deprecated.(package private) void
AsyncMetaRegionLocator.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception) (package private) void
AsyncNonMetaRegionLocator.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception) (package private) void
AsyncRegionLocator.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception) (package private) static void
AsyncRegionLocatorHelper.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) private void
AsyncNonMetaRegionLocator.updateMetaReplicaSelector
(HRegionLocation loc) private static <REQ> CompletableFuture<Void>
RawAsyncTableImpl.voidMutate
(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, REQ req, ConnectionUtils.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest, byte[], REQ> reqConvert) Modifier and TypeMethodDescription(package private) static void
AsyncRegionLocatorHelper.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) (package private) static void
AsyncRegionLocatorHelper.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) (package private) static void
AsyncRegionLocatorHelper.updateCachedLocationOnError
(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) ModifierConstructorDescriptionAsyncScanSingleRegionRpcRetryingCaller
(org.apache.hbase.thirdparty.io.netty.util.Timer retryTimer, AsyncConnectionImpl conn, Scan scan, ScanMetrics scanMetrics, long scannerId, ScanResultCache resultCache, AdvancedScanResultConsumer consumer, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, HRegionLocation loc, boolean isRegionServerRemote, int priority, long scannerLeaseTimeoutPeriodNs, long pauseNs, long pauseNsForServerOverloaded, int maxAttempts, long scanTimeoutNs, long rpcTimeoutNs, int startLogErrorsCnt, Map<String, byte[]> requestAttributes) OpenScannerResponse
(HRegionLocation loc, boolean isRegionServerRemote, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, HBaseRpcController controller, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanResponse resp) -
Uses of HRegionLocation in org.apache.hadoop.hbase.master
-
Uses of HRegionLocation in org.apache.hadoop.hbase.master.assignment
Modifier and TypeMethodDescriptionRegionStates.checkReopened
(HRegionLocation oldLoc) Check whether the region has been reopened.private HRegionLocation
RegionStates.createRegionForReopen
(RegionStateNode node) Modifier and TypeMethodDescriptionRegionStates.getRegionsOfTableForReopen
(TableName tableName) Get the regions to be reopened when modifying a table.Modifier and TypeMethodDescriptionRegionStates.checkReopened
(HRegionLocation oldLoc) Check whether the region has been reopened. -
Uses of HRegionLocation in org.apache.hadoop.hbase.master.http
-
Uses of HRegionLocation in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate List<HRegionLocation>
ReopenTableRegionsProcedure.currentRegionBatch
private List<HRegionLocation>
ReopenTableRegionsProcedure.regions
Modifier and TypeMethodDescriptionprivate List<HRegionLocation>
ReopenTableRegionsProcedure.filterReopened
(MasterProcedureEnv env, List<HRegionLocation> regionsToCheck) private List<HRegionLocation>
ReopenTableRegionsProcedure.getRegionLocationsForReopen
(List<HRegionLocation> tableRegionsForReopen) Modifier and TypeMethodDescriptionprivate boolean
ReopenTableRegionsProcedure.canSchedule
(MasterProcedureEnv env, HRegionLocation loc) Modifier and TypeMethodDescriptionprivate List<HRegionLocation>
ReopenTableRegionsProcedure.filterReopened
(MasterProcedureEnv env, List<HRegionLocation> regionsToCheck) private List<HRegionLocation>
ReopenTableRegionsProcedure.getRegionLocationsForReopen
(List<HRegionLocation> tableRegionsForReopen) private StateMachineProcedure.Flow
ReopenTableRegionsProcedure.reopenIfSchedulable
(MasterProcedureEnv env, List<HRegionLocation> regionsToReopen, boolean shouldBatchBackoff) -
Uses of HRegionLocation in org.apache.hadoop.hbase.regionserver
-
Uses of HRegionLocation in org.apache.hadoop.hbase.thrift2
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.THRegionLocation
ThriftUtilities.regionLocationFromHBase
(HRegionLocation hrl) Modifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.THRegionLocation>
ThriftUtilities.regionLocationsFromHBase
(List<HRegionLocation> locations)