Modifier and Type | Interface and Description |
---|---|
interface |
Server
Defines the set of shared functions implemented by HBase servers (Masters
and RegionServers).
|
Modifier and Type | Class and Description |
---|---|
static class |
MiniHBaseCluster.MiniHBaseClusterRegionServer
Subclass so can get at protected methods (none at moment).
|
class |
MockRegionServerServices
Basic mock region server services.
|
static class |
TestChoreService.ScheduledChoreSamples.SampleStopper
Straight forward stopper implementation that is used by default when one is not provided
|
static class |
TestLocalHBaseCluster.MyHMaster
A private master class similar to that used by HMasterCommandLine when
running in local mode.
|
static class |
TestLocalHBaseCluster.MyHRegionServer
A private regionserver class with a dummy method for testing casts
|
Modifier and Type | Method and Description |
---|---|
Stoppable |
ScheduledChore.getStopper() |
Constructor and Description |
---|
CountingChore(String name,
Stoppable stopper,
int period) |
CountingChore(String name,
Stoppable stopper,
int period,
boolean outputOnTicks) |
DoNothingChore(String name,
Stoppable stopper,
int period) |
FailInitialChore(String name,
Stoppable stopper,
int period,
int failThreshold) |
HealthCheckChore(int sleepTime,
Stoppable stopper,
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) |
SleepingChore(String name,
Stoppable stopper,
int period,
int sleepTime) |
SlowChore(String name,
Stoppable stopper,
int period) |
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 |
CalmChaosMonkey
Chaos Monkey that does nothing.
|
class |
ChaosMonkey
A utility to injects faults in a running cluster.
|
class |
PolicyBasedChaosMonkey
Chaos monkey that given multiple policies will run actions against the cluster.
|
Modifier and Type | Class and Description |
---|---|
class |
CompositeSequentialPolicy
A policy that runs multiple other policies one after the other
|
class |
DoActionsOncePolicy
A policy which performs a sequence of actions deterministically.
|
class |
PeriodicPolicy
A policy which does stuff every time interval.
|
class |
PeriodicRandomActionPolicy
A policy, which picks a random action according to the given weights,
and performs it every configurable period.
|
class |
Policy
A policy to introduce chaos to the cluster
|
class |
TwoConcurrentActionPolicy
Chaos Monkey policy that will run two different actions at the same time.
|
Modifier and Type | Interface and Description |
---|---|
interface |
LoadBalancer
Makes decisions about the placement and movement of Regions across
RegionServers.
|
interface |
MasterServices
Services Master supplies
|
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster is the "master server" for HBase.
|
static class |
HMasterCommandLine.LocalHMaster |
static class |
TestActiveMasterManager.DummyMaster
Dummy Master Implementation.
|
static class |
TestAssignmentManager.MockedLoadBalancer
Mocked load balancer class used in the testcase to make sure that the testcase waits until
random assignment is called and the gate variable is set to true.
|
static class |
TestAssignmentManagerOnCluster.MyMaster |
static class |
TestAssignmentManagerOnCluster.MyRegionServer |
static class |
TestMasterMetrics.MyMaster |
static class |
TestMetaShutdownHandler.MyRegionServer |
Constructor and Description |
---|
SplitLogManager(Server server,
Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName)
Its OK to construct this object even when region-servers are not online.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseLoadBalancer
The base class for load balancers.
|
class |
FavoredNodeLoadBalancer
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.
|
static class |
TestBaseLoadBalancer.MockBalancer |
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.
|
static class |
TestCleanerChore.AlwaysDelete |
static class |
TestCleanerChore.NeverDelete |
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.
|
Constructor and Description |
---|
CleanerChore(String name,
int sleepPeriod,
Stoppable s,
Configuration conf,
FileSystem fs,
Path oldFileDir,
String confKey) |
HFileCleaner(int period,
Stoppable stopper,
Configuration conf,
FileSystem fs,
Path directory) |
LogCleaner(int p,
Stoppable s,
Configuration conf,
FileSystem fs,
Path oldLogDir) |
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 |
SnapshotLogCleaner
Implementation of a log cleaner that checks if a log 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.
|
class |
SimpleMasterProcedureManager |
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 |
OnlineRegions
Interface to Map of online regions.
|
interface |
RegionServerServices
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.
|
class |
OOMERegionServer
A region server that will OOME.
|
static class |
TestRegionServerReportForDuty.MyRegionServer |
static class |
TestRSKilledWhenInitializing.MockedRegionServer |
static class |
TestSplitTransactionOnCluster.MockMasterWithoutCatalogJanitor |
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(Configuration conf,
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 |
---|
StorefileRefresherChore(int period,
boolean onlyMetaRefresh,
HRegionServer regionServer,
Stoppable stoppable) |
Modifier and Type | Interface and Description |
---|---|
interface |
CompactionThroughputController
A utility that constrains the total throughput of one or more simultaneous flows (compactions) by
sleeping when necessary.
|
Modifier and Type | Class and Description |
---|---|
class |
NoLimitCompactionThroughputController
A dummy CompactionThroughputController that does nothing.
|
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 tune 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]
|
Modifier and Type | Method and Description |
---|---|
static ReplicationTracker |
ReplicationFactory.getReplicationTracker(ZooKeeperWatcher zookeeper,
ReplicationPeers replicationPeers,
Configuration conf,
Abortable abortable,
Stoppable stopper) |
void |
ReplicationSourceDummy.init(Configuration conf,
FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues rq,
ReplicationPeers rp,
Stoppable stopper,
String peerClusterId,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
MetricsSource metrics) |
Constructor and Description |
---|
ReplicationTrackerZKImpl(ZooKeeperWatcher zookeeper,
ReplicationPeers replicationPeers,
Configuration conf,
Abortable abortable,
Stoppable stopper) |
Modifier and Type | Class and Description |
---|---|
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 | Method and Description |
---|---|
void |
ReplicationSource.init(Configuration conf,
FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Stoppable stopper,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
MetricsSource metrics)
Instantiation method used by region servers
|
void |
ReplicationSourceInterface.init(Configuration conf,
FileSystem fs,
ReplicationSourceManager manager,
ReplicationQueues replicationQueues,
ReplicationPeers replicationPeers,
Stoppable stopper,
String peerClusterZnode,
UUID clusterId,
ReplicationEndpoint replicationEndpoint,
MetricsSource metrics)
Initializer for the source
|
Constructor and Description |
---|
ReplicationSink(Configuration conf,
Stoppable stopper)
Create a sink for replication
|
Modifier and Type | Class and Description |
---|---|
class |
MockServer
Basic mock Server for handler tests.
|
class |
StoppableImplementation
A base implementation for a Stoppable service
|
Constructor and Description |
---|
Sleeper(int sleep,
Stoppable stopper) |
Constructor and Description |
---|
ZKLeaderManager(ZooKeeperWatcher watcher,
String leaderZNode,
byte[] identifier,
Stoppable candidate)
Deprecated.
|