Uses of Class
org.apache.hadoop.hbase.HRegionLocation
Packages that use HRegionLocation
-
Uses of HRegionLocation in org.apache.hadoop.hbase
Fields in org.apache.hadoop.hbase declared as HRegionLocationFields in org.apache.hadoop.hbase with type parameters of type HRegionLocationModifier and TypeFieldDescriptionprivate final CopyOnWriteArrayMap<Integer,HRegionLocation> MetaRegionLocationCache.cachedMetaLocationsCached meta region locations indexed by replica ID.Methods in org.apache.hadoop.hbase that return HRegionLocationModifier and TypeMethodDescriptionRegionLocations.getDefaultRegionLocation()private HRegionLocationMetaRegionLocationCache.getMetaRegionLocation(int replicaId) Gets the HRegionLocation for a given meta replica ID.private static HRegionLocationAsyncMetaTableAccessor.getRegionLocation(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.static HRegionLocationMetaTableAccessor.getRegionLocation(Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic HRegionLocationMetaTableAccessor.getRegionLocation(Connection connection, RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionprivate static HRegionLocationMetaTableAccessor.getRegionLocation(Result r, RegionInfo regionInfo, int replicaId) Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.RegionLocations.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 HRegionLocationRegionLocations.selectRegionLocation(HRegionLocation oldLocation, HRegionLocation location, boolean checkForEquals, boolean force) Methods in org.apache.hadoop.hbase that return types with arguments of type HRegionLocationModifier and TypeMethodDescriptionMetaRegionLocationCache.getMetaRegionLocations()Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.static CompletableFuture<Optional<HRegionLocation>>AsyncMetaTableAccessor.getRegionLocation(AsyncTable<?> metaTable, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic CompletableFuture<Optional<HRegionLocation>>AsyncMetaTableAccessor.getRegionLocationWithEncodedName(AsyncTable<?> metaTable, byte[] encodedRegionName) Returns the HRegionLocation from meta for the given encoded region namestatic CompletableFuture<List<HRegionLocation>>AsyncMetaTableAccessor.getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable, TableName tableName) Used to get all region locations for the specific tableRegionLocations.iterator()Methods in org.apache.hadoop.hbase with parameters of type HRegionLocationModifier and TypeMethodDescriptionintHRegionLocation.compareTo(HRegionLocation o) RegionLocations.remove(HRegionLocation location) Removes the given location from the listprivate HRegionLocationRegionLocations.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.Constructors in org.apache.hadoop.hbase with parameters of type HRegionLocationModifierConstructorDescriptionRegionLocations(HRegionLocation... locations) Constructs the region location list.Constructor parameters in org.apache.hadoop.hbase with type arguments of type HRegionLocation -
Uses of HRegionLocation in org.apache.hadoop.hbase.client
Fields in org.apache.hadoop.hbase.client declared as HRegionLocationModifier and TypeFieldDescriptionprivate final HRegionLocationHTableMultiplexer.FlushWorker.addrfinal HRegionLocationAsyncBatchRpcRetryingCaller.RegionRequest.locfinal HRegionLocationAsyncClientScanner.OpenScannerResponse.locprivate HRegionLocationAsyncRpcRetryingCallerFactory.ScanSingleRegionCallerBuilder.locprivate final HRegionLocationAsyncScanSingleRegionRpcRetryingCaller.locprotected HRegionLocationRegionAdminServiceCallable.locationprotected HRegionLocationRegionServerCallable.locationSome subclasses want to set their own location.Fields in org.apache.hadoop.hbase.client with type parameters of type HRegionLocationModifier and TypeFieldDescriptionprivate final Map<HRegionLocation,HTableMultiplexer.FlushWorker> HTableMultiplexer.serverToFlushWorkerMapDeprecated.The map between each region server to its flush workerMethods in org.apache.hadoop.hbase.client that return HRegionLocationModifier and TypeMethodDescriptionprivate HRegionLocationAsyncNonMetaRegionLocator.getCachedLocation(HRegionLocation loc) private HRegionLocationAsyncMetaRegionLocator.getCacheLocation(HRegionLocation loc) protected HRegionLocationMultiServerCallable.getLocation()RegionAdminServiceCallable.getLocation(boolean useCache) protected HRegionLocationRegionServerCallable.getLocation()protected final HRegionLocationScannerCallable.getLocationForReplica(RegionLocations locs) ClusterConnection.getRegionLocation(TableName tableName, byte[] row, boolean reload) Find region location hosting passed rowConnectionImplementation.getRegionLocation(TableName tableName, byte[] row, boolean reload) HRegionLocator.getRegionLocation(byte[] row, int replicaId, boolean reload) default HRegionLocationRegionLocator.getRegionLocation(byte[] row) Finds the region on which the given row is being served.default HRegionLocationRegionLocator.getRegionLocation(byte[] row, boolean reload) Finds the region on which the given row is being served.default HRegionLocationRegionLocator.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.private HRegionLocationAsyncRequestFutureImpl.getReplicaLocationOrFail(Action action) ClusterConnection.locateRegion(byte[] regionName) Gets the location of the region of regionName.ClusterConnection.locateRegion(TableName tableName, byte[] row) Find the location of the region of tableName that row lives in.ConnectionImplementation.locateRegion(byte[] regionName) ConnectionImplementation.locateRegion(TableName tableName, byte[] row) ClusterConnection.relocateRegion(TableName tableName, byte[] row) 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) Methods in org.apache.hadoop.hbase.client that return types with arguments of type HRegionLocationModifier and TypeMethodDescriptionAsyncTableRegionLocator.getAllRegionLocations()Retrieves all of the regions associated with this table.AsyncTableRegionLocatorImpl.getAllRegionLocations()HRegionLocator.getAllRegionLocations()RegionLocator.getAllRegionLocations()Retrieves all of the regions associated with this table.private Pair<List<byte[]>,List<HRegionLocation>> HTable.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>> HTable.getKeysAndRegionsInRange(byte[] startKey, byte[] endKey, boolean includeEndKey, boolean reload) Get the corresponding start keys and regions for an arbitrary range of keys.(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 givenreplicaIdon which the given row is being served.AsyncTableRegionLocator.getRegionLocation(byte[] row, int replicaId, boolean reload) Finds the region with the givenreplicaIdon 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) HRegionLocator.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.private CompletableFuture<List<HRegionLocation>>RawAsyncHBaseAdmin.getTableHRegionLocations(TableName tableName) List all region locations for the specific table.private Pair<HRegionLocation,byte[]> ReversedScannerCallable.locateLastRegionInRange(byte[] startKey, byte[] endKey) Get the last region before the endkey, which will be used to execute the reverse scanClusterConnection.locateRegions(TableName tableName) Gets the locations of all regions in the specified table, tableName.ClusterConnection.locateRegions(TableName tableName, boolean useCache, boolean offlined) Gets the locations of all regions in the specified table, tableName.ConnectionImplementation.locateRegions(TableName tableName) ConnectionImplementation.locateRegions(TableName tableName, boolean useCache, boolean offlined) Methods in org.apache.hadoop.hbase.client with parameters of type HRegionLocationModifier and TypeMethodDescriptionvoidAsyncBatchRpcRetryingCaller.ServerRequest.addAction(HRegionLocation loc, Action action) private voidAsyncMetaRegionLocator.addLocationToCache(HRegionLocation loc) (package private) voidAsyncNonMetaRegionLocator.addLocationToCache(HRegionLocation loc) private voidConnectionImplementation.cacheLocation(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.voidMetaCache.cacheLocation(TableName tableName, ServerName source, HRegionLocation location) Put a newly discovered HRegionLocation into the cache.private voidAsyncSingleRequestRpcRetryingCaller.call(HRegionLocation loc) AsyncSingleRequestRpcRetryingCaller.Callable.call(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) private static <REQ,PREQ, PRESP, RESP>
CompletableFuture<RESP>RawAsyncTableImpl.call(HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub, REQ req, RawAsyncTableImpl.Converter<PREQ, byte[], REQ> reqConvert, RawAsyncTableImpl.RpcCall<PRESP, PREQ> rpcCall, RawAsyncTableImpl.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 booleanAsyncRegionLocatorHelper.canUpdateOnError(HRegionLocation loc, HRegionLocation oldLoc) (package private) static RegionLocationsAsyncRegionLocatorHelper.createRegionLocations(HRegionLocation loc) private HRegionLocationAsyncNonMetaRegionLocator.getCachedLocation(HRegionLocation loc) private HRegionLocationAsyncMetaRegionLocator.getCacheLocation(HRegionLocation loc) (package private) LinkedBlockingQueue<HTableMultiplexer.PutStatus>HTableMultiplexer.getQueue(HRegionLocation addr) Deprecated.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, RawAsyncTableImpl.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest, byte[], REQ> reqConvert, RawAsyncTableImpl.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, RawAsyncTableImpl.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, RawAsyncTableImpl.Converter<RESP, HBaseRpcController, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateResponse> respConverter) voidSimpleRequestController.RequestHeapSizeChecker.notifyFinal(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) voidSimpleRequestController.RequestRowsChecker.notifyFinal(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) voidSimpleRequestController.RowChecker.notifyFinal(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) Add the final ReturnCode to the checker.voidSimpleRequestController.SubmittedSizeChecker.notifyFinal(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) voidSimpleRequestController.TaskCountChecker.notifyFinal(RequestController.ReturnCode code, HRegionLocation loc, long heapSizeOfRow) voidCatalogReplicaLoadBalanceSelector.onError(HRegionLocation loc) This method is called when input location is stale, i.e, when clients run into org.apache.hadoop.hbase.NotServingRegionException.voidCatalogReplicaLoadBalanceSimpleSelector.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<com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.CoprocessorCallback<R> callback, List<HRegionLocation> locs, byte[] endKey, boolean endKeyInclusive, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, HRegionLocation loc, Throwable error) booleanAsyncRegionLocationCache.remove(HRegionLocation loc) Removes the location from the cache if it exists and can be removed.private voidAsyncMetaRegionLocator.removeLocationFromCache(HRegionLocation loc) private voidAsyncNonMetaRegionLocator.removeLocationFromCache(HRegionLocation loc) (package private) static RegionLocationsAsyncRegionLocatorHelper.replaceRegionLocation(RegionLocations oldLocs, HRegionLocation loc) Create a newRegionLocationsbased on the givenoldLocs, and replace the location for the givenreplicaIdwith the givenloc.(package private) booleanHTableMultiplexer.FlushWorker.resubmitFailedPut(HTableMultiplexer.PutStatus ps, HRegionLocation oldLoc) private CompletableFuture<com.google.protobuf.Message>RegionCoprocessorRpcChannelImpl.rpcCall(com.google.protobuf.Descriptors.MethodDescriptor method, com.google.protobuf.Message request, com.google.protobuf.Message responsePrototype, HBaseRpcController controller, HRegionLocation loc, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ClientService.Interface stub) protected voidRegionServerCallable.setLocation(HRegionLocation location) (package private) voidAsyncMetaRegionLocator.updateCachedLocationOnError(HRegionLocation loc, Throwable exception) (package private) voidAsyncNonMetaRegionLocator.updateCachedLocationOnError(HRegionLocation loc, Throwable exception) (package private) voidAsyncRegionLocator.updateCachedLocationOnError(HRegionLocation loc, Throwable exception) (package private) static voidAsyncRegionLocatorHelper.updateCachedLocationOnError(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) private voidAsyncNonMetaRegionLocator.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, RawAsyncTableImpl.Converter<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.MutateRequest, byte[], REQ> reqConvert) Method parameters in org.apache.hadoop.hbase.client with type arguments of type HRegionLocationModifier and TypeMethodDescriptionprivate booleanRawAsyncHBaseAdmin.compareRegionsWithSplitKeys(List<HRegionLocation> locations, byte[][] splitKeys) HRegionLocator.getRegionNames(List<HRegionLocation> locations) private voidHTableMultiplexer.HTableMultiplexerStatus.initialize(Map<HRegionLocation, HTableMultiplexer.FlushWorker> serverToFlushWorkerMap) Deprecated.private <S,R> void RawAsyncTableImpl.onLocateComplete(Function<com.google.protobuf.RpcChannel, S> stubMaker, ServiceCaller<S, R> callable, AsyncTable.CoprocessorCallback<R> callback, List<HRegionLocation> locs, byte[] endKey, boolean endKeyInclusive, AtomicBoolean locateFinished, AtomicInteger unfinishedRequest, HRegionLocation loc, Throwable error) private static voidZKConnectionRegistry.tryComplete(org.apache.commons.lang3.mutable.MutableInt remaining, Collection<HRegionLocation> locs, CompletableFuture<RegionLocations> future) Deprecated.(package private) static voidAsyncRegionLocatorHelper.updateCachedLocationOnError(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) (package private) static voidAsyncRegionLocatorHelper.updateCachedLocationOnError(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) (package private) static voidAsyncRegionLocatorHelper.updateCachedLocationOnError(HRegionLocation loc, Throwable exception, Function<HRegionLocation, HRegionLocation> cachedLocationSupplier, Consumer<HRegionLocation> addToCache, Consumer<HRegionLocation> removeFromCache, MetricsConnection metrics) Constructors in org.apache.hadoop.hbase.client with parameters of type HRegionLocationModifierConstructorDescriptionAsyncScanSingleRegionRpcRetryingCaller(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) FlushWorker(org.apache.hadoop.conf.Configuration conf, ClusterConnection conn, HRegionLocation addr, HTableMultiplexer htableMultiplexer, int perRegionServerBufferQueueSize, ExecutorService pool, ScheduledExecutorService executor) 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) RegionAdminServiceCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row) RegionAdminServiceCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, HRegionLocation location, TableName tableName, byte[] row, int replicaId) ReplicaRegionServerCallable(int id, HRegionLocation location) Constructor parameters in org.apache.hadoop.hbase.client with type arguments of type HRegionLocationModifierConstructorDescriptionHTableMultiplexerStatus(Map<HRegionLocation, HTableMultiplexer.FlushWorker> serverToFlushWorkerMap) Deprecated. -
Uses of HRegionLocation in org.apache.hadoop.hbase.master.assignment
Methods in org.apache.hadoop.hbase.master.assignment that return HRegionLocationModifier and TypeMethodDescriptionRegionStates.checkReopened(HRegionLocation oldLoc) Check whether the region has been reopened.private HRegionLocationRegionStates.createRegionForReopen(RegionStateNode node) Methods in org.apache.hadoop.hbase.master.assignment that return types with arguments of type HRegionLocationModifier and TypeMethodDescriptionRegionStates.getRegionsOfTableForReopen(TableName tableName) Get the regions to be reopened when modifying a table.Methods in org.apache.hadoop.hbase.master.assignment with parameters of type HRegionLocationModifier and TypeMethodDescriptionRegionStates.checkReopened(HRegionLocation oldLoc) Check whether the region has been reopened. -
Uses of HRegionLocation in org.apache.hadoop.hbase.master.http
Constructors in org.apache.hadoop.hbase.master.http with parameters of type HRegionLocation -
Uses of HRegionLocation in org.apache.hadoop.hbase.master.procedure
Fields in org.apache.hadoop.hbase.master.procedure with type parameters of type HRegionLocationModifier and TypeFieldDescriptionprivate List<HRegionLocation>ReopenTableRegionsProcedure.currentRegionBatchprivate List<HRegionLocation>ReopenTableRegionsProcedure.regionsMethods in org.apache.hadoop.hbase.master.procedure that return types with arguments of type HRegionLocationModifier and TypeMethodDescriptionprivate List<HRegionLocation>ReopenTableRegionsProcedure.filterReopened(MasterProcedureEnv env, List<HRegionLocation> regionsToCheck) private List<HRegionLocation>ReopenTableRegionsProcedure.getRegionLocationsForReopen(List<HRegionLocation> tableRegionsForReopen) Methods in org.apache.hadoop.hbase.master.procedure with parameters of type HRegionLocationModifier and TypeMethodDescriptionprivate booleanReopenTableRegionsProcedure.canSchedule(MasterProcedureEnv env, HRegionLocation loc) Method parameters in org.apache.hadoop.hbase.master.procedure with type arguments of type HRegionLocationModifier and TypeMethodDescriptionprivate List<HRegionLocation>ReopenTableRegionsProcedure.filterReopened(MasterProcedureEnv env, List<HRegionLocation> regionsToCheck) private List<HRegionLocation>ReopenTableRegionsProcedure.getRegionLocationsForReopen(List<HRegionLocation> tableRegionsForReopen) private StateMachineProcedure.FlowReopenTableRegionsProcedure.reopenIfSchedulable(MasterProcedureEnv env, List<HRegionLocation> regionsToReopen, boolean shouldBatchBackoff) -
Uses of HRegionLocation in org.apache.hadoop.hbase.replication.regionserver
Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type HRegionLocationModifierConstructorDescriptionRegionReplicaReplayCallable(ClusterConnection connection, RpcControllerFactory rpcControllerFactory, TableName tableName, HRegionLocation location, RegionInfo regionInfo, byte[] row, List<WAL.Entry> entries, AtomicLong skippedEntries) -
Uses of HRegionLocation in org.apache.hadoop.hbase.thrift2
Methods in org.apache.hadoop.hbase.thrift2 with parameters of type HRegionLocationModifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.thrift2.generated.THRegionLocationThriftUtilities.regionLocationFromHBase(HRegionLocation hrl) Method parameters in org.apache.hadoop.hbase.thrift2 with type arguments of type HRegionLocationModifier and TypeMethodDescriptionstatic List<org.apache.hadoop.hbase.thrift2.generated.THRegionLocation>ThriftUtilities.regionLocationsFromHBase(List<HRegionLocation> locations)