Uses of Interface
org.apache.hadoop.hbase.Stoppable
Packages that use Stoppable
Package
Description
Provides HBase Client
Multi Cluster Replication
- 
Uses of Stoppable in org.apache.hadoop.hbaseSubinterfaces of Stoppable in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Classes in org.apache.hadoop.hbase that implement StoppableModifier and TypeClassDescriptionclassHBaseServerBase<R extends HBaseRpcServicesBase<?>>Base class for hbase services, such as master or region server.static classDeprecated.Subclass so can get at protected methods (none at moment).classBasic mock region server services.Fields in org.apache.hadoop.hbase declared as StoppableModifier and TypeFieldDescriptionprivate final StoppableScheduledChore.stopperA means by which a ScheduledChore can be stopped.Methods in org.apache.hadoop.hbase that return StoppableModifier and TypeMethodDescriptionprivate static StoppableAuthUtil.createDummyStoppable()Deprecated.ScheduledChore.getStopper()Constructors in org.apache.hadoop.hbase with parameters of type StoppableModifierConstructorDescriptionExecutorStatusChore(int sleepTime, Stoppable stopper, ExecutorService service, MetricsRegionServerSource metrics) HealthCheckChore(int sleepTime, Stoppable stopper, org.apache.hadoop.conf.Configuration conf) ScheduledChore(String name, Stoppable stopper, int period) Construct a ScheduledChoreScheduledChore(String name, Stoppable stopper, int period, long initialDelay) Construct a ScheduledChoreScheduledChore(String name, Stoppable stopper, int period, long initialDelay, TimeUnit unit) Construct a ScheduledChore
- 
Uses of Stoppable in org.apache.hadoop.hbase.backupClasses in org.apache.hadoop.hbase.backup that implement StoppableModifier and TypeClassDescriptionclassFile cleaner that prevents deletion of HFiles that are still required by future incremental backups.
- 
Uses of Stoppable in org.apache.hadoop.hbase.backup.exampleClasses in org.apache.hadoop.hbase.backup.example that implement StoppableModifier and TypeClassDescriptionclassBaseHFileCleanerDelegatethat only cleans HFiles that don't belong to a table that is currently being archived.
- 
Uses of Stoppable in org.apache.hadoop.hbase.backup.masterClasses in org.apache.hadoop.hbase.backup.master that implement StoppableModifier and TypeClassDescriptionclassImplementation of a log cleaner that checks if a log is still scheduled for incremental backup before deleting it when its TTL is over.classMaster procedure manager for coordinated cluster-wide WAL roll operation, which is run during backup operation, seeMasterProcedureManagerandRegionServerProcedureManager
- 
Uses of Stoppable in org.apache.hadoop.hbase.clientClasses in org.apache.hadoop.hbase.client that implement StoppableModifier and TypeClassDescription(package private) classCatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing algorithm.
- 
Uses of Stoppable in org.apache.hadoop.hbase.favoredClasses in org.apache.hadoop.hbase.favored that implement StoppableModifier and TypeClassDescriptionclassAn implementation of theLoadBalancerthat assigns favored nodes for each region.
- 
Uses of Stoppable in org.apache.hadoop.hbase.masterSubinterfaces of Stoppable in org.apache.hadoop.hbase.masterModifier and TypeInterfaceDescriptioninterfaceMakes decisions about the placement and movement of Regions across RegionServers.interfaceA curated subset of services provided byHMaster.Classes in org.apache.hadoop.hbase.master that implement StoppableModifier and TypeClassDescriptionclassHMaster is the "master server" for HBase.static classConstructors in org.apache.hadoop.hbase.master with parameters of type StoppableModifierConstructorDescription(package private)RegionsRecoveryChore(Stoppable stopper, org.apache.hadoop.conf.Configuration configuration, HMaster hMaster) Construct RegionsRecoveryChore with provided paramsTimeoutMonitor(int period, Stoppable stopper) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.master.balancerClasses in org.apache.hadoop.hbase.master.balancer that implement StoppableModifier and TypeClassDescriptionclassThe base class for load balancers.classclassAn implementation of theLoadBalancerthat assigns favored nodes for each region.classa balancer which is only used in maintenance mode.classMakes decisions about the placement and movement of Regions across RegionServers.classThis is a best effort load balancer.
- 
Uses of Stoppable in org.apache.hadoop.hbase.master.cleanerSubinterfaces of Stoppable in org.apache.hadoop.hbase.master.cleanerModifier and TypeInterfaceDescriptioninterfaceGeneral interface for cleaning files from a folder (generally an archive or backup folder).Classes in org.apache.hadoop.hbase.master.cleaner that implement StoppableModifier and TypeClassDescriptionclassBase class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).classBase class for the hfile cleaning function inside the master.classBase class for the log cleaning function inside the master.classBase class for time to live file cleaner.classHFileLink cleaner that determines if a hfile should be deleted.classHFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.classLog cleaner that uses the timestamp of the wal to determine if it should be deleted.classMaster local storage HFile cleaner that uses the timestamp of the HFile to determine if it should be deleted.classMaster local storage WAL cleaner that uses the timestamp of the WAL file to determine if it should be deleted.classDeprecated.Since 2.3.0, will be removed in 4.0.0.Constructors in org.apache.hadoop.hbase.master.cleaner with parameters of type StoppableModifierConstructorDescriptionCleanerChore(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, List<org.apache.hadoop.fs.Path> excludePaths) 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(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, List<org.apache.hadoop.fs.Path> excludePaths) 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, List<org.apache.hadoop.fs.Path> excludePaths) 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, Map<String, Object> params) 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
- 
Uses of Stoppable in org.apache.hadoop.hbase.master.migrateConstructors in org.apache.hadoop.hbase.master.migrate with parameters of type StoppableModifierConstructorDescriptionprivateRollingUpgradeChore(org.apache.hadoop.conf.Configuration conf, ProcedureExecutor<MasterProcedureEnv> procedureExecutor, TableDescriptors tableDescriptors, Stoppable stopper) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.master.snapshotClasses in org.apache.hadoop.hbase.master.snapshot that implement StoppableModifier and TypeClassDescriptionclassIntelligently keep track of all the files for all the snapshots.classImplementation of a file cleaner that checks if a hfile is still used by snapshots of HBase tables.classThis class manages the procedure of taking and restoring snapshots.
- 
Uses of Stoppable in org.apache.hadoop.hbase.mobClasses in org.apache.hadoop.hbase.mob that implement StoppableModifier and TypeClassDescriptionclassBaseHFileCleanerDelegatethat 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.
- 
Uses of Stoppable in org.apache.hadoop.hbase.namequeuesConstructors in org.apache.hadoop.hbase.namequeues with parameters of type StoppableModifierConstructorDescriptionNamedQueueServiceChore(Stoppable stopper, int period, NamedQueueRecorder namedQueueRecorder, Connection connection) Chore Constructor
- 
Uses of Stoppable in org.apache.hadoop.hbase.procedureClasses in org.apache.hadoop.hbase.procedure that implement StoppableModifier and TypeClassDescriptionclassA life-cycle management interface for globally barriered procedures on master.
- 
Uses of Stoppable in org.apache.hadoop.hbase.procedure.flushClasses in org.apache.hadoop.hbase.procedure.flush that implement Stoppable
- 
Uses of Stoppable in org.apache.hadoop.hbase.quotasClasses in org.apache.hadoop.hbase.quotas that implement StoppableModifier and TypeClassDescriptionclassCache that keeps track of the quota settings for the users and tables that are interacting with it.Constructors in org.apache.hadoop.hbase.quotas with parameters of type StoppableModifierConstructorDescription(package private)QuotaObserverChore(Connection conn, org.apache.hadoop.conf.Configuration conf, SpaceQuotaSnapshotNotifier snapshotNotifier, MasterQuotaManager quotaManager, Stoppable stopper, MetricsMaster metrics) QuotaRefresherChore(org.apache.hadoop.conf.Configuration conf, int period, Stoppable stoppable) (package private)SnapshotQuotaObserverChore(Connection conn, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, Stoppable stopper, MetricsMaster metrics) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.regionserverSubinterfaces of Stoppable in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterfaceA curated subset of services provided byHRegionServer.Classes in org.apache.hadoop.hbase.regionserver that implement StoppableModifier and TypeClassDescriptionclassHRegionServer makes a set of HRegions available to clients.(package private) static classFields in org.apache.hadoop.hbase.regionserver declared as StoppableMethods in org.apache.hadoop.hbase.regionserver with parameters of type StoppableModifier and TypeMethodDescriptionServerNonceManager.createCleanupScheduledChore(Stoppable stoppable) Creates a scheduled chore that is used to clean up old nonces.static voidShutdownHook.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 passedthreadToJoin.booleanServerNonceManager.startOperation(long group, long nonce, Stoppable stoppable) Starts the operation if operation with such nonce has not already succeeded.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type StoppableModifierConstructorDescriptionBrokenStoreFileCleaner(int delay, int period, Stoppable stopper, org.apache.hadoop.conf.Configuration conf, HRegionServer regionServer) CompactedHFilesDischarger(int period, Stoppable stopper, RegionServerServices regionServerServices) CompactedHFilesDischarger(int period, Stoppable stopper, RegionServerServices regionServerServices, boolean useExecutor) (package private)CompactionChecker(HRegionServer h, int sleepTime, Stoppable stopper) (package private)ShutdownHookThread(org.apache.hadoop.conf.Configuration conf, Stoppable stop, Thread threadToJoin, Runnable fsShutdownHook) StorefileRefresherChore(int period, boolean onlyMetaRefresh, HRegionServer regionServer, Stoppable stoppable) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.regionserver.throttleSubinterfaces of Stoppable in org.apache.hadoop.hbase.regionserver.throttleModifier and TypeInterfaceDescriptioninterfaceA utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.Classes in org.apache.hadoop.hbase.regionserver.throttle that implement StoppableModifier and TypeClassDescriptionclassclassA 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]classA 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
- 
Uses of Stoppable in org.apache.hadoop.hbase.replicationConstructors in org.apache.hadoop.hbase.replication with parameters of type StoppableModifierConstructorDescription(package private)ReplicationStatisticsChore(String name, Stoppable stopper, int period) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.replication.masterClasses in org.apache.hadoop.hbase.replication.master that implement StoppableModifier and TypeClassDescriptionclassImplementation of a file cleaner that checks if a hfile is still scheduled for replication before deleting it from hfile archive directory.classImplementation of a log cleaner that checks if a log is still scheduled for replication before deleting it when its TTL is over.
- 
Uses of Stoppable in org.apache.hadoop.hbase.replication.regionserverClasses in org.apache.hadoop.hbase.replication.regionserver that implement StoppableConstructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type StoppableModifierConstructorDescriptionReplicationMarkerChore(Stoppable stopper, RegionServerServices rsServices, int period, org.apache.hadoop.conf.Configuration conf) (package private)ReplicationStatisticsChore(String name, Stoppable stopper, int period) 
- 
Uses of Stoppable in org.apache.hadoop.hbase.rsgroupClasses in org.apache.hadoop.hbase.rsgroup that implement StoppableModifier and TypeClassDescriptionclassGroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.
- 
Uses of Stoppable in org.apache.hadoop.hbase.security.accessClasses in org.apache.hadoop.hbase.security.access that implement StoppableModifier and TypeClassDescriptionclassImplementation of a file cleaner that checks if a empty directory with no subdirs and subfiles is deletable when user scan snapshot feature is enabled
- 
Uses of Stoppable in org.apache.hadoop.hbase.security.tokenClasses in org.apache.hadoop.hbase.security.token that implement Stoppable
- 
Uses of Stoppable in org.apache.hadoop.hbase.utilFields in org.apache.hadoop.hbase.util declared as StoppableConstructors in org.apache.hadoop.hbase.util with parameters of type Stoppable
- 
Uses of Stoppable in org.apache.hadoop.hbase.zookeeperFields in org.apache.hadoop.hbase.zookeeper declared as StoppableConstructors in org.apache.hadoop.hbase.zookeeper with parameters of type StoppableModifierConstructorDescriptionZKLeaderManager(ZKWatcher watcher, String leaderZNode, byte[] identifier, Stoppable candidate) Deprecated.