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 | Method and Description |
---|---|
Stoppable |
ScheduledChore.getStopper() |
Constructor and Description |
---|
HealthCheckChore(int sleepTime,
Stoppable stopper,
org.apache.hadoop.conf.Configuration conf) |
ScheduledChore(String name,
Stoppable stopper,
int period) |
ScheduledChore(String name,
Stoppable stopper,
int period,
long initialDelay) |
ScheduledChore(String name,
Stoppable stopper,
int period,
long initialDelay,
TimeUnit unit) |
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 |
---|---|
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.
|
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 |
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 |
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 |
TimeToLiveProcedureWALCleaner
Procedure WAL cleaner that uses the timestamp of the Procedure WAL to determine if it should be
deleted.
|
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) |
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,
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) |
HFileCleaner(int period,
Stoppable stopper,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path directory,
Map<String,Object> params) |
LogCleaner(int period,
Stoppable stopper,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path oldLogDir) |
ReplicationBarrierCleaner(org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
Connection conn,
ReplicationPeerManager peerManager) |
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 |
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.
|
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.
|
protected static class |
HRegionServer.MovedRegionsCleaner
Creates a Chore thread to clean the moved region cache.
|
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 |
---|
CompactedHFilesDischarger(int period,
Stoppable stopper,
RegionServerServices regionServerServices) |
CompactedHFilesDischarger(int period,
Stoppable stopper,
RegionServerServices regionServerServices,
boolean useExecutor) |
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 |
Modifier and Type | Method and Description |
---|---|
static ReplicationTracker |
ReplicationFactory.getReplicationTracker(ZKWatcher zookeeper,
Abortable abortable,
Stoppable stopper) |
Constructor and Description |
---|
ReplicationTrackerZKImpl(ZKWatcher zookeeper,
Abortable abortable,
Stoppable stopper) |
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.
|
Constructor and Description |
---|
ReplicationSink(org.apache.hadoop.conf.Configuration conf,
Stoppable stopper)
Create a sink for replication
|
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.
|
Constructor and Description |
---|
Sleeper(int sleep,
Stoppable stopper) |
Constructor and Description |
---|
ZKLeaderManager(ZKWatcher watcher,
String leaderZNode,
byte[] identifier,
Stoppable candidate)
Deprecated.
|
Copyright © 2007–2019 Cloudera. All rights reserved.