| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.coordination | |
| org.apache.hadoop.hbase.coprocessor | Table of Contents | 
| org.apache.hadoop.hbase.favored | |
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.assignment | |
| org.apache.hadoop.hbase.master.balancer | |
| org.apache.hadoop.hbase.master.janitor | |
| org.apache.hadoop.hbase.master.normalizer | The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
 a "normal" size, according to their storefile size. | 
| org.apache.hadoop.hbase.master.procedure | |
| org.apache.hadoop.hbase.master.slowlog | |
| org.apache.hadoop.hbase.master.snapshot | |
| org.apache.hadoop.hbase.namespace | |
| org.apache.hadoop.hbase.procedure | |
| org.apache.hadoop.hbase.procedure.flush | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.rsgroup | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.util | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | SplitLogManagerCoordination.SplitLogManagerDetails. master | 
| Modifier and Type | Method and Description | 
|---|---|
| MasterServices | SplitLogManagerCoordination.SplitLogManagerDetails. getMaster() | 
| Constructor and Description | 
|---|
| SplitLogManagerDetails(ConcurrentMap<String,SplitLogManager.Task> tasks,
                      MasterServices master,
                      Set<String> failedDeletions) | 
| Modifier and Type | Method and Description | 
|---|---|
| MasterServices | HasMasterServices. getMasterServices()Deprecated.  | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | FavoredNodesManager. masterServices | 
| Constructor and Description | 
|---|
| FavoredNodesManager(MasterServices masterServices) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HMasterHMaster is the "master server" for HBase. | 
| static class  | HMasterCommandLine.LocalHMaster | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | SplitWALManager. master | 
| private MasterServices | SplitWALManager.SplitWorkerAssigner. master | 
| protected MasterServices | TableStateManager. master | 
| private MasterServices | ServerManager. master | 
| private MasterServices | HbckChore. master | 
| private MasterServices | TableNamespaceManager. masterServices | 
| private MasterServices | MasterCoprocessorHost. masterServices | 
| private MasterServices | MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors. masterServices | 
| private MasterServices | ClusterSchemaServiceImpl. masterServices | 
| private MasterServices | SplitLogManager. serverDeprecated.  | 
| private MasterServices | RegionServerTracker. server | 
| private MasterServices | MasterCoprocessorHost.MasterEnvironment. services | 
| private MasterServices | MasterWalManager. services | 
| Modifier and Type | Method and Description | 
|---|---|
| MasterServices | MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors. getMasterServices() | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | TableNamespaceManager. block(MasterServices services,
     long procId)An ugly utility to be removed when refactor TableNamespaceManager. | 
| protected AssignmentManager | HMaster. createAssignmentManager(MasterServices master) | 
| private void | TableNamespaceManager. createNamespaceTable(MasterServices masterServices) | 
| protected ServerManager | HMaster. createServerManager(MasterServices master)
 Create a  ServerManagerinstance. | 
| void | LoadBalancer. setMasterServices(MasterServices masterServices)Set the master service. | 
| Constructor and Description | 
|---|
| ClusterSchemaServiceImpl(MasterServices masterServices) | 
| HbckChore(MasterServices master) | 
| MasterCoprocessorHost(MasterServices services,
                     org.apache.hadoop.conf.Configuration conf) | 
| MasterEnvironment(MasterCoprocessor impl,
                 int priority,
                 int seq,
                 org.apache.hadoop.conf.Configuration conf,
                 MasterServices services) | 
| MasterEnvironmentForCoreCoprocessors(MasterCoprocessor impl,
                                    int priority,
                                    int seq,
                                    org.apache.hadoop.conf.Configuration conf,
                                    MasterServices services) | 
| MasterWalManager(org.apache.hadoop.conf.Configuration conf,
                org.apache.hadoop.fs.FileSystem fs,
                MasterServices services) | 
| MasterWalManager(MasterServices services) | 
| MirroringTableStateManager(MasterServices master)Deprecated.  | 
| RegionServerTracker(ZKWatcher watcher,
                   MasterServices server,
                   ServerManager serverManager) | 
| ServerManager(MasterServices master)Constructor. | 
| SplitLogManager(MasterServices master,
               org.apache.hadoop.conf.Configuration conf)Deprecated.  Its OK to construct this object even when region-servers are not online. | 
| SplitWALManager(MasterServices master) | 
| SplitWorkerAssigner(MasterServices master,
                   int maxSplitTasks) | 
| TableNamespaceManager(MasterServices masterServices) | 
| TableStateManager(MasterServices master) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | RegionStateStore. master | 
| private MasterServices | AssignmentManager. master | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) MasterServices | AssignmentManager. getMaster() | 
| Constructor and Description | 
|---|
| AssignmentManager(MasterServices master) | 
| AssignmentManager(MasterServices master,
                 RegionStateStore stateStore) | 
| RegionStateStore(MasterServices master) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | LocalityBasedCandidateGenerator. masterServices | 
| private MasterServices | StochasticLoadBalancer.LocalityBasedCostFunction. services | 
| protected MasterServices | BaseLoadBalancer. services | 
| private MasterServices | RegionLocationFinder. services | 
| Modifier and Type | Method and Description | 
|---|---|
| void | StochasticLoadBalancer. setMasterServices(MasterServices masterServices) | 
| void | BaseLoadBalancer. setMasterServices(MasterServices masterServices) | 
| void | FavoredStochasticBalancer. setMasterServices(MasterServices masterServices) | 
| void | StochasticLoadBalancer.LocalityBasedCostFunction. setServices(MasterServices srvc) | 
| void | RegionLocationFinder. setServices(MasterServices services) | 
| (package private) void | LocalityBasedCandidateGenerator. setServices(MasterServices services) | 
| Constructor and Description | 
|---|
| LocalityBasedCandidateGenerator(MasterServices masterServices) | 
| LocalityBasedCostFunction(org.apache.hadoop.conf.Configuration conf,
                         MasterServices srv,
                         BaseLoadBalancer.Cluster.LocalityType type,
                         String localityCostKey,
                         float defaultLocalityCost) | 
| RackLocalityCostFunction(org.apache.hadoop.conf.Configuration conf,
                        MasterServices services) | 
| ServerLocalityCostFunction(org.apache.hadoop.conf.Configuration conf,
                          MasterServices srv) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | MetaFixer. masterServices | 
| private MasterServices | ReportMakingVisitor. services | 
| private MasterServices | CatalogJanitor. services | 
| Modifier and Type | Method and Description | 
|---|---|
| private static Pair<Boolean,Boolean> | CatalogJanitor. checkDaughterInFs(MasterServices services,
                 RegionInfo parent,
                 RegionInfo daughter)Checks if a daughter region -- either splitA or splitB -- still holds references to parent. | 
| (package private) static boolean | CatalogJanitor. cleanParent(MasterServices services,
           RegionInfo parent,
           Result rowContent) | 
| private static List<RegionInfo> | MetaFixer. createMetaEntries(MasterServices masterServices,
                 List<RegionInfo> newRegionInfos)Create entries in the  hbase:metafor each providedRegionInfo. | 
| Constructor and Description | 
|---|
| CatalogJanitor(MasterServices services) | 
| MetaFixer(MasterServices masterServices) | 
| ReportMakingVisitor(MasterServices services) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | RegionNormalizerChore. master | 
| private MasterServices | SimpleRegionNormalizer. masterServices | 
| private MasterServices | RegionNormalizerWorker. masterServices | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RegionNormalizer. setMasterServices(MasterServices masterServices)Set the master service. | 
| void | SimpleRegionNormalizer. setMasterServices(MasterServices masterServices) | 
| Constructor and Description | 
|---|
| RegionNormalizerChore(MasterServices master) | 
| RegionNormalizerWorker(org.apache.hadoop.conf.Configuration configuration,
                      MasterServices masterServices,
                      RegionNormalizer regionNormalizer,
                      RegionNormalizerWorkQueue<TableName> workQueue) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | MasterProcedureUtil.NonceProcedureRunnable. master | 
| private MasterServices | MasterProcedureEnv. master | 
| private MasterServices | MasterProcedureEnv.FsUtilsLeaseRecovery. master | 
| protected MasterServices | RSProcedureDispatcher. master | 
| private MasterServices | RecoverMetaProcedure. masterDeprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| protected MasterServices | MasterProcedureUtil.NonceProcedureRunnable. getMaster() | 
| MasterServices | MasterProcedureEnv. getMasterServices() | 
| Constructor and Description | 
|---|
| FsUtilsLeaseRecovery(MasterServices master) | 
| MasterProcedureEnv(MasterServices master) | 
| MasterProcedureEnv(MasterServices master,
                  RSProcedureDispatcher remoteDispatcher) | 
| NonceProcedureRunnable(MasterServices master,
                      long nonceGroup,
                      long nonce) | 
| RSProcedureDispatcher(MasterServices master) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | SlowLogMasterService. masterServices | 
| Constructor and Description | 
|---|
| SlowLogMasterService(org.apache.hadoop.conf.Configuration configuration,
                    MasterServices masterServices) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | SnapshotHFileCleaner. master | 
| protected MasterServices | TakeSnapshotHandler. master | 
| private MasterServices | SnapshotManager. master | 
| private MasterServices | MasterSnapshotVerifier. services | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SnapshotManager. initialize(MasterServices master,
          MetricsMaster metricsMaster) | 
| Constructor and Description | 
|---|
| DisabledTableSnapshotHandler(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                            MasterServices masterServices,
                            SnapshotManager snapshotManager) | 
| EnabledTableSnapshotHandler(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                           MasterServices master,
                           SnapshotManager manager) | 
| MasterSnapshotVerifier(MasterServices services,
                      org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                      org.apache.hadoop.fs.FileSystem workingDirFs) | 
| SnapshotManager(MasterServices master,
               ProcedureCoordinator coordinator,
               ExecutorService pool,
               int sentinelCleanInterval)Fully specify all necessary components of a snapshot manager. | 
| TakeSnapshotHandler(org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription snapshot,
                   MasterServices masterServices,
                   SnapshotManager snapshotManager) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | NamespaceStateManager. master | 
| private MasterServices | NamespaceAuditor. masterServices | 
| Constructor and Description | 
|---|
| NamespaceAuditor(MasterServices masterServices) | 
| NamespaceStateManager(MasterServices masterServices) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MasterProcedureManagerHost. initialize(MasterServices master,
          MetricsMaster metricsMaster) | 
| abstract void | MasterProcedureManager. initialize(MasterServices master,
          MetricsMaster metricsMaster)Initialize a globally barriered procedure for master. | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | MasterFlushTableProcedureManager. master | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MasterFlushTableProcedureManager. initialize(MasterServices master,
          MetricsMaster metricsMaster) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | MasterQuotaManager. masterServices | 
| private MasterServices | MasterQuotasObserver. masterServices | 
| Constructor and Description | 
|---|
| MasterQuotaManager(MasterServices masterServices) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | RSGroupAdminServer. master | 
| private MasterServices | RSGroupAdminEndpoint. master | 
| private MasterServices | RSGroupBasedLoadBalancer. masterServices | 
| private MasterServices | RSGroupInfoManagerImpl. masterServices | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) static RSGroupInfoManager | RSGroupInfoManagerImpl. getInstance(MasterServices master) | 
| private static Set<Address> | RSGroupInfoManagerImpl. getOnlineServers(MasterServices master) | 
| private static boolean | RSGroupInfoManagerImpl. isMasterRunning(MasterServices masterServices) | 
| static boolean | RSGroupUtil. rsGroupHasOnlineServer(MasterServices master,
                      RSGroupInfo rsGroupInfo) | 
| void | RSGroupBasedLoadBalancer. setMasterServices(MasterServices masterServices) | 
| Constructor and Description | 
|---|
| RSGroupAdminServer(MasterServices master,
                  RSGroupInfoManager rsGroupInfoManager) | 
| RSGroupInfoManagerImpl(MasterServices masterServices) | 
| Modifier and Type | Field and Description | 
|---|---|
| private MasterServices | SnapshotScannerHDFSAclController. masterServices | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | ServerRegionReplicaUtil. setupRegionReplicaReplication(MasterServices services)Create replication peer for replicating user-space Region Read Replicas. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.