Uses of Interface
org.apache.hadoop.hbase.master.MasterServices
Package
Description
Table of Contents
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
-
Uses of MasterServices in org.apache.hadoop.hbase.backup.master
Modifier and TypeMethodDescriptionvoid
LogRollMasterProcedureManager.initialize
(MasterServices master, MetricsMaster metricsMaster) -
Uses of MasterServices in org.apache.hadoop.hbase.coordination
Modifier and TypeFieldDescriptionprivate final MasterServices
SplitLogManagerCoordination.SplitLogManagerDetails.master
Modifier and TypeMethodDescriptionSplitLogManagerCoordination.SplitLogManagerDetails.getMaster()
Returns the master valueModifierConstructorDescriptionSplitLogManagerDetails
(ConcurrentMap<String, SplitLogManager.Task> tasks, MasterServices master, Set<String> failedDeletions) -
Uses of MasterServices in org.apache.hadoop.hbase.coprocessor
Modifier and TypeMethodDescriptionHasMasterServices.getMasterServices()
Deprecated.Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption. -
Uses of MasterServices in org.apache.hadoop.hbase.master
Modifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Modifier and TypeFieldDescriptionprivate final MasterServices
OldWALsDirSizeChore.master
private final MasterServices
ServerManager.master
private final MasterServices
SplitWALManager.master
private final MasterServices
TableStateManager.master
private final MasterServices
WorkerAssigner.master
private final MasterServices
ClusterSchemaServiceImpl.masterServices
private final MasterServices
MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors.masterServices
private MasterServices
MasterCoprocessorHost.masterServices
private final MasterServices
TableNamespaceManager.masterServices
private final MasterServices
RegionServerTracker.server
private final MasterServices
SplitLogManager.server
Deprecated.private final MasterServices
MasterCoprocessorHost.MasterEnvironment.services
private final MasterServices
MasterWalManager.services
Modifier and TypeMethodDescriptionMasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors.getMasterServices()
Modifier and TypeMethodDescriptionprotected AssignmentManager
HMaster.createAssignmentManager
(MasterServices master, MasterRegion masterRegion) protected ServerManager
HMaster.createServerManager
(MasterServices master, RegionServerList storage) Create aServerManager
instance.ModifierConstructorDescription(package private)
ClusterSchemaServiceImpl
(MasterServices masterServices) 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, org.apache.hadoop.fs.Path rootDir, MasterServices services) MasterWalManager
(MasterServices services) OldWALsDirSizeChore
(MasterServices master) RegionServerTracker
(ZKWatcher watcher, MasterServices server) ServerManager
(MasterServices master, RegionServerList storage) 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) (package private)
TableNamespaceManager
(MasterServices masterServices) (package private)
TableStateManager
(MasterServices master) WorkerAssigner
(MasterServices master, int maxTasks, ProcedureEvent<?> event) -
Uses of MasterServices in org.apache.hadoop.hbase.master.assignment
Modifier and TypeFieldDescriptionprivate final MasterServices
AssignmentManager.master
private final MasterServices
RegionStateStore.master
ModifierConstructorDescriptionAssignmentManager
(MasterServices master, MasterRegion masterRegion) (package private)
AssignmentManager
(MasterServices master, MasterRegion masterRegion, RegionStateStore stateStore) RegionStateStore
(MasterServices master, MasterRegion masterRegion) -
Uses of MasterServices in org.apache.hadoop.hbase.master.balancer
-
Uses of MasterServices in org.apache.hadoop.hbase.master.hbck
-
Uses of MasterServices in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
-
Uses of MasterServices in org.apache.hadoop.hbase.master.http.hbck.resource
-
Uses of MasterServices in org.apache.hadoop.hbase.master.janitor
Modifier and TypeFieldDescriptionprivate final MasterServices
MetaFixer.masterServices
private final MasterServices
CatalogJanitor.services
private final MasterServices
ReportMakingVisitor.services
Modifier and TypeMethodDescriptionCatalogJanitor.checkRegionReferences
(MasterServices services, TableName tableName, RegionInfo region) Checks if a region still holds references to parent.(package private) static boolean
CatalogJanitor.cleanMergeRegion
(MasterServices services, RegionInfo mergedRegion, List<RegionInfo> parents) If merged region no longer holds reference to the merge regions, archive merge region on hdfs and perform deleting references in hbase:meta(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 thehbase:meta
for each providedRegionInfo
.ModifierConstructorDescriptionCatalogJanitor
(MasterServices services) MetaFixer
(MasterServices masterServices) (package private)
ReportMakingVisitor
(MasterServices services) -
Uses of MasterServices in org.apache.hadoop.hbase.master.migrate
-
Uses of MasterServices in org.apache.hadoop.hbase.master.normalizer
Modifier and TypeFieldDescriptionprivate final MasterServices
RegionNormalizerChore.master
private final MasterServices
RegionNormalizerWorker.masterServices
private MasterServices
SimpleRegionNormalizer.masterServices
Modifier and TypeMethodDescriptionvoid
RegionNormalizer.setMasterServices
(MasterServices masterServices) Set the master service.void
SimpleRegionNormalizer.setMasterServices
(MasterServices masterServices) ModifierConstructorDescriptionRegionNormalizerChore
(MasterServices master) (package private)
RegionNormalizerWorker
(org.apache.hadoop.conf.Configuration configuration, MasterServices masterServices, RegionNormalizer regionNormalizer, RegionNormalizerWorkQueue<TableName> workQueue) -
Uses of MasterServices in org.apache.hadoop.hbase.master.procedure
Modifier and TypeFieldDescriptionprivate final MasterServices
MasterProcedureEnv.FsUtilsLeaseRecovery.master
private final MasterServices
MasterProcedureEnv.master
private final MasterServices
MasterProcedureUtil.NonceProcedureRunnable.master
private MasterServices
RecoverMetaProcedure.master
Deprecated.protected final MasterServices
RSProcedureDispatcher.master
Modifier and TypeMethodDescriptionprotected MasterServices
MasterProcedureUtil.NonceProcedureRunnable.getMaster()
MasterProcedureEnv.getMasterServices()
ModifierConstructorDescriptionFsUtilsLeaseRecovery
(MasterServices master) MasterProcedureEnv
(MasterServices master) MasterProcedureEnv
(MasterServices master, RSProcedureDispatcher remoteDispatcher) NonceProcedureRunnable
(MasterServices master, long nonceGroup, long nonce) RSProcedureDispatcher
(MasterServices master) -
Uses of MasterServices in org.apache.hadoop.hbase.master.replication
Modifier and TypeMethodDescriptionstatic ReplicationPeerManager
ReplicationPeerManager.create
(MasterServices services, String clusterId) private static Pair<ReplicationQueueStorage,
ReplicationPeerManager.ReplicationQueueStorageInitializer> ReplicationPeerManager.createReplicationQueueStorage
(MasterServices services) -
Uses of MasterServices in org.apache.hadoop.hbase.master.slowlog
Modifier and TypeFieldDescriptionprivate final MasterServices
SlowLogMasterService.masterServices
ModifierConstructorDescriptionSlowLogMasterService
(org.apache.hadoop.conf.Configuration configuration, MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.master.snapshot
Modifier and TypeFieldDescriptionprivate MasterServices
SnapshotHFileCleaner.master
private MasterServices
SnapshotManager.master
protected final MasterServices
TakeSnapshotHandler.master
private MasterServices
MasterSnapshotVerifier.services
Modifier and TypeMethodDescriptionvoid
SnapshotManager.initialize
(MasterServices master, MetricsMaster metricsMaster) ModifierConstructorDescriptionDisabledTableSnapshotHandler
(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) (package private)
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) -
Uses of MasterServices in org.apache.hadoop.hbase.master.waleventtracker
Modifier and TypeMethodDescriptionstatic void
WALEventTrackerTableCreator.createIfNeededAndNotExists
(org.apache.hadoop.conf.Configuration conf, MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.namespace
Modifier and TypeFieldDescriptionprivate MasterServices
NamespaceStateManager.master
private MasterServices
NamespaceAuditor.masterServices
ModifierConstructorDescriptionNamespaceAuditor
(MasterServices masterServices) NamespaceStateManager
(MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.procedure
Modifier and TypeMethodDescriptionabstract void
MasterProcedureManager.initialize
(MasterServices master, MetricsMaster metricsMaster) Initialize a globally barriered procedure for master.void
MasterProcedureManagerHost.initialize
(MasterServices master, MetricsMaster metricsMaster) -
Uses of MasterServices in org.apache.hadoop.hbase.procedure.flush
Modifier and TypeMethodDescriptionvoid
MasterFlushTableProcedureManager.initialize
(MasterServices master, MetricsMaster metricsMaster) -
Uses of MasterServices in org.apache.hadoop.hbase.quotas
Modifier and TypeFieldDescriptionprivate final MasterServices
MasterQuotaManager.masterServices
private MasterServices
MasterQuotasObserver.masterServices
-
Uses of MasterServices in org.apache.hadoop.hbase.replication.master
Modifier and TypeMethodDescriptionstatic void
ReplicationSinkTrackerTableCreator.createIfNeededAndNotExists
(org.apache.hadoop.conf.Configuration conf, MasterServices masterServices) private Set<ServerName>
ReplicationLogCleaner.getNotFullyDeadServers
(MasterServices services) -
Uses of MasterServices in org.apache.hadoop.hbase.rsgroup
Modifier and TypeFieldDescriptionprivate MasterServices
RSGroupAdminEndpoint.master
Deprecated.private MasterServices
RSGroupAdminServiceImpl.master
Deprecated.private MasterServices
RSGroupBasedLoadBalancer.masterServices
private final MasterServices
RSGroupInfoManagerImpl.masterServices
Modifier and TypeMethodDescriptionstatic RSGroupInfoManager
RSGroupInfoManager.create
(MasterServices master) (package private) static RSGroupInfoManager
RSGroupInfoManagerImpl.getInstance
(MasterServices masterServices) static Optional<RSGroupInfo>
RSGroupUtil.getRSGroupInfo
(MasterServices master, RSGroupInfoManager manager, TableName tableName) Will try to get the rsgroup fromTableDescriptor
first, and then try to get the rsgroup from theNamespaceDescriptor
.(package private) void
RSGroupAdminServiceImpl.initialize
(MasterServices masterServices) Deprecated.private static boolean
RSGroupInfoManagerImpl.isMasterRunning
(MasterServices masterServices) RSGroupUtil.listTablesInRSGroup
(MasterServices master, String groupName) void
RSGroupBasedLoadBalancer.setMasterServices
(MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.security.access
Modifier and TypeFieldDescriptionprivate MasterServices
SnapshotScannerHDFSAclController.masterServices