Uses of Interface
org.apache.hadoop.hbase.master.MasterServices
Packages that use 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
Fields in org.apache.hadoop.hbase.backup.master declared as MasterServicesMethods in org.apache.hadoop.hbase.backup.master with parameters of type MasterServicesModifier and TypeMethodDescriptionvoid
LogRollMasterProcedureManager.initialize
(MasterServices master, MetricsMaster metricsMaster) -
Uses of MasterServices in org.apache.hadoop.hbase.coordination
Fields in org.apache.hadoop.hbase.coordination declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
SplitLogManagerCoordination.SplitLogManagerDetails.master
Methods in org.apache.hadoop.hbase.coordination that return MasterServicesModifier and TypeMethodDescriptionSplitLogManagerCoordination.SplitLogManagerDetails.getMaster()
Returns the master valueConstructors in org.apache.hadoop.hbase.coordination with parameters of type MasterServicesModifierConstructorDescriptionSplitLogManagerDetails
(ConcurrentMap<String, SplitLogManager.Task> tasks, MasterServices master, Set<String> failedDeletions) -
Uses of MasterServices in org.apache.hadoop.hbase.coprocessor
Methods in org.apache.hadoop.hbase.coprocessor that return MasterServicesModifier and TypeMethodDescriptionHasMasterServices.getMasterServices()
Deprecated.Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption. -
Uses of MasterServices in org.apache.hadoop.hbase.master
Classes in org.apache.hadoop.hbase.master that implement MasterServicesModifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Fields in org.apache.hadoop.hbase.master declared as MasterServicesModifier 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
Methods in org.apache.hadoop.hbase.master that return MasterServicesModifier and TypeMethodDescriptionMasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors.getMasterServices()
Methods in org.apache.hadoop.hbase.master with parameters of type MasterServicesModifier and TypeMethodDescriptionprotected AssignmentManager
HMaster.createAssignmentManager
(MasterServices master, MasterRegion masterRegion) protected ServerManager
HMaster.createServerManager
(MasterServices master, RegionServerList storage) Create aServerManager
instance.Constructors in org.apache.hadoop.hbase.master with parameters of type MasterServicesModifierConstructorDescription(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
Fields in org.apache.hadoop.hbase.master.assignment declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
AssignmentManager.master
private final MasterServices
RegionStateStore.master
Methods in org.apache.hadoop.hbase.master.assignment that return MasterServicesConstructors in org.apache.hadoop.hbase.master.assignment with parameters of type MasterServicesModifierConstructorDescriptionAssignmentManager
(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
Fields in org.apache.hadoop.hbase.master.balancer declared as MasterServicesConstructors in org.apache.hadoop.hbase.master.balancer with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.hbck
Fields in org.apache.hadoop.hbase.master.hbck declared as MasterServicesConstructors in org.apache.hadoop.hbase.master.hbck with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource
Constructors in org.apache.hadoop.hbase.master.http.api_v1.cluster_metrics.resource with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.http.hbck.resource
Constructors in org.apache.hadoop.hbase.master.http.hbck.resource with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.janitor
Fields in org.apache.hadoop.hbase.master.janitor declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
MetaFixer.masterServices
private final MasterServices
CatalogJanitor.services
private final MasterServices
ReportMakingVisitor.services
Methods in org.apache.hadoop.hbase.master.janitor with parameters of type MasterServicesModifier 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
.Constructors in org.apache.hadoop.hbase.master.janitor with parameters of type MasterServicesModifierConstructorDescriptionCatalogJanitor
(MasterServices services) MetaFixer
(MasterServices masterServices) (package private)
ReportMakingVisitor
(MasterServices services) -
Uses of MasterServices in org.apache.hadoop.hbase.master.migrate
Constructors in org.apache.hadoop.hbase.master.migrate with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.normalizer
Fields in org.apache.hadoop.hbase.master.normalizer declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
RegionNormalizerChore.master
private final MasterServices
RegionNormalizerWorker.masterServices
private MasterServices
SimpleRegionNormalizer.masterServices
Methods in org.apache.hadoop.hbase.master.normalizer with parameters of type MasterServicesModifier and TypeMethodDescriptionvoid
RegionNormalizer.setMasterServices
(MasterServices masterServices) Set the master service.void
SimpleRegionNormalizer.setMasterServices
(MasterServices masterServices) Constructors in org.apache.hadoop.hbase.master.normalizer with parameters of type MasterServicesModifierConstructorDescriptionRegionNormalizerChore
(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
Fields in org.apache.hadoop.hbase.master.procedure declared as MasterServicesModifier 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
Methods in org.apache.hadoop.hbase.master.procedure that return MasterServicesModifier and TypeMethodDescriptionprotected MasterServices
MasterProcedureUtil.NonceProcedureRunnable.getMaster()
MasterProcedureEnv.getMasterServices()
Constructors in org.apache.hadoop.hbase.master.procedure with parameters of type MasterServicesModifierConstructorDescriptionFsUtilsLeaseRecovery
(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
Methods in org.apache.hadoop.hbase.master.replication with parameters of type MasterServicesModifier and TypeMethodDescriptionstatic ReplicationPeerManager
ReplicationPeerManager.create
(MasterServices services, String clusterId) private static Pair<ReplicationQueueStorage,
ReplicationPeerManager.ReplicationQueueStorageInitializer> ReplicationPeerManager.createReplicationQueueStorage
(MasterServices services) Constructors in org.apache.hadoop.hbase.master.replication with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.master.slowlog
Fields in org.apache.hadoop.hbase.master.slowlog declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
SlowLogMasterService.masterServices
Constructors in org.apache.hadoop.hbase.master.slowlog with parameters of type MasterServicesModifierConstructorDescriptionSlowLogMasterService
(org.apache.hadoop.conf.Configuration configuration, MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.master.snapshot
Fields in org.apache.hadoop.hbase.master.snapshot declared as MasterServicesModifier and TypeFieldDescriptionprivate MasterServices
SnapshotHFileCleaner.master
private MasterServices
SnapshotManager.master
protected final MasterServices
TakeSnapshotHandler.master
private MasterServices
MasterSnapshotVerifier.services
Methods in org.apache.hadoop.hbase.master.snapshot with parameters of type MasterServicesModifier and TypeMethodDescriptionvoid
SnapshotManager.initialize
(MasterServices master, MetricsMaster metricsMaster) Constructors in org.apache.hadoop.hbase.master.snapshot with parameters of type MasterServicesModifierConstructorDescriptionDisabledTableSnapshotHandler
(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
Methods in org.apache.hadoop.hbase.master.waleventtracker with parameters of type MasterServicesModifier and TypeMethodDescriptionstatic void
WALEventTrackerTableCreator.createIfNeededAndNotExists
(org.apache.hadoop.conf.Configuration conf, MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.namespace
Fields in org.apache.hadoop.hbase.namespace declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
NamespaceStateManager.master
private MasterServices
NamespaceAuditor.masterServices
Constructors in org.apache.hadoop.hbase.namespace with parameters of type MasterServicesModifierConstructorDescriptionNamespaceAuditor
(MasterServices masterServices) NamespaceStateManager
(MasterServices masterServices) -
Uses of MasterServices in org.apache.hadoop.hbase.procedure
Methods in org.apache.hadoop.hbase.procedure with parameters of type MasterServicesModifier 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
Fields in org.apache.hadoop.hbase.procedure.flush declared as MasterServicesMethods in org.apache.hadoop.hbase.procedure.flush with parameters of type MasterServicesModifier and TypeMethodDescriptionvoid
MasterFlushTableProcedureManager.initialize
(MasterServices master, MetricsMaster metricsMaster) -
Uses of MasterServices in org.apache.hadoop.hbase.quotas
Fields in org.apache.hadoop.hbase.quotas declared as MasterServicesModifier and TypeFieldDescriptionprivate final MasterServices
MasterQuotaManager.masterServices
private MasterServices
MasterQuotasObserver.masterServices
Constructors in org.apache.hadoop.hbase.quotas with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.replication.master
Methods in org.apache.hadoop.hbase.replication.master with parameters of type MasterServicesModifier 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
Fields in org.apache.hadoop.hbase.rsgroup declared as MasterServicesModifier and TypeFieldDescriptionprivate MasterServices
RSGroupAdminEndpoint.master
Deprecated.private MasterServices
RSGroupAdminServiceImpl.master
Deprecated.private MasterServices
RSGroupBasedLoadBalancer.masterServices
private final MasterServices
RSGroupInfoManagerImpl.masterServices
Methods in org.apache.hadoop.hbase.rsgroup with parameters of type MasterServicesModifier 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) Constructors in org.apache.hadoop.hbase.rsgroup with parameters of type MasterServices -
Uses of MasterServices in org.apache.hadoop.hbase.security.access
Fields in org.apache.hadoop.hbase.security.access declared as MasterServicesModifier and TypeFieldDescriptionprivate MasterServices
SnapshotScannerHDFSAclController.masterServices