Uses of Class
org.apache.hadoop.hbase.ScheduledChore
Packages that use ScheduledChore
Package
Description
Provides HBase Client
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
-
Uses of ScheduledChore in org.apache.hadoop.hbase
Subclasses of ScheduledChore in org.apache.hadoop.hbaseModifier and TypeClassDescriptionclassThe Class HealthCheckChore for running health checker regularly.Fields in org.apache.hadoop.hbase with type parameters of type ScheduledChoreModifier and TypeFieldDescriptionprivate final 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 final HashMap<ScheduledChore,ScheduledFuture<?>> ChoreService.scheduledChoresMaps chores to their futures.Methods in org.apache.hadoop.hbase that return ScheduledChoreModifier and TypeMethodDescriptionstatic ScheduledChoreAuthUtil.getAuthChore(org.apache.hadoop.conf.Configuration conf) Deprecated.static ScheduledChoreAuthUtil.getAuthRenewalChore(org.apache.hadoop.security.UserGroupInformation user, org.apache.hadoop.conf.Configuration conf) Deprecated.Checks if security is enabled and if so, launches chore for refreshing kerberos ticket.Methods in org.apache.hadoop.hbase with parameters of type ScheduledChoreModifier and TypeMethodDescription(package private) voidChoreService.cancelChore(ScheduledChore chore) Cancel any ongoing schedules that this chore has with the implementer of this interface.(package private) voidChoreService.cancelChore(ScheduledChore chore, boolean mayInterruptIfRunning) Cancel any ongoing schedules that this chore has with the implementer of this interface.booleanChoreService.isChoreScheduled(ScheduledChore chore) Returns true when the chore is scheduled with the implementer of this interface(package private) voidChoreService.onChoreMissedStartTime(ScheduledChore chore) A callback that tells the implementer of this interface that one of the scheduled chores is missing its start time.private voidChoreService.printChoreDetails(String header, ScheduledChore chore) Prints a summary of important details about the chore.private voidChoreService.rescheduleChore(ScheduledChore chore, boolean immediately) booleanChoreService.scheduleChore(ScheduledChore chore) Schedule a chore.(package private) voidChoreService.triggerNow(ScheduledChore chore) This method tries to execute the chore immediately. -
Uses of ScheduledChore in org.apache.hadoop.hbase.client
Methods in org.apache.hadoop.hbase.client that return ScheduledChoreModifier and TypeMethodDescriptionprivate ScheduledChoreCatalogReplicaLoadBalanceSimpleSelector.getCacheCleanupChore(CatalogReplicaLoadBalanceSimpleSelector selector) private ScheduledChoreCatalogReplicaLoadBalanceSimpleSelector.getRefreshReplicaCountChore(CatalogReplicaLoadBalanceSimpleSelector selector) -
Uses of ScheduledChore in org.apache.hadoop.hbase.master
Subclasses of ScheduledChore in org.apache.hadoop.hbase.masterModifier and TypeClassDescriptionclassClass to publish the cluster status to the client.classThis chore is used to update the 'oldWALsDirSize' variable inMasterWalManagerthrough theMasterWalManager.updateOldWALsDirSize()method.classThis chore, every time it runs, will try to recover regions with high store ref count by reopening themprivate classDeprecated.Periodically checks all active tasks and resubmits the ones that have timed out -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.balancer
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.balancerModifier and TypeClassDescriptionclassChore that will call HMaster.balanceHMaster.balance()when needed.classChore that will feed the balancer the cluster status. -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.cleaner
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.cleanerModifier and TypeClassDescriptionclassCleanerChore<T extends FileCleanerDelegate>Abstract Cleaner that uses a chain of delegates to clean a directory of filesclassThis Chore, every time it runs, will clear the HFiles in the hfile archive folder that are deletable for each HFile cleaner in the chain.classThis Chore, every time it runs, will attempt to delete the WALs and Procedure WALs in the old logs folder.classUsed to clean the useless barriers inHConstants.REPLICATION_BARRIER_FAMILY_STRfamily in meta table.classThis chore, every time it runs, will try to delete snapshots that are expired based on TTL in seconds configured for each Snapshot -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.hbck
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.hbckModifier and TypeClassDescriptionclassUsed to do the hbck checking job at master side. -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.janitor
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.janitor -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.migrate
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.migrateModifier and TypeClassDescriptionclassTo avoid too many migrating/upgrade threads to be submitted at the time during master initialization, RollingUpgradeChore handles all rolling-upgrade tasks. -
Uses of ScheduledChore in org.apache.hadoop.hbase.master.normalizer
Subclasses of ScheduledChore in org.apache.hadoop.hbase.master.normalizerModifier and TypeClassDescription(package private) classChore that will periodically callHMaster.normalizeRegions(NormalizeTableFilterParams, boolean).Methods in org.apache.hadoop.hbase.master.normalizer that return ScheduledChore -
Uses of ScheduledChore in org.apache.hadoop.hbase.mob
Subclasses of ScheduledChore in org.apache.hadoop.hbase.mobModifier and TypeClassDescriptionclassThe class MobFileCleanerChore for running cleaner regularly to remove the expired and obsolete (files which have no active references to) mob files.classPeriodic MOB compaction chore.classThe class RSMobFileCleanerChore for running cleaner regularly to remove the obsolete (files which have no active references to) mob files that were referenced from the current RS. -
Uses of ScheduledChore in org.apache.hadoop.hbase.namequeues
Subclasses of ScheduledChore in org.apache.hadoop.hbase.namequeuesModifier and TypeClassDescriptionclassChore to insert multiple accumulated slow/large logs to hbase:slowlog system table -
Uses of ScheduledChore in org.apache.hadoop.hbase.quotas
Subclasses of ScheduledChore in org.apache.hadoop.hbase.quotasModifier and TypeClassDescriptionclassA chore which computes the size of eachHRegionon the FileSystem hosted by the givenHRegionServer.private classclassReads the currently received Region filesystem-space use reports and acts on those which violate a defined quota.classA Chore which sends the region size reports on this RegionServer to the Master.classA Master-invokedChorethat computes the size of each snapshot which was created from a table which has a space quota.classAScheduledChorewhich periodically updates theRegionServerSpaceQuotaManagerwith information from the hbase:quota. -
Uses of ScheduledChore in org.apache.hadoop.hbase.regionserver
Subclasses of ScheduledChore in org.apache.hadoop.hbase.regionserverModifier and TypeClassDescriptionclassThis Chore, every time it runs, will clear the unsused HFiles in the data folder.classA 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 classprivate static classInner class that runs on a long period checking if regions need compaction.private static classclassA chore for refreshing the store files for secondary regions hosted in the region server.Fields in org.apache.hadoop.hbase.regionserver declared as ScheduledChoreModifier and TypeFieldDescriptionprivate ScheduledChoreHRegionServer.compactionCheckerCheck for compactions requests.private ScheduledChoreHRegionServer.nonceManagerChoreThe nonce manager chore.private ScheduledChoreHRegionServer.periodicFlusherCheck for flushesMethods in org.apache.hadoop.hbase.regionserver that return ScheduledChoreModifier and TypeMethodDescriptionServerNonceManager.createCleanupScheduledChore(Stoppable stoppable) Creates a scheduled chore that is used to clean up old nonces.Methods in org.apache.hadoop.hbase.regionserver with parameters of type ScheduledChoreModifier and TypeMethodDescriptionprotected final voidHRegionServer.shutdownChore(ScheduledChore chore) -
Uses of ScheduledChore in org.apache.hadoop.hbase.replication
Subclasses of ScheduledChore in org.apache.hadoop.hbase.replicationModifier and TypeClassDescriptionprivate final class -
Uses of ScheduledChore in org.apache.hadoop.hbase.replication.regionserver
Subclasses of ScheduledChore in org.apache.hadoop.hbase.replication.regionserverModifier and TypeClassDescriptionclassThis chore is responsible to create replication marker rows with special WALEdit with family asWALEdit.METAFAMILYand column qualifier asWALEdit.REPLICATION_MARKERand empty value.
InterfaceAudience.Privateuse only after 4.0.0.