Uses of Interface
org.apache.hadoop.hbase.Stoppable
Packages that use org.apache.hadoop.hbase.Stoppable
Package
Description
-
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase
Subinterfaces of org.apache.hadoop.hbase.Stoppable in in org.apache.hadoop.hbaseModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.ServerDefines a curated set of shared functions implemented by HBase servers (Masters and RegionServers).Classes in org.apache.hadoop.hbase that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.HBaseServerBase<R extends org.apache.hadoop.hbase.HBaseRpcServicesBase<?>>Base class for hbase services, such as master or region server.static classorg.apache.hadoop.hbase.MiniHBaseCluster.MiniHBaseClusterRegionServerDeprecated.Subclass so can get at protected methods (none at moment).classorg.apache.hadoop.hbase.MockRegionServerServicesBasic mock region server services.Methods in org.apache.hadoop.hbase that return org.apache.hadoop.hbase.Stoppable in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.StoppableScheduledChore.getStopper()Constructors in org.apache.hadoop.hbase with parameters of type org.apache.hadoop.hbase.Stoppable in inModifierConstructorDescriptionExecutorStatusChore(int sleepTime, org.apache.hadoop.hbase.Stoppable stopper, org.apache.hadoop.hbase.executor.ExecutorService service, org.apache.hadoop.hbase.regionserver.MetricsRegionServerSource metrics) HealthCheckChore(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
Classes in org.apache.hadoop.hbase.backup that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.backup.BackupHFileCleanerFile cleaner that prevents deletion of HFiles that are still required by future incremental backups. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.favored
Classes in org.apache.hadoop.hbase.favored that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.favored.FavoredNodeLoadBalancerAn implementation of theLoadBalancerthat assigns favored nodes for each region. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master
Subinterfaces of org.apache.hadoop.hbase.Stoppable in in org.apache.hadoop.hbase.masterModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.master.LoadBalancerMakes decisions about the placement and movement of Regions across RegionServers.interfaceorg.apache.hadoop.hbase.master.MasterServicesA curated subset of services provided byHMaster.Classes in org.apache.hadoop.hbase.master that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.HMasterHMaster is the "master server" for HBase.static classorg.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master.balancer
Classes in org.apache.hadoop.hbase.master.balancer that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.balancer.BaseLoadBalancerThe base class for load balancers. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.master.cleaner
Classes in org.apache.hadoop.hbase.master.cleaner that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.cleaner.BaseFileCleanerDelegateBase class for file cleaners which allows subclasses to implement a simple isFileDeletable method (which used to be the FileCleanerDelegate contract).classorg.apache.hadoop.hbase.master.cleaner.BaseHFileCleanerDelegateBase class for the hfile cleaning function inside the master. -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.mob
Classes in org.apache.hadoop.hbase.mob that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.mob.ManualMobMaintHFileCleanerBaseHFileCleanerDelegatethat 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
Constructors in org.apache.hadoop.hbase.namequeues with parameters of type org.apache.hadoop.hbase.Stoppable in inModifierConstructorDescriptionNamedQueueServiceChore(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
Classes in org.apache.hadoop.hbase.quotas that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.quotas.QuotaCacheCache 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
Subinterfaces of org.apache.hadoop.hbase.Stoppable in in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.regionserver.RegionServerServicesA curated subset of services provided byHRegionServer.Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.HRegionServerHRegionServer makes a set of HRegions available to clients.Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Stoppable in inModifier and TypeMethodDescriptionorg.apache.hadoop.hbase.ScheduledChoreServerNonceManager.createCleanupScheduledChore(org.apache.hadoop.hbase.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, 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.booleanServerNonceManager.startOperation(long group, long nonce, org.apache.hadoop.hbase.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 org.apache.hadoop.hbase.Stoppable in inModifierConstructorDescriptionBrokenStoreFileCleaner(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
Subinterfaces of org.apache.hadoop.hbase.Stoppable in in org.apache.hadoop.hbase.regionserver.throttleModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.regionserver.throttle.ThroughputControllerA 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 org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.throttle.NoLimitThroughputControllerclassorg.apache.hadoop.hbase.regionserver.throttle.PressureAwareCompactionThroughputControllerA 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]classorg.apache.hadoop.hbase.regionserver.throttle.PressureAwareFlushThroughputControllerA 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)classorg.apache.hadoop.hbase.regionserver.throttle.PressureAwareThroughputController -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.rsgroup
Classes in org.apache.hadoop.hbase.rsgroup that implement org.apache.hadoop.hbase.Stoppable in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancerGroupBasedLoadBalancer, 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
Constructors in org.apache.hadoop.hbase.util with parameters of type org.apache.hadoop.hbase.Stoppable in inModifierConstructorDescriptionSleeper(int sleep, org.apache.hadoop.hbase.Stoppable stopper) -
Uses of org.apache.hadoop.hbase.Stoppable in org.apache.hadoop.hbase.zookeeper
Constructors in org.apache.hadoop.hbase.zookeeper with parameters of type org.apache.hadoop.hbase.Stoppable in inModifierConstructorDescriptionZKLeaderManager(org.apache.hadoop.hbase.zookeeper.ZKWatcher watcher, String leaderZNode, byte[] identifier, org.apache.hadoop.hbase.Stoppable candidate) Deprecated.