Uses of Interface
org.apache.hadoop.hbase.regionserver.Region

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

    Methods in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    static void
    HBaseTestingUtility.closeRegionAndWAL(org.apache.hadoop.hbase.regionserver.Region r)
    Deprecated.
    Close both the region r and it's underlying WAL.
    int
    HBaseTestingUtility.countRows(org.apache.hadoop.hbase.regionserver.Region region)
    Deprecated.
     
    int
    HBaseTestingUtility.countRows(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.client.Scan scan)
    Deprecated.
     
    org.apache.hadoop.hbase.client.Result
    HBaseTestingUtility.getClosestRowBefore(org.apache.hadoop.hbase.regionserver.Region r, byte[] row, byte[] family)
    Deprecated.
     
    int
    HBaseTestingUtility.loadRegion(org.apache.hadoop.hbase.regionserver.Region r, byte[] f)
    Deprecated.
     
    void
    HBaseTestingUtility.verifyNumericRows(org.apache.hadoop.hbase.regionserver.Region region, byte[] f, int startRow, int endRow)
    Deprecated.
     
    void
    HBaseTestingUtility.verifyNumericRows(org.apache.hadoop.hbase.regionserver.Region region, byte[] f, int startRow, int endRow, boolean present)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.regionserver.Region in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.regionserver.Region
    RegionCoprocessorEnvironment.getRegion()
    Returns the region associated with this coprocessor
    Methods in org.apache.hadoop.hbase.coprocessor with parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionCoprocessorEnvironment.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionCoprocessorEnvironment.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type)
    Check the quota for the current (rpc-context) user.
  • Uses of org.apache.hadoop.hbase.regionserver.Region in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionServerRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionServerRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition)
     
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionServerRpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type)
     
    org.apache.hadoop.hbase.quotas.OperationQuota
    RpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, int numWrites, int numReads)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, List<org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.Action> actions, boolean hasCondition)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RpcQuotaManager.checkBatchQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.quotas.OperationQuota.OperationType type)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.OperationQuota
    RegionServerRpcQuotaManager.checkScanQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference)
     
    org.apache.hadoop.hbase.quotas.OperationQuota
    RpcQuotaManager.checkScanQuota(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.hbase.shaded.protobuf.generated.ClientProtos.ScanRequest scanRequest, long maxScannerResultSize, long maxBlockBytesScanned, long prevBlockBytesScannedDifference)
    Check the quota for the current (rpc-context) user.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    ActivePolicyEnforcement.getPolicyEnforcement(org.apache.hadoop.hbase.regionserver.Region r)
    Returns the proper SpaceViolationPolicyEnforcement implementation for the given table.
  • Uses of org.apache.hadoop.hbase.regionserver.Region in org.apache.hadoop.hbase.regionserver

    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.HRegion
    Regions store data for a certain region of a table.
    Fields in org.apache.hadoop.hbase.regionserver with type parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Field
    Description
    protected final Map<org.apache.hadoop.hbase.regionserver.Region,org.apache.hadoop.hbase.regionserver.MemStoreFlusher.FlushRegionEntry>
    MemStoreFlusher.regionsInQueue
     
    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.regionserver.Region
    OnlineRegions.getRegion(String encodedRegionName)
    Return Region instance.
    static org.apache.hadoop.hbase.regionserver.Region
    HRegion.openHRegion(org.apache.hadoop.hbase.regionserver.Region other, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
     
    Methods in org.apache.hadoop.hbase.regionserver that return types with arguments of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    List<? extends org.apache.hadoop.hbase.regionserver.Region>
    OnlineRegions.getRegions()
    Get all online regions in this RS.
    List<? extends org.apache.hadoop.hbase.regionserver.Region>
    OnlineRegions.getRegions(org.apache.hadoop.hbase.TableName tableName)
    Get all online regions of a table in this RS.
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    void
    FlushRequestListener.flushRequested(org.apache.hadoop.hbase.regionserver.FlushType type, org.apache.hadoop.hbase.regionserver.Region region)
    Callback which will get called when a flush request is made for a region.
    static org.apache.hadoop.hbase.regionserver.Region
    HRegion.openHRegion(org.apache.hadoop.hbase.regionserver.Region other, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
     
    boolean
    CompactSplit.requestSplit(org.apache.hadoop.hbase.regionserver.Region r)
     
  • Uses of org.apache.hadoop.hbase.regionserver.Region in org.apache.hadoop.hbase.regionserver.throttle

    Constructors in org.apache.hadoop.hbase.regionserver.throttle with parameters of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier
    Constructor
    Description
     
    StoreHotnessProtector(org.apache.hadoop.hbase.regionserver.Region region, org.apache.hadoop.conf.Configuration conf)
     
  • Uses of org.apache.hadoop.hbase.regionserver.Region in org.apache.hadoop.hbase.testing

    Methods in org.apache.hadoop.hbase.testing that return types with arguments of type org.apache.hadoop.hbase.regionserver.Region in in
    Modifier and Type
    Method
    Description
    Optional<org.apache.hadoop.hbase.regionserver.Region>
    TestingHBaseCluster.getRegion(org.apache.hadoop.hbase.client.RegionInfo regionInfo)
    Get the server side Region interface for the specific region.