Package org.apache.hadoop.hbase.master


package org.apache.hadoop.hbase.master
  • Class
    Description
    org.apache.hadoop.hbase.master.ActiveMasterManager
    Handles everything on master-side related to master election.
    org.apache.hadoop.hbase.master.AssignmentVerificationReport
    Helper class that is used by RegionPlacementMaintainer to print information for favored nodes
    org.apache.hadoop.hbase.master.BooleanStateStore
    Store a boolean state.
    org.apache.hadoop.hbase.master.CachedClusterId
    Caches the cluster ID of the cluster.
    org.apache.hadoop.hbase.master.ClusterSchema
    View and edit the current cluster schema.
    org.apache.hadoop.hbase.master.ClusterSchemaService
    Mixes in ClusterSchema and Service
    org.apache.hadoop.hbase.master.ClusterStatusPublisher
    Class to publish the cluster status to the client.
    org.apache.hadoop.hbase.master.ClusterStatusPublisher.MulticastPublisher
     
    org.apache.hadoop.hbase.master.ClusterStatusPublisher.Publisher
     
    org.apache.hadoop.hbase.master.DeadServer
    Class to hold dead servers list and utility querying dead server list.
    org.apache.hadoop.hbase.master.DrainingServerTracker
    Tracks the list of draining region servers via ZK.
    org.apache.hadoop.hbase.master.HMaster
    HMaster is the "master server" for HBase.
    org.apache.hadoop.hbase.master.HMaster.TableDescriptorGetter
    Implement to return TableDescriptor after pre-checks
    org.apache.hadoop.hbase.master.HMasterCommandLine
     
    org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
     
    org.apache.hadoop.hbase.master.LoadBalancer
    Makes decisions about the placement and movement of Regions across RegionServers.
    org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
    Priority function specifically for the master.
    org.apache.hadoop.hbase.master.MasterCoprocessorHost
    Provides the coprocessor framework and environment for master oriented operations.
    org.apache.hadoop.hbase.master.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.
    org.apache.hadoop.hbase.master.MasterRegionServerList
    MasterRegion based RegionServerList.
    org.apache.hadoop.hbase.master.MasterRpcServices
    Implements the master RPC services.
    org.apache.hadoop.hbase.master.MasterRpcServicesVersionWrapper
    A 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.MasterServices
    A curated subset of services provided by HMaster.
    org.apache.hadoop.hbase.master.MasterStateStore
    A state storage which stores the state in master local region.
    org.apache.hadoop.hbase.master.MasterWalManager
    This class abstracts a bunch of operations the HMaster needs when splitting log files e.g.
    org.apache.hadoop.hbase.master.MetricsAssignmentManager
     
    org.apache.hadoop.hbase.master.MetricsAssignmentManagerSource
     
    org.apache.hadoop.hbase.master.MetricsAssignmentManagerSourceImpl
     
    org.apache.hadoop.hbase.master.MetricsMaster
    This class is for maintaining the various master statistics and publishing them through the metrics interfaces.
    org.apache.hadoop.hbase.master.MetricsMasterFileSystem
     
    org.apache.hadoop.hbase.master.MetricsMasterFileSystemSource
     
    org.apache.hadoop.hbase.master.MetricsMasterFilesystemSourceImpl
     
    org.apache.hadoop.hbase.master.MetricsMasterProcSource
    Interface that classes that expose metrics about the master will implement.
    org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactory
    Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
    org.apache.hadoop.hbase.master.MetricsMasterProcSourceFactoryImpl
    Factory to create MetricsMasterProcSource when given a MetricsMasterWrapper
    org.apache.hadoop.hbase.master.MetricsMasterProcSourceImpl
    Hadoop2 implementation of MetricsMasterSource.
    org.apache.hadoop.hbase.master.MetricsMasterQuotaSource
    A collection of exposed metrics for space quotas from the HBase Master.
    org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactory
    Interface of a factory to create MetricsMasterQuotaSource when given a MetricsMasterWrapper.
    org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceFactoryImpl
    Factory to create MetricsMasterQuotaSource instances when given a MetricsMasterWrapper.
    org.apache.hadoop.hbase.master.MetricsMasterQuotaSourceImpl
    Implementation of MetricsMasterQuotaSource which writes the values passed in via the interface to the metrics backend.
    org.apache.hadoop.hbase.master.MetricsMasterSource
    Interface that classes that expose metrics about the master will implement.
    org.apache.hadoop.hbase.master.MetricsMasterSourceFactory
    Interface of a factory to create MetricsMasterSource when given a MetricsMasterWrapper
    org.apache.hadoop.hbase.master.MetricsMasterSourceFactoryImpl
    Factory to create MetricsMasterSource when given a MetricsMasterWrapper
    org.apache.hadoop.hbase.master.MetricsMasterSourceImpl
    Hadoop2 implementation of MetricsMasterSource.
    org.apache.hadoop.hbase.master.MetricsMasterWrapper
    This is the interface that will expose information to hadoop1/hadoop2 implementations of the MetricsMasterSource.
    org.apache.hadoop.hbase.master.MetricsMasterWrapperImpl
    Impl for exposing HMaster Information through JMX
    org.apache.hadoop.hbase.master.MetricsSnapshot
     
    org.apache.hadoop.hbase.master.MetricsSnapshotSource
     
    org.apache.hadoop.hbase.master.MetricsSnapshotSourceImpl
     
    org.apache.hadoop.hbase.master.NoSuchProcedureException
     
    org.apache.hadoop.hbase.master.OldWALsDirSizeChore
    This chore is used to update the 'oldWALsDirSize' variable in MasterWalManager through the MasterWalManager.updateOldWALsDirSize() method.
    org.apache.hadoop.hbase.master.RackManager
    Wrapper over the rack resolution utility in Hadoop.
    org.apache.hadoop.hbase.master.RegionPlacementMaintainer
    A tool that is used for manipulating and viewing favored nodes information for regions.
    org.apache.hadoop.hbase.master.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.
    org.apache.hadoop.hbase.master.RegionPlan
    Stores the plan for the move of an individual region.
    org.apache.hadoop.hbase.master.RegionPlan.RegionPlanComparator
     
    org.apache.hadoop.hbase.master.RegionServerList
    For storing the region server list.
    org.apache.hadoop.hbase.master.RegionServerTracker
    Tracks the online region servers via ZK.
    org.apache.hadoop.hbase.master.RegionsRecoveryChore
    This chore, every time it runs, will try to recover regions with high store ref count by reopening them
    org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
    Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
    org.apache.hadoop.hbase.master.RegionState
    State of a Region while undergoing transitions.
    org.apache.hadoop.hbase.master.RegionState.State
     
    org.apache.hadoop.hbase.master.ServerListener
    Get notification of server registration events.
    org.apache.hadoop.hbase.master.ServerManager
    The ServerManager class manages info about region servers.
    org.apache.hadoop.hbase.master.ServerManager.ServerLiveState
     
    org.apache.hadoop.hbase.master.SnapshotOfRegionAssignmentFromMeta
    Used 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.SnapshotSentinel
    Watch the current snapshot under process
    org.apache.hadoop.hbase.master.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.
    org.apache.hadoop.hbase.master.SplitLogManager.ResubmitDirective
     
    org.apache.hadoop.hbase.master.SplitLogManager.Task
    in memory state of an active task.
    org.apache.hadoop.hbase.master.SplitLogManager.TaskBatch
    Keeps track of the batch of tasks submitted together by a caller in splitLogDistributed().
    org.apache.hadoop.hbase.master.SplitLogManager.TerminationStatus
     
    org.apache.hadoop.hbase.master.SplitOrMergeStateStore
    Tracks the switch of split and merge states.
    org.apache.hadoop.hbase.master.SplitWALManager
    Create SplitWALProcedure for each WAL which need to split.
    org.apache.hadoop.hbase.master.TableNamespaceManager
    This 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.TableStateManager
    This is a helper class used to manage table states.
    org.apache.hadoop.hbase.master.WorkerAssigner
    help assign and release a worker for each remote task.