| Package | Description | 
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.client | Provides HBase Client | 
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.balancer | |
| org.apache.hadoop.hbase.master.cleaner | |
| org.apache.hadoop.hbase.master.janitor | |
| org.apache.hadoop.hbase.master.normalizer | The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
 a "normal" size, according to their storefile size. | 
| org.apache.hadoop.hbase.namequeues | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.replication | Multi Cluster Replication | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HealthCheckChoreThe Class HealthCheckChore for running health checker regularly. | 
| Modifier and Type | Field and Description | 
|---|---|
| private HashMap<ScheduledChore,Boolean> | ChoreService. choresMissingStartTimeMaps chores to Booleans which indicate whether or not a chore has caused an increase in the
 core pool size of the ScheduledThreadPoolExecutor. | 
| private HashMap<ScheduledChore,ScheduledFuture<?>> | ChoreService. scheduledChoresMaps chores to their futures. | 
| Modifier and Type | Method and Description | 
|---|---|
| static ScheduledChore | AuthUtil. getAuthChore(org.apache.hadoop.conf.Configuration conf)Deprecated. 
 Deprecated since 2.2.0, this method will be
    InterfaceAudience.Privateuse only after 4.0.0. | 
| static ScheduledChore | AuthUtil. getAuthRenewalChore(org.apache.hadoop.security.UserGroupInformation user)Deprecated.  Checks if security is enabled and if so, launches chore for refreshing kerberos ticket. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ChoreService. cancelChore(ScheduledChore chore) | 
| void | ScheduledChore.ChoreServicer. cancelChore(ScheduledChore chore)Cancel any ongoing schedules that this chore has with the implementer of this interface. | 
| void | ChoreService. cancelChore(ScheduledChore chore,
           boolean mayInterruptIfRunning) | 
| void | ScheduledChore.ChoreServicer. cancelChore(ScheduledChore chore,
           boolean mayInterruptIfRunning) | 
| boolean | ChoreService. isChoreScheduled(ScheduledChore chore) | 
| boolean | ScheduledChore.ChoreServicer. isChoreScheduled(ScheduledChore chore) | 
| void | ChoreService. onChoreMissedStartTime(ScheduledChore chore) | 
| void | ScheduledChore.ChoreServicer. onChoreMissedStartTime(ScheduledChore chore)A callback that tells the implementer of this interface that one of the scheduled chores is
 missing its start time. | 
| private void | ChoreService. printChoreDetails(String header,
                 ScheduledChore chore)Prints a summary of important details about the chore. | 
| private void | ChoreService. rescheduleChore(ScheduledChore chore) | 
| boolean | ChoreService. scheduleChore(ScheduledChore chore) | 
| boolean | ChoreService. triggerNow(ScheduledChore chore) | 
| boolean | ScheduledChore.ChoreServicer. triggerNow(ScheduledChore chore)This method tries to execute the chore immediately. | 
| Modifier and Type | Method and Description | 
|---|---|
| private ScheduledChore | CatalogReplicaLoadBalanceSimpleSelector. getCacheCleanupChore(CatalogReplicaLoadBalanceSimpleSelector selector) | 
| private ScheduledChore | CatalogReplicaLoadBalanceSimpleSelector. getRefreshReplicaCountChore(CatalogReplicaLoadBalanceSimpleSelector selector) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClusterStatusPublisherClass to publish the cluster status to the client. | 
| class  | ExpiredMobFileCleanerChoreThe Class ExpiredMobFileCleanerChore for running cleaner regularly to remove the expired
 mob files. | 
| class  | HbckChoreUsed to do the hbck checking job at master side. | 
| class  | MobCompactionChoreThe Class MobCompactChore for running compaction regularly to merge small mob files. | 
| class  | RegionsRecoveryChoreThis chore, every time it runs, will try to recover regions with high store ref count
 by reopening them | 
| private class  | SplitLogManager.TimeoutMonitorDeprecated.  Periodically checks all active tasks and resubmits the ones that have timed out | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BalancerChoreChore that will call HMaster.balance HMaster.balance()when
 needed. | 
| class  | ClusterStatusChoreChore that will feed the balancer the cluster status. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CleanerChore<T extends FileCleanerDelegate>Abstract Cleaner that uses a chain of delegates to clean a directory of files | 
| class  | HFileCleanerThis Chore, every time it runs, will clear the HFiles in the hfile archive
 folder that are deletable for each HFile cleaner in the chain. | 
| class  | LogCleanerThis Chore, every time it runs, will attempt to delete the WALs and Procedure WALs in the old
 logs folder. | 
| class  | ReplicationBarrierCleanerUsed to clean the useless barriers in  HConstants.REPLICATION_BARRIER_FAMILY_STRfamily in
 meta table. | 
| class  | SnapshotCleanerChoreThis chore, every time it runs, will try to delete snapshots that are expired based on TTL in
 seconds configured for each Snapshot | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CatalogJanitorA janitor for the catalog tables. | 
| Modifier and Type | Class and Description | 
|---|---|
| (package private) class  | RegionNormalizerChoreChore that will periodically call
  HMaster.normalizeRegions(NormalizeTableFilterParams, boolean). | 
| Modifier and Type | Method and Description | 
|---|---|
| ScheduledChore | RegionNormalizerManager. getRegionNormalizerChore() | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SlowLogTableOpsChoreChore to insert multiple accumulated slow/large logs to hbase:slowlog system table | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FileSystemUtilizationChoreA chore which computes the size of each  HRegionon the FileSystem hosted by the givenHRegionServer. | 
| private class  | QuotaCache.QuotaRefresherChore | 
| class  | QuotaObserverChoreReads the currently received Region filesystem-space use reports and acts on those which
 violate a defined quota. | 
| class  | RegionSizeReportingChoreA Chore which sends the region size reports on this RegionServer to the Master. | 
| class  | SnapshotQuotaObserverChoreA Master-invoked  Chorethat computes the size of each snapshot which was created from
 a table which has a space quota. | 
| class  | SpaceQuotaRefresherChoreA  ScheduledChorewhich periodically updates theRegionServerSpaceQuotaManagerwith information from the hbase:quota. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CompactedHFilesDischargerA chore service that periodically cleans up the compacted files when there are no active readers
 using those compacted files and also helps in clearing the block cache of these compacted
 file entries. | 
| private class  | HeapMemoryManager.HeapMemoryTunerChore | 
| private static class  | HRegionServer.CompactionCheckerInner class that runs on a long period checking if regions need compaction. | 
| private static class  | HRegionServer.PeriodicMemStoreFlusher | 
| class  | StorefileRefresherChoreA chore for refreshing the store files for secondary regions hosted in the region server. | 
| Modifier and Type | Field and Description | 
|---|---|
| private ScheduledChore | HRegionServer. compactionCheckerCheck for compactions requests. | 
| private ScheduledChore | HRegionServer. nonceManagerChoreThe nonce manager chore. | 
| private ScheduledChore | HRegionServer. periodicFlusherCheck for flushes | 
| Modifier and Type | Method and Description | 
|---|---|
| ScheduledChore | ServerNonceManager. createCleanupScheduledChore(Stoppable stoppable)Creates a scheduled chore that is used to clean up old nonces. | 
| Modifier and Type | Class and Description | 
|---|---|
| private class  | ReplicationSinkServiceImpl.ReplicationStatisticsChore | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.