| Interface | Description | 
|---|---|
| AssignmentListener | 
 Get notification of assignment events. 
 | 
| ClusterStatusPublisher.Publisher | |
| LoadBalancer | 
 Makes decisions about the placement and movement of Regions across
 RegionServers. 
 | 
| MasterServices | 
 Services Master supplies 
 | 
| MetricsAssignmentManagerSource | |
| MetricsMasterFileSystemSource | |
| MetricsMasterProcSource | 
 Interface that classes that expose metrics about the master will implement. 
 | 
| MetricsMasterProcSourceFactory | 
 Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper 
 | 
| MetricsMasterSource | 
 Interface that classes that expose metrics about the master will implement. 
 | 
| MetricsMasterSourceFactory | 
 Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper 
 | 
| MetricsMasterWrapper | 
 This is the interface that will expose information to hadoop1/hadoop2 implementations of the
 MetricsMasterSource. 
 | 
| MetricsSnapshotSource | |
| ServerListener | 
 Get notification of server events. 
 | 
| SnapshotSentinel | 
 Watch the current snapshot under process 
 | 
| TableLockManager.TableLock | 
 A distributed lock for a table. 
 | 
| Class | Description | 
|---|---|
| ActiveMasterManager | 
 Handles everything on master-side related to master election. 
 | 
| AssignCallable | 
 A callable object that invokes the corresponding action that needs to be
 taken for assignment of a region in transition. 
 | 
| AssignmentManager | 
 Manages and performs region assignment. 
 | 
| AssignmentVerificationReport | 
 Helper class that is used by  
RegionPlacementMaintainer to print
 information for favored nodes | 
| BulkAssigner | 
 Base class used bulk assigning and unassigning regions. 
 | 
| BulkReOpen | 
 Performs bulk reopen of the list of regions provided to it. 
 | 
| CatalogJanitor | 
 A janitor for the catalog tables. 
 | 
| ClusterStatusPublisher | 
 Class to publish the cluster status to the client. 
 | 
| ClusterStatusPublisher.MulticastPublisher | |
| DeadServer | 
 Class to hold dead servers list and utility querying dead server list. 
 | 
| ExpiredMobFileCleanerChore | 
 The Class ExpiredMobFileCleanerChore for running cleaner regularly to remove the expired
 mob files. 
 | 
| GeneralBulkAssigner | 
 Run bulk assign. 
 | 
| HMaster | 
 HMaster is the "master server" for HBase. 
 | 
| HMaster.RedirectServlet | |
| HMasterCommandLine | |
| HMasterCommandLine.LocalHMaster | |
| MasterCoprocessorHost | 
 Provides the coprocessor framework and environment for master oriented
 operations. 
 | 
| MasterDumpServlet | |
| MasterFileSystem | 
 This class abstracts a bunch of operations the HMaster needs to interact with
 the underlying file system, including splitting log files, checking file
 system status, etc. 
 | 
| MasterMobCompactionThread | 
 The mob compaction thread used in  
MasterRpcServices | 
| MasterRpcServices | 
 Implements the master RPC services. 
 | 
| MasterStatusServlet | 
 The servlet responsible for rendering the index page of the
 master. 
 | 
| MetricsAssignmentManager | |
| MetricsAssignmentManagerSourceImpl | |
| MetricsMaster | 
 This class is for maintaining the various master statistics
 and publishing them through the metrics interfaces. 
 | 
| MetricsMasterFileSystem | |
| MetricsMasterFilesystemSourceImpl | |
| MetricsMasterProcSourceFactoryImpl | 
 Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper 
 | 
| MetricsMasterProcSourceImpl | 
 Hadoop2 implementation of MetricsMasterSource. 
 | 
| MetricsMasterSourceFactoryImpl | 
 Factory to create MetricsMasterSource when given a  MetricsMasterWrapper 
 | 
| MetricsMasterSourceImpl | 
 Hadoop2 implementation of MetricsMasterSource. 
 | 
| MetricsMasterWrapperImpl | 
 Impl for exposing HMaster Information through JMX 
 | 
| MetricsSnapshot | |
| MetricsSnapshotSourceImpl | |
| MobCompactionChore | 
 The Class MobCompactChore for running compaction regularly to merge small mob files. 
 | 
| Mocking | 
 Package scoped mocking utility. 
 | 
| OfflineCallback | 
 Callback handler for creating unassigned offline znodes
 used during bulk assign, async setting region to offline. 
 | 
| RackManager | 
 Wrapper over the rack resolution utility in Hadoop. 
 | 
| RegionPlacementMaintainer | 
 A tool that is used for manipulating and viewing favored nodes information
 for regions. 
 | 
| RegionPlacementMaintainer.RandomizedMatrix | 
 Some algorithms for solving the assignment problem may traverse workers or
 jobs in linear order which may result in skewing the assignments of the
 first jobs in the matrix toward the last workers in the matrix if the
 costs are uniform. 
 | 
| RegionPlan | 
 Stores the plan for the move of an individual region. 
 | 
| RegionPlan.RegionPlanComparator | |
| RegionState | 
 State of a Region while undergoing transitions. 
 | 
| RegionStates | 
 Region state accountant. 
 | 
| RegionStateStore | 
 A helper to persist region state in meta. 
 | 
| ServerManager | 
 The ServerManager class manages info about region servers. 
 | 
| SnapshotOfRegionAssignmentFromMeta | 
 Used internally for reading meta and constructing datastructures that are
 then queried, for things like regions to regionservers, table to regions, etc. 
 | 
| SplitLogManager | 
 Distributes the task of log splitting to the available region servers. 
 | 
| SplitLogManager.Task | 
 in memory state of an active task. 
 | 
| SplitLogManager.TaskBatch | 
 Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed(). 
 | 
| TableLockManager | 
 A manager for distributed table level locks. 
 | 
| TableLockManager.NullTableLockManager | 
 A null implementation 
 | 
| TableNamespaceManager | 
 This is a helper class used to manage the namespace
 metadata that is stored in TableName.NAMESPACE_TABLE_NAME
 It also mirrors updates to the ZK store by forwarding updates to
  
ZKNamespaceManager | 
| TestActiveMasterManager | 
 Test the  
ActiveMasterManager. | 
| TestActiveMasterManager.DummyMaster | 
 Dummy Master Implementation. 
 | 
| TestActiveMasterManager.NodeDeletionListener | |
| TestActiveMasterManager.WaitToBeMasterThread | |
| TestAssignmentListener | |
| TestAssignmentManager | 
 Test  
AssignmentManager | 
| 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. 
 | 
| TestAssignmentManagerOnCluster | 
 This tests AssignmentManager with a testing cluster. 
 | 
| TestAssignmentManagerOnCluster.MyMaster | |
| TestAssignmentManagerOnCluster.MyRegionObserver | |
| TestAssignmentManagerOnCluster.MyRegionServer | |
| TestCatalogJanitor | |
| TestClockSkewDetection | |
| TestClusterStatusPublisher | |
| TestDeadServer | |
| TestDistributedLogSplitting | |
| TestGetInfoPort | 
 Trivial test to confirm that we do not get 0 infoPort. 
 | 
| TestGetLastFlushedSequenceId | 
 Trivial test to confirm that we can get last flushed sequence id by encodedRegionName. 
 | 
| TestHMasterCommandLine | |
| TestHMasterRPCException | |
| TestMaster | |
| TestMasterFailover | |
| TestMasterFailoverBalancerPersistence | |
| TestMasterFileSystem | 
 Test the master filesystem in a local cluster 
 | 
| TestMasterFileSystemWithWALDir | 
 Test the master filesystem in a local cluster 
 | 
| TestMasterMetrics | |
| TestMasterMetrics.MyMaster | |
| TestMasterMetricsWrapper | |
| TestMasterNoCluster | 
 Standup the master and fake it to test various aspects of master function. 
 | 
| TestMasterOperationsForRegionReplicas | |
| TestMasterPriorityRpc | 
 Tests to verify correct priority on Master RPC methods. 
 | 
| TestMasterRestartAfterDisablingTable | |
| TestMasterShutdown | |
| TestMasterStatusServlet | 
 Tests for the master status page and its template. 
 | 
| TestMasterTransitions | 
 Test transitions of state across the master. 
 | 
| TestMetaShutdownHandler | 
 Tests handling of meta-carrying region server failover. 
 | 
| TestMetaShutdownHandler.MyRegionServer | |
| TestMetricsMasterProcSourceImpl | 
 Test for MetricsMasterProcSourceImpl 
 | 
| TestMetricsMasterSourceFactory | 
 Test for the CompatibilitySingletonFactory and building MetricsMasterSource 
 | 
| TestMetricsMasterSourceImpl | 
 Test for MetricsMasterSourceImpl 
 | 
| TestOpenedRegionHandler | |
| TestProcedureConf | |
| TestRegionPlacement | |
| TestRegionPlacement2 | |
| TestRegionPlan | |
| TestRegionState | |
| TestRegionStates | |
| TestRestartCluster | |
| TestRollingRestart | 
 Tests the restarting of everything as done during rolling restarts. 
 | 
| TestSplitLogManager | |
| TestTableLockManager | 
 Tests the default table lock manager 
 | 
| TestTableLockManager.TestAlterAndDisableMasterObserver | |
| TestTableLockManager.TestLockTimeoutExceptionMasterObserver | |
| TestWarmupRegion | 
 Run tests that use the HBase clients;  
HTable. | 
| TestZKBasedOpenCloseRegion | 
 Test open and close of regions using zk. 
 | 
| TestZKLessAMOnCluster | 
 This tests AssignmentManager with a testing cluster. 
 | 
| UnAssignCallable | 
 A callable object that invokes the corresponding action that needs to be
 taken for unassignment of a region in transition. 
 | 
| Enum | Description | 
|---|---|
| AssignmentManager.ServerHostRegion | |
| RegionState.State | |
| SplitLogManager.ResubmitDirective | |
| SplitLogManager.TerminationStatus |