| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ServerDefines a curated set of shared functions implemented by HBase servers (Masters
 and RegionServers). | 
| Modifier and Type | Field and Description | 
|---|---|
| private Stoppable | ScheduledChore. stopperA means by which a ScheduledChore can be stopped. | 
| Modifier and Type | Method and Description | 
|---|---|
| private static Stoppable | AuthUtil. createDummyStoppable()Deprecated.  | 
| Stoppable | ScheduledChore. getStopper() | 
| Constructor and Description | 
|---|
| HealthCheckChore(int sleepTime,
                Stoppable stopper,
                org.apache.hadoop.conf.Configuration conf) | 
| ScheduledChore(String name,
              Stoppable stopper,
              int period) | 
| ScheduledChore(String name,
              Stoppable stopper,
              int period,
              long initialDelay) | 
| ScheduledChore(String name,
              Stoppable stopper,
              int period,
              long initialDelay,
              TimeUnit unit) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LongTermArchivingHFileCleanerBaseHFileCleanerDelegatethat only cleans HFiles that don't belong to a table that is
 currently being archived. | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) class  | CatalogReplicaLoadBalanceSimpleSelectorCatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load
 balancing algorithm. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FavoredNodeLoadBalancerAn implementation of the  LoadBalancerthat
 assigns favored nodes for each region. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | LoadBalancerMakes decisions about the placement and movement of Regions across
 RegionServers. | 
| interface  | MasterServicesA curated subset of services provided by  HMaster. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HMasterHMaster is the "master server" for HBase. | 
| static class  | HMasterCommandLine.LocalHMaster | 
| class  | TableNamespaceManagerThis is a helper class used internally to manage the namespace metadata that is stored in
 TableName.NAMESPACE_TABLE_NAME. | 
| Constructor and Description | 
|---|
| RegionsRecoveryChore(Stoppable stopper,
                    org.apache.hadoop.conf.Configuration configuration,
                    HMaster hMaster)Construct RegionsRecoveryChore with provided params | 
| TimeoutMonitor(int period,
              Stoppable stopper) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseLoadBalancerThe base class for load balancers. | 
| class  | FavoredStochasticBalancerAn implementation of the  LoadBalancerthat
 assigns favored nodes for each region. | 
| class  | SimpleLoadBalancerMakes decisions about the placement and movement of Regions across
 RegionServers. | 
| class  | StochasticLoadBalancerThis is a best effort load balancer. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | FileCleanerDelegateGeneral interface for cleaning files from a folder (generally an archive or
 backup folder). | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseFileCleanerDelegateBase class for file cleaners which allows subclasses to implement a simple
 isFileDeletable method (which used to be the FileCleanerDelegate contract). | 
| class  | BaseHFileCleanerDelegateBase class for the hfile cleaning function inside the master. | 
| class  | BaseLogCleanerDelegateBase class for the log cleaning function inside the master. | 
| class  | BaseTimeToLiveFileCleanerBase class for time to live file cleaner. | 
| class  | HFileLinkCleanerHFileLink cleaner that determines if a hfile should be deleted. | 
| class  | TimeToLiveHFileCleanerHFile cleaner that uses the timestamp of the hfile to determine if it should be deleted. | 
| class  | TimeToLiveLogCleanerLog cleaner that uses the timestamp of the wal to determine if it should be deleted. | 
| class  | TimeToLiveMasterLocalStoreHFileCleanerMaster local storage HFile cleaner that uses the timestamp of the HFile to determine if it should
 be deleted. | 
| class  | TimeToLiveMasterLocalStoreWALCleanerMaster local storage WAL cleaner that uses the timestamp of the WAL file to determine if it
 should be deleted. | 
| class  | TimeToLiveProcedureWALCleanerDeprecated. 
 Since 2.3.0, will be removed in 4.0.0. We will not use the procedure wal to store
             procedure any more. | 
| Constructor and Description | 
|---|
| CleanerChore(String name,
            int sleepPeriod,
            Stoppable s,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path oldFileDir,
            String confKey,
            DirScanPool pool) | 
| CleanerChore(String name,
            int sleepPeriod,
            Stoppable s,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path oldFileDir,
            String confKey,
            DirScanPool pool,
            Map<String,Object> params) | 
| HFileCleaner(int period,
            Stoppable stopper,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path directory,
            DirScanPool pool) | 
| HFileCleaner(int period,
            Stoppable stopper,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path directory,
            DirScanPool pool,
            Map<String,Object> params) | 
| HFileCleaner(String name,
            int period,
            Stoppable stopper,
            org.apache.hadoop.conf.Configuration conf,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path directory,
            String confKey,
            DirScanPool pool,
            Map<String,Object> params)For creating customized HFileCleaner. | 
| LogCleaner(int period,
          Stoppable stopper,
          org.apache.hadoop.conf.Configuration conf,
          org.apache.hadoop.fs.FileSystem fs,
          org.apache.hadoop.fs.Path oldLogDir,
          DirScanPool pool) | 
| ReplicationBarrierCleaner(org.apache.hadoop.conf.Configuration conf,
                         Stoppable stopper,
                         Connection conn,
                         ReplicationPeerManager peerManager) | 
| SnapshotCleanerChore(Stoppable stopper,
                    org.apache.hadoop.conf.Configuration configuration,
                    SnapshotManager snapshotManager)Construct Snapshot Cleaner Chore with parameterized constructor | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SnapshotFileCacheIntelligently keep track of all the files for all the snapshots. | 
| class  | SnapshotHFileCleanerImplementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
 tables. | 
| class  | SnapshotManagerThis class manages the procedure of taking and restoring snapshots. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ManualMobMaintHFileCleanerBaseHFileCleanerDelegatethat prevents cleaning HFiles from a mob region
 keeps a map of table name strings to mob region name strings over the life of
 a JVM instance. | 
| Constructor and Description | 
|---|
| SlowLogTableOpsChore(Stoppable stopper,
                    int period,
                    NamedQueueRecorder namedQueueRecorder)Chore Constructor | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MasterProcedureManagerA life-cycle management interface for globally barriered procedures on master. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MasterFlushTableProcedureManager | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QuotaCacheCache that keeps track of the quota settings for the users and tables that
 are interacting with it. | 
| Constructor and Description | 
|---|
| QuotaObserverChore(Connection conn,
                  org.apache.hadoop.conf.Configuration conf,
                  SpaceQuotaSnapshotNotifier snapshotNotifier,
                  MasterQuotaManager quotaManager,
                  Stoppable stopper,
                  MetricsMaster metrics) | 
| QuotaRefresherChore(int period,
                   Stoppable stoppable) | 
| SnapshotQuotaObserverChore(Connection conn,
                          org.apache.hadoop.conf.Configuration conf,
                          org.apache.hadoop.fs.FileSystem fs,
                          Stoppable stopper,
                          MetricsMaster metrics) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RegionServerServicesA curated subset of services provided by  HRegionServer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HRegionServerHRegionServer makes a set of HRegions available to clients. | 
| (package private) static class  | ShutdownHook.DoNothingStoppable | 
| Modifier and Type | Field and Description | 
|---|---|
| private Stoppable | ShutdownHook.ShutdownHookThread. stop | 
| Modifier and Type | Method and Description | 
|---|---|
| ScheduledChore | ServerNonceManager. createCleanupScheduledChore(Stoppable stoppable)Creates a scheduled chore that is used to clean up old nonces. | 
| static void | ShutdownHook. install(org.apache.hadoop.conf.Configuration conf,
       org.apache.hadoop.fs.FileSystem fs,
       Stoppable stop,
       Thread threadToJoin)Install a shutdown hook that calls stop on the passed Stoppable
 and then thread joins against the passed  threadToJoin. | 
| boolean | ServerNonceManager. startOperation(long group,
              long nonce,
              Stoppable stoppable)Starts the operation if operation with such nonce has not already succeeded. | 
| Constructor and Description | 
|---|
| CompactedHFilesDischarger(int period,
                         Stoppable stopper,
                         RegionServerServices regionServerServices) | 
| CompactedHFilesDischarger(int period,
                         Stoppable stopper,
                         RegionServerServices regionServerServices,
                         boolean useExecutor) | 
| CompactionChecker(HRegionServer h,
                 int sleepTime,
                 Stoppable stopper) | 
| ShutdownHookThread(org.apache.hadoop.conf.Configuration conf,
                  Stoppable stop,
                  Thread threadToJoin,
                  Runnable fsShutdownHook) | 
| StorefileRefresherChore(int period,
                       boolean onlyMetaRefresh,
                       HRegionServer regionServer,
                       Stoppable stoppable) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ThroughputControllerA utility that constrains the total throughput of one or more simultaneous flows by
 sleeping when necessary. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NoLimitThroughputController | 
| class  | PressureAwareCompactionThroughputControllerA throughput controller which uses the follow schema to limit throughput
 
 If compaction pressure is greater than 1.0, no limitation.
 In off peak hours, use a fixed throughput limitation
 "hbase.hstore.compaction.throughput.offpeak"
 In normal hours, the max throughput is tuned between
 "hbase.hstore.compaction.throughput.lower.bound" and
 "hbase.hstore.compaction.throughput.higher.bound", using the formula "lower +
 (higer - lower) * compactionPressure", where compactionPressure is in range [0.0, 1.0]
  | 
| class  | PressureAwareFlushThroughputControllerA throughput controller which uses the follow schema to limit throughput
 
 If flush pressure is greater than or equal to 1.0, no limitation.
 In normal case, the max throughput is tuned between
 "hbase.hstore.flush.throughput.lower.bound" and
 "hbase.hstore.flush.throughput.upper.bound", using the formula "lower +
 (upper - lower) * flushPressure", where flushPressure is in range [0.0, 1.0)
  | 
| class  | PressureAwareThroughputController | 
| Modifier and Type | Field and Description | 
|---|---|
| private Stoppable | ReplicationTrackerZKImpl. stopper | 
| Modifier and Type | Method and Description | 
|---|---|
| static ReplicationTracker | ReplicationFactory. getReplicationTracker(ZKWatcher zookeeper,
                     Abortable abortable,
                     Stoppable stopper) | 
| Constructor and Description | 
|---|
| ReplicationStatisticsChore(String name,
                          Stoppable stopper,
                          int period) | 
| ReplicationTrackerZKImpl(ZKWatcher zookeeper,
                        Abortable abortable,
                        Stoppable stopper) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReplicationHFileCleanerImplementation of a file cleaner that checks if a hfile is still scheduled for replication before
 deleting it from hfile archive directory. | 
| class  | ReplicationLogCleanerImplementation of a log cleaner that checks if a log is still scheduled for
 replication before deleting it when its TTL is over. | 
| Modifier and Type | Class and Description | 
|---|---|
| private static class  | DumpReplicationQueues.WarnOnlyStoppable | 
| (package private) class  | ReplicationSyncUp.DummyServer | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RSGroupableBalancerMarker Interface. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RSGroupBasedLoadBalancerGroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721)
 It does region balance based on a table's group membership. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SnapshotScannerHDFSAclCleanerImplementation of a file cleaner that checks if a empty directory with no subdirs and subfiles is
 deletable when user scan snapshot feature is enabled | 
| Modifier and Type | Class and Description | 
|---|---|
| private class  | AuthenticationTokenSecretManager.LeaderElector | 
| Modifier and Type | Field and Description | 
|---|---|
| private Stoppable | Sleeper. stopper | 
| Constructor and Description | 
|---|
| Sleeper(int sleep,
       Stoppable stopper) | 
| Modifier and Type | Field and Description | 
|---|---|
| private Stoppable | ZKLeaderManager. candidateDeprecated.  | 
| Constructor and Description | 
|---|
| ZKLeaderManager(ZKWatcher watcher,
               String leaderZNode,
               byte[] identifier,
               Stoppable candidate)Deprecated.  | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.