Modifier and Type | Interface and Description |
---|---|
interface |
Server
Defines a curated set of shared functions implemented by HBase servers (Masters and
RegionServers).
|
Modifier and Type | Field and Description |
---|---|
private Stoppable |
ScheduledChore.stopper
A means by which a ScheduledChore can be stopped.
|
Modifier and Type | Method and Description |
---|---|
private static Stoppable |
AuthUtil.createDummyStoppable()
Deprecated.
|
Stoppable |
ScheduledChore.getStopper() |
Constructor and Description |
---|
HealthCheckChore(int sleepTime,
Stoppable stopper,
org.apache.hadoop.conf.Configuration conf) |
ScheduledChore(String name,
Stoppable stopper,
int period)
Construct a ScheduledChore
|
ScheduledChore(String name,
Stoppable stopper,
int period,
long initialDelay)
Construct a ScheduledChore
|
ScheduledChore(String name,
Stoppable stopper,
int period,
long initialDelay,
TimeUnit unit)
Construct a ScheduledChore
|
Modifier and Type | Class and Description |
---|---|
class |
LongTermArchivingHFileCleaner
BaseHFileCleanerDelegate that only cleans HFiles that don't belong to a table that is
currently being archived. |
Modifier and Type | Class and Description |
---|---|
(package private) class |
CatalogReplicaLoadBalanceSimpleSelector
CatalogReplicaLoadBalanceReplicaSimpleSelector implements a simple catalog replica load balancing
algorithm.
|
Modifier and Type | Class and Description |
---|---|
class |
FavoredNodeLoadBalancer
An implementation of the
LoadBalancer that assigns favored
nodes for each region. |
Modifier and Type | Interface and Description |
---|---|
interface |
LoadBalancer
Makes decisions about the placement and movement of Regions across RegionServers.
|
interface |
MasterServices
A curated subset of services provided by
HMaster . |
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster is the "master server" for HBase.
|
static class |
HMasterCommandLine.LocalHMaster |
class |
TableNamespaceManager
This is a helper class used internally to manage the namespace metadata that is stored in
TableName.NAMESPACE_TABLE_NAME.
|
Constructor and Description |
---|
RegionsRecoveryChore(Stoppable stopper,
org.apache.hadoop.conf.Configuration configuration,
HMaster hMaster)
Construct RegionsRecoveryChore with provided params
|
TimeoutMonitor(int period,
Stoppable stopper) |
Modifier and Type | Class and Description |
---|---|
class |
BaseLoadBalancer
The base class for load balancers.
|
class |
FavoredStochasticBalancer
An implementation of the
LoadBalancer that assigns favored
nodes for each region. |
class |
MaintenanceLoadBalancer
a balancer which is only used in maintenance mode.
|
class |
SimpleLoadBalancer
Makes decisions about the placement and movement of Regions across RegionServers.
|
class |
StochasticLoadBalancer
This is a best effort load balancer.
|
Modifier and Type | Interface and Description |
---|---|
interface |
FileCleanerDelegate
General interface for cleaning files from a folder (generally an archive or backup folder).
|
Modifier and Type | Class and Description |
---|---|
class |
BaseFileCleanerDelegate
Base class for file cleaners which allows subclasses to implement a simple isFileDeletable method
(which used to be the FileCleanerDelegate contract).
|
class |
BaseHFileCleanerDelegate
Base class for the hfile cleaning function inside the master.
|
class |
BaseLogCleanerDelegate
Base class for the log cleaning function inside the master.
|
class |
BaseTimeToLiveFileCleaner
Base class for time to live file cleaner.
|
class |
HFileLinkCleaner
HFileLink cleaner that determines if a hfile should be deleted.
|
class |
TimeToLiveHFileCleaner
HFile cleaner that uses the timestamp of the hfile to determine if it should be deleted.
|
class |
TimeToLiveLogCleaner
Log cleaner that uses the timestamp of the wal to determine if it should be deleted.
|
class |
TimeToLiveMasterLocalStoreHFileCleaner
Master local storage HFile cleaner that uses the timestamp of the HFile to determine if it should
be deleted.
|
class |
TimeToLiveMasterLocalStoreWALCleaner
Master local storage WAL cleaner that uses the timestamp of the WAL file to determine if it
should be deleted.
|
class |
TimeToLiveProcedureWALCleaner
Deprecated.
Since 2.3.0, will be removed in 4.0.0. We will not use the procedure wal to store
procedure any more.
|
Constructor and Description |
---|
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) |
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
|
Constructor and Description |
---|
RollingUpgradeChore(org.apache.hadoop.conf.Configuration conf,
ProcedureExecutor<MasterProcedureEnv> procedureExecutor,
TableDescriptors tableDescriptors,
Stoppable stopper) |
Modifier and Type | Class and Description |
---|---|
class |
SnapshotFileCache
Intelligently keep track of all the files for all the snapshots.
|
class |
SnapshotHFileCleaner
Implementation of a file cleaner that checks if a hfile is still used by snapshots of HBase
tables.
|
class |
SnapshotManager
This class manages the procedure of taking and restoring snapshots.
|
Modifier and Type | Class and Description |
---|---|
class |
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. |
Constructor and Description |
---|
SlowLogTableOpsChore(Stoppable stopper,
int period,
NamedQueueRecorder namedQueueRecorder)
Chore Constructor
|
Modifier and Type | Class and Description |
---|---|
class |
MasterProcedureManager
A life-cycle management interface for globally barriered procedures on master.
|
Modifier and Type | Class and Description |
---|---|
class |
MasterFlushTableProcedureManager |
Modifier and Type | Class and Description |
---|---|
class |
QuotaCache
Cache that keeps track of the quota settings for the users and tables that are interacting with
it.
|
Constructor and Description |
---|
QuotaObserverChore(Connection conn,
org.apache.hadoop.conf.Configuration conf,
SpaceQuotaSnapshotNotifier snapshotNotifier,
MasterQuotaManager quotaManager,
Stoppable stopper,
MetricsMaster metrics) |
QuotaRefresherChore(int period,
Stoppable stoppable) |
SnapshotQuotaObserverChore(Connection conn,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
Stoppable stopper,
MetricsMaster metrics) |
Modifier and Type | Interface and Description |
---|---|
interface |
RegionServerServices
A curated subset of services provided by
HRegionServer . |
Modifier and Type | Class and Description |
---|---|
class |
HRegionServer
HRegionServer makes a set of HRegions available to clients.
|
(package private) static class |
ShutdownHook.DoNothingStoppable |
Modifier and Type | Field and Description |
---|---|
private Stoppable |
ShutdownHook.ShutdownHookThread.stop |
Modifier and Type | Method and Description |
---|---|
ScheduledChore |
ServerNonceManager.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 passed
threadToJoin . |
boolean |
ServerNonceManager.startOperation(long group,
long nonce,
Stoppable stoppable)
Starts the operation if operation with such nonce has not already succeeded.
|
Constructor and Description |
---|
BrokenStoreFileCleaner(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) |
CompactionChecker(HRegionServer h,
int sleepTime,
Stoppable stopper) |
ShutdownHookThread(org.apache.hadoop.conf.Configuration conf,
Stoppable stop,
Thread threadToJoin,
Runnable fsShutdownHook) |
StorefileRefresherChore(int period,
boolean onlyMetaRefresh,
HRegionServer regionServer,
Stoppable stoppable) |
Modifier and Type | Interface and Description |
---|---|
interface |
ThroughputController
A utility that constrains the total throughput of one or more simultaneous flows by sleeping when
necessary.
|
Modifier and Type | Class and Description |
---|---|
class |
NoLimitThroughputController |
class |
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 |
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 |
PressureAwareThroughputController |
Constructor and Description |
---|
ReplicationStatisticsChore(String name,
Stoppable stopper,
int period) |
Modifier and Type | Class and Description |
---|---|
class |
ReplicationHFileCleaner
Implementation of a file cleaner that checks if a hfile is still scheduled for replication before
deleting it from hfile archive directory.
|
class |
ReplicationLogCleaner
Implementation of a log cleaner that checks if a log is still scheduled for replication before
deleting it when its TTL is over.
|
Modifier and Type | Class and Description |
---|---|
(package private) class |
ReplicationSyncUp.DummyServer |
Modifier and Type | Interface and Description |
---|---|
interface |
RSGroupableBalancer
Marker Interface.
|
Modifier and Type | Class and Description |
---|---|
class |
RSGroupBasedLoadBalancer
GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does
region balance based on a table's group membership.
|
Modifier and Type | Class and Description |
---|---|
class |
SnapshotScannerHDFSAclCleaner
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
|
Modifier and Type | Class and Description |
---|---|
private class |
AuthenticationTokenSecretManager.LeaderElector |
Modifier and Type | Field and Description |
---|---|
private Stoppable |
Sleeper.stopper |
Constructor and Description |
---|
Sleeper(int sleep,
Stoppable stopper) |
Modifier and Type | Field and Description |
---|---|
private Stoppable |
ZKLeaderManager.candidate
Deprecated.
|
Constructor and Description |
---|
ZKLeaderManager(ZKWatcher watcher,
String leaderZNode,
byte[] identifier,
Stoppable candidate)
Deprecated.
|
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.