Package org.apache.hadoop.hbase.master
package org.apache.hadoop.hbase.master
-
ClassDescriptionorg.apache.hadoop.hbase.master.ActiveMasterManagerHandles everything on master-side related to master election.org.apache.hadoop.hbase.master.AssignmentVerificationReportHelper class that is used by RegionPlacementMaintainer to print information for favored nodesorg.apache.hadoop.hbase.master.BooleanStateStoreStore a boolean state.org.apache.hadoop.hbase.master.CachedClusterIdCaches the cluster ID of the cluster.org.apache.hadoop.hbase.master.ClusterSchemaView and edit the current cluster schema.org.apache.hadoop.hbase.master.ClusterSchemaServiceMixes in ClusterSchema and Serviceorg.apache.hadoop.hbase.master.ClusterStatusPublisherClass to publish the cluster status to the client.org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisherorg.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisherorg.apache.hadoop.hbase.master.DeadServerClass to hold dead servers list and utility querying dead server list.org.apache.hadoop.hbase.master.DrainingServerTrackerTracks the list of draining region servers via ZK.org.apache.hadoop.hbase.master.HMasterHMaster is the "master server" for HBase.org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetterImplement to return TableDescriptor after pre-checksorg.apache.hadoop.hbase.master.HMasterCommandLineorg.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMasterorg.apache.hadoop.hbase.master.LoadBalancerMakes decisions about the placement and movement of Regions across RegionServers.org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunctionPriority function specifically for the master.org.apache.hadoop.hbase.master.MasterCoprocessorHostProvides the coprocessor framework and environment for master oriented operations.org.apache.hadoop.hbase.master.MasterFileSystemThis 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.org.apache.hadoop.hbase.master.MasterRegionServerList
MasterRegion
basedRegionServerList
.org.apache.hadoop.hbase.master.MasterRpcServicesImplements the master RPC services.org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapperA wrapper class for MasterRpcServices shortcut that ensures a client version is available to the callee without a current RPC call.org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper.ServiceCallFunction<Req,Resp> org.apache.hadoop.hbase.master.MasterServicesA curated subset of services provided byHMaster
.org.apache.hadoop.hbase.master.MasterStateStoreA state storage which stores the state in master local region.org.apache.hadoop.hbase.master.MasterWalManagerThis class abstracts a bunch of operations the HMaster needs when splitting log files e.g.org.apache.hadoop.hbase.master.MetricsAssignmentManagerorg.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceorg.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImplorg.apache.hadoop.hbase.master.MetricsMasterThis class is for maintaining the various master statistics and publishing them through the metrics interfaces.org.apache.hadoop.hbase.master.MetricsMasterFileSystemorg.apache.hadoop.hbase.master.MetricsMasterFileSystemSourceorg.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImplorg.apache.hadoop.hbase.master.MetricsMasterProcSourceInterface that classes that expose metrics about the master will implement.org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryInterface of a factory to create MetricsMasterSource when given a MetricsMasterWrapperorg.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImplFactory to create MetricsMasterProcSource when given a MetricsMasterWrapperorg.apache.hadoop.hbase.master.MetricsMasterProcSourceImplHadoop2 implementation of MetricsMasterSource.org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceA collection of exposed metrics for space quotas from the HBase Master.org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryInterface of a factory to create MetricsMasterQuotaSource when given a MetricsMasterWrapper.org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImplFactory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImplImplementation ofMetricsMasterQuotaSource
which writes the values passed in via the interface to the metrics backend.org.apache.hadoop.hbase.master.MetricsMasterSourceInterface that classes that expose metrics about the master will implement.org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryInterface of a factory to create MetricsMasterSource when given a MetricsMasterWrapperorg.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImplFactory to create MetricsMasterSource when given a MetricsMasterWrapperorg.apache.hadoop.hbase.master.MetricsMasterSourceImplHadoop2 implementation of MetricsMasterSource.org.apache.hadoop.hbase.master.MetricsMasterWrapperThis is the interface that will expose information to hadoop1/hadoop2 implementations of the MetricsMasterSource.org.apache.hadoop.hbase.master.MetricsMasterWrapperImplImpl for exposing HMaster Information through JMXorg.apache.hadoop.hbase.master.MetricsSnapshotorg.apache.hadoop.hbase.master.MetricsSnapshotSourceorg.apache.hadoop.hbase.master.MetricsSnapshotSourceImplorg.apache.hadoop.hbase.master.NoSuchProcedureExceptionorg.apache.hadoop.hbase.master.OldWALsDirSizeChoreThis chore is used to update the 'oldWALsDirSize' variable inMasterWalManager
through theMasterWalManager.updateOldWALsDirSize()
method.org.apache.hadoop.hbase.master.RackManagerWrapper over the rack resolution utility in Hadoop.org.apache.hadoop.hbase.master.RegionPlacementMaintainerA tool that is used for manipulating and viewing favored nodes information for regions.org.apache.hadoop.hbase.master.RegionPlacementMaintainer.RandomizedMatrixSome 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.org.apache.hadoop.hbase.master.RegionPlanStores the plan for the move of an individual region.org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparatororg.apache.hadoop.hbase.master.RegionServerListFor storing the region server list.org.apache.hadoop.hbase.master.RegionServerTrackerTracks the online region servers via ZK.org.apache.hadoop.hbase.master.RegionsRecoveryChoreThis chore, every time it runs, will try to recover regions with high store ref count by reopening themorg.apache.hadoop.hbase.master.RegionsRecoveryConfigManagerConfig manager for RegionsRecovery Chore - Dynamically reload config and update chore accordinglyorg.apache.hadoop.hbase.master.RegionStateState of a Region while undergoing transitions.org.apache.hadoop.hbase.master.RegionState.Stateorg.apache.hadoop.hbase.master.ServerListenerGet notification of server registration events.org.apache.hadoop.hbase.master.ServerManagerThe ServerManager class manages info about region servers.org.apache.hadoop.hbase.master.ServerManager.ServerLiveStateorg.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMetaUsed internally for reading meta and constructing datastructures that are then queried, for things like regions to regionservers, table to regions, etc.org.apache.hadoop.hbase.master.SnapshotSentinelWatch the current snapshot under processorg.apache.hadoop.hbase.master.SplitLogManagerDeprecated.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.org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirectiveorg.apache.hadoop.hbase.master.SplitLogManager.Taskin memory state of an active task.org.apache.hadoop.hbase.master.SplitLogManager.TaskBatchKeeps track of the batch of tasks submitted together by a caller in splitLogDistributed().org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatusorg.apache.hadoop.hbase.master.SplitOrMergeStateStoreTracks the switch of split and merge states.org.apache.hadoop.hbase.master.SplitWALManagerCreateSplitWALProcedure
for each WAL which need to split.org.apache.hadoop.hbase.master.TableNamespaceManagerThis is a helper class used internally to manage the namespace metadata that is stored in the ns family in meta table.org.apache.hadoop.hbase.master.TableStateManagerThis is a helper class used to manage table states.org.apache.hadoop.hbase.master.WorkerAssignerhelp assign and release a worker for each remote task.