Package | Description |
---|---|
org.apache.hadoop.hbase | |
org.apache.hadoop.hbase.client |
Provides HBase Client
|
org.apache.hadoop.hbase.shaded.protobuf |
Modifier and Type | Method and Description |
---|---|
HRegionLocation |
RegionLocations.getDefaultRegionLocation() |
HRegionLocation |
RegionLocations.getRegionLocation()
Returns the first not-null region location in the list
|
HRegionLocation |
RegionLocations.getRegionLocation(int replicaId) |
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.
|
HRegionLocation |
RegionLocations.getRegionLocationByRegionName(byte[] regionName)
Returns the region location from the list for matching regionName, which can
be regionName or encodedRegionName
|
HRegionLocation[] |
RegionLocations.getRegionLocations() |
Modifier and Type | Method and Description |
---|---|
static CompletableFuture<Optional<HRegionLocation>> |
ClientMetaTableAccessor.getRegionLocation(AsyncTable<?> metaTable,
byte[] regionName)
Returns the HRegionLocation from meta for the given region
|
static CompletableFuture<Optional<HRegionLocation>> |
ClientMetaTableAccessor.getRegionLocationWithEncodedName(AsyncTable<?> metaTable,
byte[] encodedRegionName)
Returns the HRegionLocation from meta for the given encoded region name
|
static CompletableFuture<List<HRegionLocation>> |
ClientMetaTableAccessor.getTableHRegionLocations(AsyncTable<AdvancedScanResultConsumer> metaTable,
TableName tableName)
Used to get all region locations for the specific table.
|
Iterator<HRegionLocation> |
RegionLocations.iterator() |
Modifier and Type | Method and Description |
---|---|
int |
HRegionLocation.compareTo(HRegionLocation o) |
RegionLocations |
RegionLocations.remove(HRegionLocation location)
Removes the given location from the list
|
RegionLocations |
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.
|
Constructor and Description |
---|
RegionLocations(HRegionLocation... locations)
Constructs the region location list.
|
Constructor and Description |
---|
RegionLocations(Collection<HRegionLocation> locations) |
Modifier and Type | Method and Description |
---|---|
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.
|
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.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<List<HRegionLocation>> |
AsyncTableRegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.
|
List<HRegionLocation> |
RegionLocator.getAllRegionLocations()
Retrieves all of the regions associated with this table.
|
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 given
replicaId on which the given row is being served. |
CompletableFuture<HRegionLocation> |
AsyncTableRegionLocator.getRegionLocation(byte[] row,
int replicaId,
boolean reload)
Finds the region with the given
replicaId on which the given row is being served. |
default CompletableFuture<List<HRegionLocation>> |
AsyncTableRegionLocator.getRegionLocations(byte[] row)
Find all the replicas for the region on which the given row is being served.
|
default List<HRegionLocation> |
RegionLocator.getRegionLocations(byte[] row)
Find all the replicas for the region on which the given row is being served.
|
CompletableFuture<List<HRegionLocation>> |
AsyncTableRegionLocator.getRegionLocations(byte[] row,
boolean reload)
Find all the replicas for the region on which the given row is being served.
|
List<HRegionLocation> |
RegionLocator.getRegionLocations(byte[] row,
boolean reload)
Find all the replicas for the region on which the given row is being served.
|
Modifier and Type | Method and Description |
---|---|
RequestController.ReturnCode |
RequestController.Checker.canTakeRow(HRegionLocation loc,
Row row)
Checks the data whether it is valid to submit.
|
Modifier and Type | Method and Description |
---|---|
static HRegionLocation |
ProtobufUtil.toRegionLocation(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation proto) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation |
ProtobufUtil.toRegionLocation(HRegionLocation loc) |
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.