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 |
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 |
HbckChore.master |
private MasterServices |
TableNamespaceManager.masterServices |
private MasterServices |
MasterCoprocessorHost.masterServices |
private MasterServices |
MasterCoprocessorHost.MasterEnvironmentForCoreCoprocessors.masterServices |
private MasterServices |
MetaFixer.masterServices |
private MasterServices |
ClusterSchemaServiceImpl.masterServices |
private MasterServices |
SplitLogManager.server |
private MasterServices |
RegionServerTracker.server |
private MasterServices |
MasterCoprocessorHost.MasterEnvironment.services |
private MasterServices |
MasterWalManager.services |
private MasterServices |
CatalogJanitor.services |
private MasterServices |
CatalogJanitor.ReportMakingVisitor.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
ServerManager instance. |
void |
LoadBalancer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Constructor and Description |
---|
CatalogJanitor(MasterServices services) |
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) |
MetaFixer(MasterServices masterServices) |
MirroringTableStateManager(MasterServices master)
Deprecated.
|
RegionServerTracker(ZKWatcher watcher,
MasterServices server,
ServerManager serverManager) |
ReportMakingVisitor(MasterServices services) |
ServerManager(MasterServices master)
Constructor.
|
SplitLogManager(MasterServices master,
org.apache.hadoop.conf.Configuration conf)
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 |
StochasticLoadBalancer.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) |
(package private) void |
StochasticLoadBalancer.LocalityBasedCandidateGenerator.setServices(MasterServices services) |
void |
StochasticLoadBalancer.LocalityBasedCostFunction.setServices(MasterServices srvc) |
void |
RegionLocationFinder.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 |
SimpleRegionNormalizer.masterServices |
Modifier and Type | Method and Description |
---|---|
void |
RegionNormalizer.setMasterServices(MasterServices masterServices)
Set the master service.
|
void |
SimpleRegionNormalizer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Modifier and Type | Field and Description |
---|---|
private MasterServices |
MasterProcedureUtil.NonceProcedureRunnable.master |
private MasterServices |
MasterProcedureEnv.master |
private MasterServices |
MasterProcedureEnv.WALStoreLeaseRecovery.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 |
---|
MasterProcedureEnv(MasterServices master) |
MasterProcedureEnv(MasterServices master,
RSProcedureDispatcher remoteDispatcher) |
NonceProcedureRunnable(MasterServices master,
long nonceGroup,
long nonce) |
RSProcedureDispatcher(MasterServices master) |
WALStoreLeaseRecovery(MasterServices master) |
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) |
void |
RSGroupBasedLoadBalancer.setMasterServices(MasterServices masterServices) |
Constructor and Description |
---|
RSGroupAdminServer(MasterServices master,
RSGroupInfoManager rsGroupInfoManager) |
RSGroupInfoManagerImpl(MasterServices masterServices) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.