Uses of Interface
org.apache.hadoop.hbase.Stoppable
Package
Description
-
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.Server
Defines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.Stoppable
ScheduledChore.getStopper()
ModifierConstructorDescriptionHealthCheckChore
(int sleepTime, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.conf.Configuration conf) ScheduledChore
(String name, org.apache.hadoop.hbase.Stoppable stopper, int period) Construct a ScheduledChoreScheduledChore
(String name, org.apache.hadoop.hbase.Stoppable stopper, int period, long initialDelay) Construct a ScheduledChoreScheduledChore
(String name, org.apache.hadoop.hbase.Stoppable stopper, int period, long initialDelay, TimeUnit unit) Construct a ScheduledChore -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.backup
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.backup.BackupHFileCleaner
Implementation of a file cleaner that checks if an hfile is still referenced by backup before deleting it from hfile archive directory. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.favored
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
An implementation of theLoadBalancer
that assigns favored nodes for each region. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.master.LoadBalancer
Makes decisions about the placement and movement of Regions across RegionServers.interface
org.apache.hadoop.hbase.master.MasterServices
A curated subset of services provided byHMaster
.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.master.HMaster
HMaster is the "master server" for HBase.static class
org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
class
org.apache.hadoop.hbase.master.TableNamespaceManager
This is a helper class used internally to manage the namespace metadata that is stored in TableName.NAMESPACE_TABLE_NAME. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master.balancer
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
The base class for load balancers. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master.cleaner
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegate
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).class
org.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegate
Base class for the hfile cleaning function inside the master. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.mob
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.mob.ManualMobMaintHFileCleaner
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 org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.namequeues
ModifierConstructorDescriptionNamedQueueServiceChore
(org.apache.hadoop.hbase.Stoppable stopper, int period, org.apache.hadoop.hbase.namequeues.NamedQueueRecorder namedQueueRecorder, org.apache.hadoop.hbase.client.Connection connection) Chore Constructor -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.quotas
Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.quotas.QuotaCache
Cache that keeps track of the quota settings for the users and tables that are interacting with it. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.regionserver
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.regionserver.RegionServerServices
A curated subset of services provided byHRegionServer
.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.HRegionServer
HRegionServer makes a set of HRegions available to clients.Modifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ScheduledChore
ServerNonceManager.createCleanupScheduledChore
(org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.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, org.apache.hadoop.hbase.Stoppable stoppable) Starts the operation if operation with such nonce has not already succeeded.ModifierConstructorDescriptionBrokenStoreFileCleaner
(int delay, int period, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.HRegionServer regionServer) CompactedHFilesDischarger
(int period, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.hbase.regionserver.RegionServerServices regionServerServices) CompactedHFilesDischarger
(int period, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.hbase.regionserver.RegionServerServices regionServerServices, boolean useExecutor) StorefileRefresherChore
(int period, boolean onlyMetaRefresh, org.apache.hadoop.hbase.regionserver.HRegionServer regionServer, org.apache.hadoop.hbase.Stoppable stoppable) -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.regionserver.throttle
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.regionserver.throttle.ThroughputController
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when necessary.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputController
class
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputController
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
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputController
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
org.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController
-
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.rsgroup
Modifier and TypeInterfaceDescriptioninterface
org.apache.hadoop.hbase.rsgroup.RSGroupableBalancer
Marker Interface.Modifier and TypeClassDescriptionclass
org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.util
ModifierConstructorDescriptionSleeper
(int sleep, org.apache.hadoop.hbase.Stoppable stopper) -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.zookeeper
ModifierConstructorDescriptionZKLeaderManager
(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String leaderZNode, byte[] identifier, org.apache.hadoop.hbase.Stoppable candidate) Deprecated.