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

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

    Methods in org.apache.hadoop.hbase.coordination with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    void
    SplitLogWorkerCoordination.init(org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor splitTaskExecutor, org.apache.hadoop.hbase.regionserver.SplitLogWorker worker)
    Deprecated.
    Initialize internal values.
    void
    ZkSplitLogWorkerCoordination.init(org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor splitExecutor, org.apache.hadoop.hbase.regionserver.SplitLogWorker worker)
    Override setter from SplitLogWorkerCoordination
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.coprocessor

    Methods in org.apache.hadoop.hbase.coprocessor that return org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.regionserver.RegionServerServices
    HasRegionServerServices.getRegionServerServices()
    Deprecated.
    Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.master

    Classes in org.apache.hadoop.hbase.master that implement org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.master.HMaster
    HMaster is the "master server" for HBase.
    static class 
    org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
     
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    SpaceViolationPolicyEnforcementFactory.create(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Constructs the appropriate SpaceViolationPolicyEnforcement for tables that are in violation of their space quota.
    org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement
    SpaceViolationPolicyEnforcementFactory.createWithoutViolation(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Creates the "default" SpaceViolationPolicyEnforcement for a table that isn't in violation.
    void
    SpaceViolationPolicyEnforcement.initialize(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
    Initializes this policy instance.
    Constructors in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier
    Constructor
    Description
     
    ActivePolicyEnforcement(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss)
     
     
    ActivePolicyEnforcement(Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcement> activePolicies, Map<org.apache.hadoop.hbase.TableName,org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot> snapshots, org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.quotas.SpaceViolationPolicyEnforcementFactory factory)
     
     
    QuotaCache(org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
     
     
    RegionServerRpcQuotaManager(org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
     
     
    RegionServerSpaceQuotaManager(org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
     
     
    RegionSizeReportingChore(org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
     
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.quotas.policies

    Methods in org.apache.hadoop.hbase.quotas.policies that return org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.regionserver.RegionServerServices
    AbstractViolationPolicyEnforcement.getRegionServerServices()
     
    Methods in org.apache.hadoop.hbase.quotas.policies with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    void
    AbstractViolationPolicyEnforcement.initialize(org.apache.hadoop.hbase.regionserver.RegionServerServices rss, org.apache.hadoop.hbase.TableName tableName, org.apache.hadoop.hbase.quotas.SpaceQuotaSnapshot snapshot)
     
    void
    AbstractViolationPolicyEnforcement.setRegionServerServices(org.apache.hadoop.hbase.regionserver.RegionServerServices rss)
     
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.regionserver

    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.HRegionServer
    HRegionServer makes a set of HRegions available to clients.
    Fields in org.apache.hadoop.hbase.regionserver declared as org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.regionserver.RegionServerServices
    HRegion.rsServices
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.createHRegion(org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.TableDescriptor hTableDescriptor, org.apache.hadoop.hbase.wal.WAL wal, boolean initialize, org.apache.hadoop.hbase.regionserver.RegionServerServices rsRpcServices)
    Convenience method creating new HRegions.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.newHRegion(org.apache.hadoop.fs.Path tableDir, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
    A utility method to create new instances of HRegion based on the HConstants.REGION_IMPL configuration property.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
    Open a Region.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir, org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
    Open a Region.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.openHRegion(org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
    Open a Region.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.openHRegionFromTableDir(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
    Open a Region.
    static org.apache.hadoop.hbase.regionserver.HRegion
    HRegion.warmupHRegion(org.apache.hadoop.hbase.client.RegionInfo info, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.hbase.util.CancelableProgressable reporter)
     
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier
    Constructor
    Description
     
    CompactedHFilesDischarger(int period, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.hbase.regionserver.RegionServerServices regionServerServices)
     
     
    CompactedHFilesDischarger(int period, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.hbase.regionserver.RegionServerServices regionServerServices, boolean useExecutor)
     
     
    HRegion(org.apache.hadoop.fs.Path tableDir, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.conf.Configuration confParam, org.apache.hadoop.hbase.client.RegionInfo regionInfo, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
    Deprecated.
    Use other constructors.
     
    HRegion(org.apache.hadoop.hbase.regionserver.HRegionFileSystem fs, org.apache.hadoop.hbase.wal.WAL wal, org.apache.hadoop.conf.Configuration confParam, org.apache.hadoop.hbase.client.TableDescriptor htd, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
    HRegion constructor.
     
    LogRoller(org.apache.hadoop.hbase.regionserver.RegionServerServices services)
     
     
    RegionCoprocessorHost(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.conf.Configuration conf)
    Constructor
     
    RegionServerCoprocessorHost(org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices, org.apache.hadoop.conf.Configuration conf)
     
     
    RegionServicesForStores(org.apache.hadoop.hbase.regionserver.HRegion region, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
     
     
    SplitLogWorker(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.hbase.regionserver.LastSequenceId sequenceIdChecker, org.apache.hadoop.hbase.wal.WALFactory factory)
    Deprecated.
     
     
    SplitLogWorker(org.apache.hadoop.hbase.Server hserver, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor splitTaskExecutor)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.regionserver.throttle

    Methods in org.apache.hadoop.hbase.regionserver.throttle with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
    CompactionThroughputControllerFactory.create(org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.conf.Configuration conf)
     
    static org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
    FlushThroughputControllerFactory.create(org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.conf.Configuration conf)
     
    void
    NoLimitThroughputController.setup(org.apache.hadoop.hbase.regionserver.RegionServerServices server)
     
    void
    PressureAwareCompactionThroughputController.setup(org.apache.hadoop.hbase.regionserver.RegionServerServices server)
     
    void
    PressureAwareFlushThroughputController.setup(org.apache.hadoop.hbase.regionserver.RegionServerServices server)
     
    abstract void
    PressureAwareThroughputController.setup(org.apache.hadoop.hbase.regionserver.RegionServerServices server)
     
    void
    ThroughputController.setup(org.apache.hadoop.hbase.regionserver.RegionServerServices server)
    Setup controller for the given region server.
  • Uses of org.apache.hadoop.hbase.regionserver.RegionServerServices in org.apache.hadoop.hbase.wal

    Methods in org.apache.hadoop.hbase.wal with parameters of type org.apache.hadoop.hbase.regionserver.RegionServerServices in in
    Modifier and Type
    Method
    Description
    static boolean
    WALSplitter.splitLogFile(org.apache.hadoop.fs.Path walDir, org.apache.hadoop.fs.FileStatus logfile, org.apache.hadoop.fs.FileSystem walFS, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.util.CancelableProgressable reporter, org.apache.hadoop.hbase.regionserver.LastSequenceId idChecker, org.apache.hadoop.hbase.coordination.SplitLogWorkerCoordination splitLogWorkerCoordination, org.apache.hadoop.hbase.wal.WALFactory factory, org.apache.hadoop.hbase.regionserver.RegionServerServices rsServices)
    Splits a WAL file.