Interface | Description |
---|---|
AssignmentListener |
Get notification of assignment events.
|
AssignmentManager.RegionRunnable |
A specific runnable that works only on a region.
|
ClusterStatusPublisher.Publisher | |
LoadBalancer |
Makes decisions about the placement and movement of Regions across
RegionServers.
|
MasterServices |
Services Master supplies
|
MetricsAssignmentManagerSource | |
MetricsMasterFileSystemSource | |
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.
|
CatalogJanitor.SplitParentFirstComparator |
Compare HRegionInfos in a way that has split parents sort BEFORE their
daughters.
|
ClusterStatusPublisher |
Class to publish the cluster status to the client.
|
ClusterStatusPublisher.MulticastPublisher | |
ClusterStatusPublisher.MulticastPublisher.ClusterStatusEncoder | |
ClusterStatusPublisher.MulticastPublisher.HBaseDatagramChannelFactory<T extends io.netty.channel.Channel> | |
DeadServer |
Class to hold dead servers list and utility querying dead server list.
|
GeneralBulkAssigner |
Run bulk assign.
|
GeneralBulkAssigner.SingleServerBulkAssigner |
Manage bulk assigning to a server.
|
HMaster |
HMaster is the "master server" for HBase.
|
HMaster.InitializationMonitor |
Protection against zombie master.
|
HMaster.PeriodicDoMetrics | |
HMaster.RedirectServlet | |
HMasterCommandLine | |
HMasterCommandLine.LocalHMaster | |
MasterAnnotationReadingPriorityFunction |
Priority function specifically for the master.
|
MasterCoprocessorHost |
Provides the coprocessor framework and environment for master oriented
operations.
|
MasterCoprocessorHost.CoprocessorOperation | |
MasterCoprocessorHost.CoprocessorOperationWithResult<T> | |
MasterCoprocessorHost.MasterEnvironment |
Coprocessor environment extension providing access to master related
services.
|
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.
|
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 | |
MetricsMasterSourceFactoryImpl |
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
|
MetricsMasterSourceImpl |
Hadoop2 implementation of MetricsMasterSource.
|
MetricsMasterWrapperImpl |
Impl for exposing HMaster Information through JMX
|
MetricsSnapshot | |
MetricsSnapshotSourceImpl | |
OfflineCallback |
Callback handler for creating unassigned offline znodes
used during bulk assign, async setting region to offline.
|
OfflineCallback.ExistCallback |
Callback handler for the exists call that sets watcher on unassigned znodes.
|
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
|
TableLockManager.NullTableLockManager.NullTableLock | |
TableLockManager.ZKTableLockManager |
ZooKeeper based TableLockManager
|
TableLockManager.ZKTableLockManager.TableLockImpl | |
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 |
UnAssignCallable |
A callable object that invokes the corresponding action that needs to be
taken for unassignment of a region in transition.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.