Interface | Description |
---|---|
ClusterSchema |
View and edit the current cluster schema.
|
ClusterSchemaService |
Mixes in ClusterSchema and Service
|
ClusterStatusPublisher.Publisher | |
HMaster.TableDescriptorGetter |
Implement to return TableDescriptor after pre-checks
|
LoadBalancer |
Makes decisions about the placement and movement of Regions across RegionServers.
|
MasterServices |
A curated subset of services provided by
HMaster . |
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
|
MetricsMasterQuotaSource |
A collection of exposed metrics for space quotas from the HBase Master.
|
MetricsMasterQuotaSourceFactory |
Interface of a factory to create MetricsMasterQuotaSource 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 | |
RegionServerList |
For storing the region server list.
|
ServerListener |
Get notification of server registration events.
|
SnapshotSentinel |
Watch the current snapshot under process
|
Class | Description |
---|---|
ActiveMasterManager |
Handles everything on master-side related to master election.
|
AssignmentVerificationReport |
Helper class that is used by
RegionPlacementMaintainer to print information for favored
nodes |
CachedClusterId |
Caches the cluster ID of the cluster.
|
ClusterSchemaServiceImpl | |
ClusterStatusPublisher |
Class to publish the cluster status to the client.
|
ClusterStatusPublisher.MulticastPublisher | |
ClusterStatusPublisher.MulticastPublisher.ClusterMetricsEncoder | |
ClusterStatusPublisher.MulticastPublisher.HBaseDatagramChannelFactory<T extends org.apache.hbase.thirdparty.io.netty.channel.Channel> | |
DeadServer |
Class to hold dead servers list and utility querying dead server list.
|
DrainingServerTracker |
Tracks the list of draining region servers via ZK.
|
HMaster |
HMaster is the "master server" for HBase.
|
HMasterCommandLine | |
HMasterCommandLine.LocalHMaster | |
MasterAnnotationReadingPriorityFunction |
Priority function specifically for the master.
|
MasterCoprocessorHost |
Provides the coprocessor framework and environment for master oriented operations.
|
MasterCoprocessorHost.MasterEnvironment |
Coprocessor environment extension providing access to master related services.
|
MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors |
Special version of MasterEnvironment that exposes MasterServices for Core Coprocessors only.
|
MasterFileSystem |
This class abstracts a bunch of operations the HMaster needs to interact with the underlying file
system like creating the initial layout, checking file system status, etc.
|
MasterInitializationMonitor |
Protection against zombie master.
|
MasterRegionServerList |
MasterRegion based RegionServerList . |
MasterRpcServices |
Implements the master RPC services.
|
MasterWalManager |
This class abstracts a bunch of operations the HMaster needs when splitting log files e.g.
|
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.
|
MetricsMasterQuotaSourceFactoryImpl |
Factory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.
|
MetricsMasterQuotaSourceImpl |
Implementation of
MetricsMasterQuotaSource which writes the values passed in via the
interface to the metrics backend. |
MetricsMasterSourceFactoryImpl |
Factory to create MetricsMasterSource when given a MetricsMasterWrapper
|
MetricsMasterSourceImpl |
Hadoop2 implementation of MetricsMasterSource.
|
MetricsMasterWrapperImpl |
Impl for exposing HMaster Information through JMX
|
MetricsSnapshot | |
MetricsSnapshotSourceImpl | |
MirroringTableStateManager | Deprecated
Since 2.0.0.
|
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 | |
RegionServerTracker |
Tracks the online region servers via ZK.
|
RegionsRecoveryChore |
This chore, every time it runs, will try to recover regions with high store ref count by
reopening them
|
RegionsRecoveryConfigManager |
Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
|
RegionState |
State of a Region while undergoing transitions.
|
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 | Deprecated
since 2.4.0 and in 3.0.0, to be removed in 4.0.0, replaced by procedure-based
distributed WAL splitter, see SplitWALManager.
|
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().
|
SplitOrMergeTracker |
Tracks the switch of split and merge states in ZK
|
SplitOrMergeTracker.SwitchStateTracker | |
SplitWALManager |
Create
SplitWALProcedure for each WAL which need to split. |
SplitWALManager.SplitWorkerAssigner |
help assign and release a worker for each WAL splitting task For each worker, concurrent
running splitting task should be no more than maxSplitTasks If a task failed to acquire a
worker, it will suspend and wait for workers available
|
TableNamespaceManager |
This is a helper class used internally to manage the namespace metadata that is stored in
TableName.NAMESPACE_TABLE_NAME.
|
TableStateManager |
This is a helper class used to manage table states.
|
Exception | Description |
---|---|
NoSuchProcedureException |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.