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.
|
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 |
---|---|
protected MasterServices |
TableStateManager.master |
Modifier and Type | Method and Description |
---|---|
protected ServerManager |
HMaster.createServerManager(MasterServices master)
Create a
ServerManager instance. |
void |
LoadBalancer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Constructor and Description |
---|
MasterCoprocessorHost(MasterServices services,
org.apache.hadoop.conf.Configuration conf) |
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)
Its OK to construct this object even when region-servers are not online.
|
TableStateManager(MasterServices master) |
Modifier and Type | Method and Description |
---|---|
static boolean |
AssignProcedure.assign(MasterServices masterServices,
RegionInfo ri)
Used by ServerCrashProcedure too skip creating Assigns if not needed.
|
protected static boolean |
AssignProcedure.assign(MasterServices masterServices,
RegionStates.RegionStateNode regionNode) |
Constructor and Description |
---|
AssignmentManager(MasterServices master) |
AssignmentManager(MasterServices master,
RegionStateStore stateStore) |
RegionStateStore(MasterServices master) |
Modifier and Type | Field and Description |
---|---|
protected MasterServices |
BaseLoadBalancer.services |
Modifier and Type | Method and Description |
---|---|
void |
StochasticLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
BaseLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
FavoredStochasticBalancer.setMasterServices(MasterServices masterServices) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleRegionNormalizer.setMasterServices(MasterServices masterServices)
Set the master service.
|
void |
RegionNormalizer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Modifier and Type | Field and Description |
---|---|
protected MasterServices |
RSProcedureDispatcher.master |
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 |
---|---|
protected MasterServices |
TakeSnapshotHandler.master |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManager.initialize(MasterServices master,
MetricsMaster metricsMaster) |
Constructor and Description |
---|
DisabledTableSnapshotHandler(SnapshotProtos.SnapshotDescription snapshot,
MasterServices masterServices,
SnapshotManager snapshotManager) |
EnabledTableSnapshotHandler(SnapshotProtos.SnapshotDescription snapshot,
MasterServices master,
SnapshotManager manager) |
MasterSnapshotVerifier(MasterServices services,
SnapshotProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootDir) |
TakeSnapshotHandler(SnapshotProtos.SnapshotDescription snapshot,
MasterServices masterServices,
SnapshotManager snapshotManager) |
Constructor and Description |
---|
NamespaceAuditor(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 | Method and Description |
---|---|
void |
MasterFlushTableProcedureManager.initialize(MasterServices master,
MetricsMaster metricsMaster) |
Constructor and Description |
---|
MasterQuotaManager(MasterServices masterServices) |
Modifier and Type | Method and Description |
---|---|
void |
RSGroupBasedLoadBalancer.setMasterServices(MasterServices masterServices) |
Constructor and Description |
---|
RSGroupAdminServer(MasterServices master,
RSGroupInfoManager rsGroupInfoManager) |
Copyright © 2007–2019 Cloudera. All rights reserved.