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.hbase
Subinterfaces of Stoppable in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterface
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Classes in org.apache.hadoop.hbase that implement StoppableModifier and TypeClassDescriptionclass
HBaseServerBase<R extends HBaseRpcServicesBase<?>>
Base class for hbase services, such as master or region server.static class
Deprecated.Subclass so can get at protected methods (none at moment).class
Basic mock region server services.Fields in org.apache.hadoop.hbase declared as StoppableModifier and TypeFieldDescriptionprivate final Stoppable
ScheduledChore.stopper
A means by which a ScheduledChore can be stopped.Methods in org.apache.hadoop.hbase that return StoppableModifier and TypeMethodDescriptionprivate static Stoppable
AuthUtil.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.backup
Classes in org.apache.hadoop.hbase.backup that implement StoppableModifier and TypeClassDescriptionclass
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory. -
Uses of Stoppable in org.apache.hadoop.hbase.backup.example
Classes in org.apache.hadoop.hbase.backup.example that implement StoppableModifier and TypeClassDescriptionclass
BaseHFileCleanerDelegate
that only cleans HFiles that don't belong to a table that is currently being archived. -
Uses of Stoppable in org.apache.hadoop.hbase.backup.master
Classes in org.apache.hadoop.hbase.backup.master that implement StoppableModifier and TypeClassDescriptionclass
Implementation of a log cleaner that checks if a log is still scheduled for incremental backup before deleting it when its TTL is over.class
Master procedure manager for coordinated cluster-wide WAL roll operation, which is run during backup operation, seeMasterProcedureManager
andRegionServerProcedureManager
-
Uses of Stoppable in org.apache.hadoop.hbase.client
Classes in org.apache.hadoop.hbase.client that implement StoppableModifier and TypeClassDescription(package private) class
CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing algorithm. -
Uses of Stoppable in org.apache.hadoop.hbase.favored
Classes in org.apache.hadoop.hbase.favored that implement StoppableModifier and TypeClassDescriptionclass
An implementation of theLoadBalancer
that assigns favored nodes for each region. -
Uses of Stoppable in org.apache.hadoop.hbase.master
Subinterfaces of Stoppable in org.apache.hadoop.hbase.masterModifier and TypeInterfaceDescriptioninterface
Makes decisions about the placement and movement of Regions across RegionServers.interface
A curated subset of services provided byHMaster
.Classes in org.apache.hadoop.hbase.master that implement StoppableModifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Constructors 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.balancer
Classes in org.apache.hadoop.hbase.master.balancer that implement StoppableModifier and TypeClassDescriptionclass
The base class for load balancers.class
class
An implementation of theLoadBalancer
that assigns favored nodes for each region.class
a balancer which is only used in maintenance mode.class
Makes decisions about the placement and movement of Regions across RegionServers.class
This is a best effort load balancer. -
Uses of Stoppable in org.apache.hadoop.hbase.master.cleaner
Subinterfaces of Stoppable in org.apache.hadoop.hbase.master.cleanerModifier and TypeInterfaceDescriptioninterface
General 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 TypeClassDescriptionclass
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).class
Base class for the hfile cleaning function inside the master.class
Base class for the log cleaning function inside the master.class
Base class for time to live file cleaner.class
HFileLink cleaner that determines if a hfile should be deleted.class
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.class
Log cleaner that uses the timestamp of the wal to determine if it should be deleted.class
Master local storage HFile cleaner that uses the timestamp of the HFile to determine if it should be deleted.class
Master local storage WAL cleaner that uses the timestamp of the WAL file to determine if it should be deleted.class
Deprecated.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.migrate
Constructors in org.apache.hadoop.hbase.master.migrate with parameters of type StoppableModifierConstructorDescriptionprivate
RollingUpgradeChore
(org.apache.hadoop.conf.Configuration conf, ProcedureExecutor<MasterProcedureEnv> procedureExecutor, TableDescriptors tableDescriptors, Stoppable stopper) -
Uses of Stoppable in org.apache.hadoop.hbase.master.snapshot
Classes in org.apache.hadoop.hbase.master.snapshot that implement StoppableModifier and TypeClassDescriptionclass
Intelligently keep track of all the files for all the snapshots.class
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase tables.class
This class manages the procedure of taking and restoring snapshots. -
Uses of Stoppable in org.apache.hadoop.hbase.mob
Classes in org.apache.hadoop.hbase.mob that implement StoppableModifier and TypeClassDescriptionclass
BaseHFileCleanerDelegate
that 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.namequeues
Constructors 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.procedure
Classes in org.apache.hadoop.hbase.procedure that implement StoppableModifier and TypeClassDescriptionclass
A life-cycle management interface for globally barriered procedures on master. -
Uses of Stoppable in org.apache.hadoop.hbase.procedure.flush
Classes in org.apache.hadoop.hbase.procedure.flush that implement Stoppable -
Uses of Stoppable in org.apache.hadoop.hbase.quotas
Classes in org.apache.hadoop.hbase.quotas that implement StoppableModifier and TypeClassDescriptionclass
Cache 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.regionserver
Subinterfaces of Stoppable in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Classes in org.apache.hadoop.hbase.regionserver that implement StoppableModifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.(package private) static class
Fields 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 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 passedthreadToJoin
.boolean
ServerNonceManager.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.throttle
Subinterfaces of Stoppable in org.apache.hadoop.hbase.regionserver.throttleModifier and TypeInterfaceDescriptioninterface
A 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 TypeClassDescriptionclass
class
A 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
A 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.replication
Constructors 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.master
Classes in org.apache.hadoop.hbase.replication.master that implement StoppableModifier and TypeClassDescriptionclass
Implementation of a file cleaner that checks if a hfile is still scheduled for replication before deleting it from hfile archive directory.class
Implementation 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.regionserver
Classes 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.rsgroup
Classes in org.apache.hadoop.hbase.rsgroup that implement StoppableModifier and TypeClassDescriptionclass
GroupBasedLoadBalancer, 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.access
Classes in org.apache.hadoop.hbase.security.access that implement StoppableModifier and TypeClassDescriptionclass
Implementation 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.token
Classes in org.apache.hadoop.hbase.security.token that implement Stoppable -
Uses of Stoppable in org.apache.hadoop.hbase.util
Fields 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.zookeeper
Fields 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.