Uses of Interface
org.apache.hadoop.hbase.Stoppable
Package
Description
Provides HBase Client
Multi Cluster Replication
-
Uses of Stoppable in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Modifier 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.Modifier and TypeFieldDescriptionprivate final Stoppable
ScheduledChore.stopper
A means by which a ScheduledChore can be stopped.Modifier and TypeMethodDescriptionprivate static Stoppable
AuthUtil.createDummyStoppable()
Deprecated.ScheduledChore.getStopper()
ModifierConstructorDescriptionExecutorStatusChore
(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
Modifier 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
Modifier 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
Modifier 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
Modifier and TypeClassDescription(package private) class
CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing algorithm. -
Uses of Stoppable in org.apache.hadoop.hbase.favored
Modifier and TypeClassDescriptionclass
An implementation of theLoadBalancer
that assigns favored nodes for each region. -
Uses of Stoppable in org.apache.hadoop.hbase.master
Modifier and TypeInterfaceDescriptioninterface
Makes decisions about the placement and movement of Regions across RegionServers.interface
A curated subset of services provided byHMaster
.Modifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
ModifierConstructorDescription(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
Modifier 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
Modifier and TypeInterfaceDescriptioninterface
General interface for cleaning files from a folder (generally an archive or backup folder).Modifier 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.ModifierConstructorDescriptionCleanerChore
(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
ModifierConstructorDescriptionprivate
RollingUpgradeChore
(org.apache.hadoop.conf.Configuration conf, ProcedureExecutor<MasterProcedureEnv> procedureExecutor, TableDescriptors tableDescriptors, Stoppable stopper) -
Uses of Stoppable in org.apache.hadoop.hbase.master.snapshot
Modifier 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
Modifier 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
ModifierConstructorDescriptionNamedQueueServiceChore
(Stoppable stopper, int period, NamedQueueRecorder namedQueueRecorder, Connection connection) Chore Constructor -
Uses of Stoppable in org.apache.hadoop.hbase.procedure
Modifier and TypeClassDescriptionclass
A life-cycle management interface for globally barriered procedures on master. -
Uses of Stoppable in org.apache.hadoop.hbase.procedure.flush
-
Uses of Stoppable in org.apache.hadoop.hbase.quotas
Modifier and TypeClassDescriptionclass
Cache that keeps track of the quota settings for the users and tables that are interacting with it.ModifierConstructorDescription(package private)
QuotaObserverChore
(Connection conn, org.apache.hadoop.conf.Configuration conf, SpaceQuotaSnapshotNotifier snapshotNotifier, MasterQuotaManager quotaManager, Stoppable stopper, MetricsMaster metrics) QuotaRefresherChore
(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
Modifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Modifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.(package private) static class
Modifier 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.ModifierConstructorDescriptionBrokenStoreFileCleaner
(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
Modifier and TypeInterfaceDescriptioninterface
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.Modifier 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
ModifierConstructorDescription(package private)
ReplicationStatisticsChore
(String name, Stoppable stopper, int period) -
Uses of Stoppable in org.apache.hadoop.hbase.replication.master
Modifier 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
ModifierConstructorDescriptionReplicationMarkerChore
(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
Modifier 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
Modifier 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
-
Uses of Stoppable in org.apache.hadoop.hbase.util
-
Uses of Stoppable in org.apache.hadoop.hbase.zookeeper
ModifierConstructorDescriptionZKLeaderManager
(ZKWatcher watcher, String leaderZNode, byte[] identifier, Stoppable candidate) Deprecated.