Uses of Class
org.apache.hadoop.hbase.HRegionLocation

Packages that use org.apache.hadoop.hbase.HRegionLocation
  • Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase

    Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.HRegionLocation
    RegionLocations.getDefaultRegionLocation()
     
    static org.apache.hadoop.hbase.HRegionLocation
    CatalogFamilyFormat.getRegionLocation(org.apache.hadoop.hbase.client.Result r, org.apache.hadoop.hbase.client.RegionInfo regionInfo, int replicaId)
    Returns the HRegionLocation parsed from the given meta row Result for the given regionInfo and replicaId.
    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 region
    static 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 region
    org.apache.hadoop.hbase.HRegionLocation
    RegionLocations.getRegionLocation()
    Returns the first not-null region location in the list
    org.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 encodedRegionName
    org.apache.hadoop.hbase.HRegionLocation[]
    RegionLocations.getRegionLocations()
     
    Methods in org.apache.hadoop.hbase that return types with arguments of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.HRegionLocation>
    MetaRegionLocationCache.getMetaRegionLocations()
    Returns Optional list of HRegionLocations for meta replica(s), null if the cache is empty.
    static CompletableFuture<Optional<org.apache.hadoop.hbase.HRegionLocation>>
    ClientMetaTableAccessor.getRegionLocation(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, byte[] regionName)
    Returns the HRegionLocation from meta for the given region
    static CompletableFuture<Optional<org.apache.hadoop.hbase.HRegionLocation>>
    ClientMetaTableAccessor.getRegionLocationWithEncodedName(org.apache.hadoop.hbase.client.AsyncTable<?> metaTable, byte[] encodedRegionName)
    Returns the HRegionLocation from meta for the given encoded region name
    static CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
    ClientMetaTableAccessor.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 table
    Iterator<org.apache.hadoop.hbase.HRegionLocation>
    RegionLocations.iterator()
     
    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    int
    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 list
    org.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.
    Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier
    Constructor
    Description
     
    RegionLocations(org.apache.hadoop.hbase.HRegionLocation... locations)
    Constructs the region location list.
    Constructor parameters in org.apache.hadoop.hbase with type arguments of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier
    Constructor
    Description
     
    RegionLocations(Collection<org.apache.hadoop.hbase.HRegionLocation> locations)
     
  • Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.client

    Methods in org.apache.hadoop.hbase.client that return org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    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.
    Methods in org.apache.hadoop.hbase.client that return types with arguments of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    CompletableFuture<List<org.apache.hadoop.hbase.HRegionLocation>>
    AsyncTableRegionLocator.getAllRegionLocations()
    Retrieves all of the regions associated with this table.
    List<org.apache.hadoop.hbase.HRegionLocation>
    RegionLocator.getAllRegionLocations()
    Retrieves all of the regions associated with this table.
    List<org.apache.hadoop.hbase.HRegionLocation>
    ConnectionRegistryEndpoint.getMetaLocations()
    Get the location of meta regions.
    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 given replicaId 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 given replicaId 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.
    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.
    Methods in org.apache.hadoop.hbase.client with parameters of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    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.
  • Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.master

    Methods in org.apache.hadoop.hbase.master that return types with arguments of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.HRegionLocation>
    HMaster.getMetaLocations()
     
  • Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    List<org.apache.hadoop.hbase.HRegionLocation>
    HRegionServer.getMetaLocations()
     
  • Uses of org.apache.hadoop.hbase.HRegionLocation in org.apache.hadoop.hbase.shaded.protobuf

    Methods in org.apache.hadoop.hbase.shaded.protobuf that return org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.HRegionLocation
    ProtobufUtil.toRegionLocation(org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation proto)
     
    Methods in org.apache.hadoop.hbase.shaded.protobuf with parameters of type org.apache.hadoop.hbase.HRegionLocation in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.RegionLocation
    ProtobufUtil.toRegionLocation(org.apache.hadoop.hbase.HRegionLocation loc)