Uses of Class
org.apache.hadoop.hbase.HRegionLocation
Package
Description
Provides HBase Client
-
Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase
Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.HRegionLocation
RegionLocations.getDefaultRegionLocation()
static org.apache.hadoop.hbase.HRegionLocation
MetaTableAccessor.getRegionLocation
(org.apache.hadoop.hbase.client.Connection connection, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic org.apache.hadoop.hbase.HRegionLocation
MetaTableAccessor.getRegionLocation
(org.apache.hadoop.hbase.client.Connection connection, org.apache.hadoop.hbase.client.RegionInfo regionInfo) Returns the HRegionLocation from meta for the given regionorg.apache.hadoop.hbase.HRegionLocation
RegionLocations.getRegionLocation()
Returns the first not-null region location in the listorg.apache.hadoop.hbase.HRegionLocation
RegionLocations.getRegionLocation
(int replicaId) org.apache.hadoop.hbase.HRegionLocation
RegionLocations.getRegionLocationByRegionName
(byte[] regionName) Returns the region location from the list for matching regionName, which can be regionName or encodedRegionNameorg.apache.hadoop.hbase.HRegionLocation[]
RegionLocations.getRegionLocations()
Modifier and TypeMethodDescriptionMetaRegionLocationCache.getMetaRegionLocations()
Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.static CompletableFuture<Optional<org.apache.hadoop.hbase.HRegionLocation>>
AsyncMetaTableAccessor.getRegionLocation
(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, byte[] regionName) Returns the HRegionLocation from meta for the given regionstatic CompletableFuture<Optional<org.apache.hadoop.hbase.HRegionLocation>>
AsyncMetaTableAccessor.getRegionLocationWithEncodedName
(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, byte[] encodedRegionName) Returns the HRegionLocation from meta for the given encoded region namestatic CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
AsyncMetaTableAccessor.getTableHRegionLocations
(org.apache.hadoop.hbase.client.AsyncTable<org.apache.hadoop.hbase.client.AdvancedScanResultConsumer> metaTable, org.apache.hadoop.hbase.TableName tableName) Used to get all region locations for the specific tableIterator<org.apache.hadoop.hbase.HRegionLocation>
RegionLocations.iterator()
Modifier and TypeMethodDescriptionint
HRegionLocation.compareTo
(org.apache.hadoop.hbase.HRegionLocation o) org.apache.hadoop.hbase.RegionLocations
RegionLocations.remove
(org.apache.hadoop.hbase.HRegionLocation location) Removes the given location from the listorg.apache.hadoop.hbase.RegionLocations
RegionLocations.updateLocation
(org.apache.hadoop.hbase.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
(org.apache.hadoop.hbase.HRegionLocation... locations) Constructs the region location list.ModifierConstructorDescriptionRegionLocations
(Collection<org.apache.hadoop.hbase.HRegionLocation> locations) -
Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.client
Modifier and TypeFieldDescriptionprotected org.apache.hadoop.hbase.HRegionLocation
RegionAdminServiceCallable.location
protected org.apache.hadoop.hbase.HRegionLocation
RegionServerCallable.location
Some subclasses want to set their own location.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.HRegionLocation
RegionAdminServiceCallable.getLocation
(boolean useCache) protected org.apache.hadoop.hbase.HRegionLocation
RegionServerCallable.getLocation()
protected final org.apache.hadoop.hbase.HRegionLocation
ScannerCallable.getLocationForReplica
(org.apache.hadoop.hbase.RegionLocations locs) org.apache.hadoop.hbase.HRegionLocation
ClusterConnection.getRegionLocation
(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean reload) Find region location hosting passed roworg.apache.hadoop.hbase.HRegionLocation
ConnectionImplementation.getRegionLocation
(org.apache.hadoop.hbase.TableName tableName, byte[] row, boolean reload) org.apache.hadoop.hbase.HRegionLocation
HRegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) default org.apache.hadoop.hbase.HRegionLocation
RegionLocator.getRegionLocation
(byte[] row) Finds the region on which the given row is being served.default org.apache.hadoop.hbase.HRegionLocation
RegionLocator.getRegionLocation
(byte[] row, boolean reload) Finds the region on which the given row is being served.default org.apache.hadoop.hbase.HRegionLocation
RegionLocator.getRegionLocation
(byte[] row, int replicaId) Finds the region with the given replica id on which the given row is being served.org.apache.hadoop.hbase.HRegionLocation
RegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) Finds the region with the given replica id on which the given row is being served.org.apache.hadoop.hbase.HRegionLocation
ClusterConnection.locateRegion
(byte[] regionName) Gets the location of the region of regionName.org.apache.hadoop.hbase.HRegionLocation
ClusterConnection.locateRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] row) Find the location of the region of tableName that row lives in.org.apache.hadoop.hbase.HRegionLocation
ConnectionImplementation.locateRegion
(byte[] regionName) org.apache.hadoop.hbase.HRegionLocation
ConnectionImplementation.locateRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] row) org.apache.hadoop.hbase.HRegionLocation
ClusterConnection.relocateRegion
(org.apache.hadoop.hbase.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.org.apache.hadoop.hbase.HRegionLocation
ConnectionImplementation.relocateRegion
(org.apache.hadoop.hbase.TableName tableName, byte[] row) Modifier and TypeMethodDescriptionCompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
AsyncTableRegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.List<org.apache.hadoop.hbase.HRegionLocation>
HRegionLocator.getAllRegionLocations()
List<org.apache.hadoop.hbase.HRegionLocation>
RegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.default CompletableFuture<org.apache.hadoop.hbase.HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row) Finds the region on which the given row is being served.default CompletableFuture<org.apache.hadoop.hbase.HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row, boolean reload) Finds the region on which the given row is being served.default CompletableFuture<org.apache.hadoop.hbase.HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row, int replicaId) Finds the region with the givenreplicaId
on which the given row is being served.CompletableFuture<org.apache.hadoop.hbase.HRegionLocation>
AsyncTableRegionLocator.getRegionLocation
(byte[] row, int replicaId, boolean reload) Finds the region with the givenreplicaId
on which the given row is being served.default CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
AsyncTableRegionLocator.getRegionLocations
(byte[] row) Find all the replicas for the region on which the given row is being served.CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
AsyncTableRegionLocator.getRegionLocations
(byte[] row, boolean reload) Find all the replicas for the region on which the given row is being served.List<org.apache.hadoop.hbase.HRegionLocation>
HRegionLocator.getRegionLocations
(byte[] row, boolean reload) default List<org.apache.hadoop.hbase.HRegionLocation>
RegionLocator.getRegionLocations
(byte[] row) Find all the replicas for the region on which the given row is being served.List<org.apache.hadoop.hbase.HRegionLocation>
RegionLocator.getRegionLocations
(byte[] row, boolean reload) Find all the replicas for the region on which the given row is being served.List<org.apache.hadoop.hbase.HRegionLocation>
ClusterConnection.locateRegions
(org.apache.hadoop.hbase.TableName tableName) Gets the locations of all regions in the specified table, tableName.List<org.apache.hadoop.hbase.HRegionLocation>
ClusterConnection.locateRegions
(org.apache.hadoop.hbase.TableName tableName, boolean useCache, boolean offlined) Gets the locations of all regions in the specified table, tableName.List<org.apache.hadoop.hbase.HRegionLocation>
ConnectionImplementation.locateRegions
(org.apache.hadoop.hbase.TableName tableName) List<org.apache.hadoop.hbase.HRegionLocation>
ConnectionImplementation.locateRegions
(org.apache.hadoop.hbase.TableName tableName, boolean useCache, boolean offlined) Modifier and TypeMethodDescriptionvoid
MetaCache.cacheLocation
(org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.ServerName source, org.apache.hadoop.hbase.HRegionLocation location) Put a newly discovered HRegionLocation into the cache.org.apache.hadoop.hbase.client.RequestController.ReturnCode
RequestController.Checker.canTakeRow
(org.apache.hadoop.hbase.HRegionLocation loc, org.apache.hadoop.hbase.client.Row row) Checks the data whether it is valid to submit.protected void
RegionServerCallable.setLocation
(org.apache.hadoop.hbase.HRegionLocation location) ModifierConstructorDescriptionRegionAdminServiceCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row) RegionAdminServiceCallable
(org.apache.hadoop.hbase.client.ClusterConnection connection, org.apache.hadoop.hbase.ipc.RpcControllerFactory rpcControllerFactory, org.apache.hadoop.hbase.HRegionLocation location, org.apache.hadoop.hbase.TableName tableName, byte[] row, int replicaId) ModifierConstructorDescriptionHTableMultiplexerStatus
(Map<org.apache.hadoop.hbase.HRegionLocation, org.apache.hadoop.hbase.client.HTableMultiplexer.FlushWorker> serverToFlushWorkerMap) Deprecated. -
Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.shaded.protobuf
Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.HRegionLocation
ProtobufUtil.toRegionLocation
(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation proto) Modifier and TypeMethodDescriptionstatic org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation
ProtobufUtil.toRegionLocation
(org.apache.hadoop.hbase.HRegionLocation loc)