Modifier and Type | Field and Description |
---|---|
private MasterServices |
SplitLogManagerCoordination.SplitLogManagerDetails.master |
Modifier and Type | Method and Description |
---|---|
MasterServices |
SplitLogManagerCoordination.SplitLogManagerDetails.getMaster()
Returns the master value
|
Constructor and Description |
---|
SplitLogManagerDetails(ConcurrentMap<String,SplitLogManager.Task> tasks,
MasterServices master,
Set<String> failedDeletions) |
Modifier and Type | Method and Description |
---|---|
MasterServices |
HasMasterServices.getMasterServices()
Deprecated.
Returns An instance of RegionServerServices, an object NOT for Coprocessor consumption.
|
Modifier and Type | Field and Description |
---|---|
private MasterServices |
FavoredNodesManager.masterServices |
Constructor and Description |
---|
FavoredNodesManager(MasterServices masterServices) |
Modifier and Type | Class and Description |
---|---|
class |
HMaster
HMaster 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 |
TableNamespaceManager.masterServices |
private MasterServices |
MasterCoprocessorHost.masterServices |
private MasterServices |
MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors.masterServices |
private MasterServices |
ClusterSchemaServiceImpl.masterServices |
private MasterServices |
SplitLogManager.server
Deprecated.
|
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,
MasterRegion masterRegion) |
private void |
TableNamespaceManager.createNamespaceTable(MasterServices masterServices) |
protected ServerManager |
HMaster.createServerManager(MasterServices master,
RegionServerList storage)
Create a
ServerManager instance. |
void |
LoadBalancer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Constructor and Description |
---|
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,
MasterServices services) |
MasterWalManager(MasterServices services) |
MirroringTableStateManager(MasterServices master)
Deprecated.
|
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) |
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,
MasterRegion masterRegion) |
AssignmentManager(MasterServices master,
MasterRegion masterRegion,
RegionStateStore stateStore) |
RegionStateStore(MasterServices master,
MasterRegion masterRegion) |
Modifier and Type | Field and Description |
---|---|
protected MasterServices |
BaseLoadBalancer.services |
private MasterServices |
RegionLocationFinder.services |
Modifier and Type | Method and Description |
---|---|
void |
BaseLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
FavoredStochasticBalancer.setMasterServices(MasterServices masterServices) |
void |
MaintenanceLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
RegionLocationFinder.setServices(MasterServices services) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
HbckChore.master |
Constructor and Description |
---|
HbckChore(MasterServices master) |
Constructor and Description |
---|
ClusterMetricsResource(MasterServices master) |
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:meta for each provided RegionInfo . |
Constructor and Description |
---|
CatalogJanitor(MasterServices services) |
MetaFixer(MasterServices masterServices) |
ReportMakingVisitor(MasterServices services) |
Constructor and Description |
---|
RollingUpgradeChore(MasterServices masterServices) |
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.master
Deprecated.
|
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–2020 The Apache Software Foundation. All rights reserved.