Modifier and Type | Field and Description |
---|---|
private MasterServices |
MetaMigrationConvertingToPB.ConvertToPBMetaVisitor.services |
Modifier and Type | Method and Description |
---|---|
(package private) static long |
MetaMigrationConvertingToPB.updateMeta(MasterServices masterServices)
Deprecated.
Update hbase:meta rows, converting writable serialization to PB
|
static long |
MetaMigrationConvertingToPB.updateMetaIfNecessary(MasterServices services)
Deprecated.
Converting writable serialization to PB, if it is needed.
|
Constructor and Description |
---|
MetaMigrationConvertingToPB.ConvertToPBMetaVisitor(MasterServices services) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
SplitLogManagerCoordination.SplitLogManagerDetails.master |
Modifier and Type | Method and Description |
---|---|
MasterServices |
SplitLogManagerCoordination.SplitLogManagerDetails.getMaster() |
Constructor and Description |
---|
SplitLogManagerCoordination.SplitLogManagerDetails(ConcurrentMap<String,SplitLogManager.Task> tasks,
MasterServices master,
Set<String> failedDeletions,
ServerName serverName) |
ZKSplitLogManagerCoordination.ZkSplitLogManagerDetails(ConcurrentMap<String,SplitLogManager.Task> tasks,
MasterServices master,
Set<String> failedDeletions,
ServerName serverName) |
Modifier and Type | Method and Description |
---|---|
MasterServices |
MasterCoprocessorEnvironment.getMasterServices() |
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 |
MasterCoprocessorHost.masterServices |
private MasterServices |
MasterCoprocessorHost.MasterEnvironment.masterServices |
private MasterServices |
TableNamespaceManager.masterServices |
protected MasterServices |
AssignmentManager.server |
private MasterServices |
ServerManager.services |
private MasterServices |
CatalogJanitor.services |
private MasterServices |
MasterFileSystem.services |
Modifier and Type | Method and Description |
---|---|
MasterServices |
MasterCoprocessorHost.MasterEnvironment.getMasterServices() |
Modifier and Type | Method and Description |
---|---|
private void |
TableNamespaceManager.createNamespaceTable(MasterServices masterServices) |
(package private) ServerManager |
HMaster.createServerManager(Server master,
MasterServices services)
Create a
ServerManager instance. |
static List<HRegionInfo> |
AssignmentManager.replicaRegionsNotRecordedInMeta(Set<HRegionInfo> regionsRecordedInMeta,
MasterServices master)
Get a list of replica regions that are:
not recorded in meta yet.
|
void |
LoadBalancer.setMasterServices(MasterServices masterServices)
Set the master service.
|
Constructor and Description |
---|
AssignmentManager(MasterServices server,
ServerManager serverManager,
LoadBalancer balancer,
ExecutorService service,
MetricsMaster metricsMaster,
TableLockManager tableLockManager)
Constructs a new assignment manager.
|
CatalogJanitor(Server server,
MasterServices services) |
MasterCoprocessorHost.MasterEnvironment(Class<?> implClass,
Coprocessor impl,
int priority,
int seq,
org.apache.hadoop.conf.Configuration conf,
MasterServices services) |
MasterCoprocessorHost(MasterServices services,
org.apache.hadoop.conf.Configuration conf) |
MasterFileSystem(Server master,
MasterServices services) |
ServerManager(Server master,
MasterServices services)
Constructor.
|
ServerManager(Server master,
MasterServices services,
boolean connect) |
SplitLogManager(Server server,
org.apache.hadoop.conf.Configuration conf,
Stoppable stopper,
MasterServices master,
ServerName serverName)
Its OK to construct this object even when region-servers are not online.
|
TableNamespaceManager(MasterServices masterServices) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
StochasticLoadBalancer.LocalityBasedCandidateGenerator.masterServices |
protected MasterServices |
BaseLoadBalancer.services |
private MasterServices |
RegionLocationFinder.services |
private MasterServices |
StochasticLoadBalancer.LocalityCostFunction.services |
Modifier and Type | Method and Description |
---|---|
void |
BaseLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
StochasticLoadBalancer.setMasterServices(MasterServices masterServices) |
void |
RegionLocationFinder.setServices(MasterServices services) |
(package private) void |
StochasticLoadBalancer.LocalityBasedCandidateGenerator.setServices(MasterServices services) |
(package private) void |
StochasticLoadBalancer.LocalityCostFunction.setServices(MasterServices srvc) |
Constructor and Description |
---|
StochasticLoadBalancer.LocalityBasedCandidateGenerator(MasterServices masterServices) |
StochasticLoadBalancer.LocalityCostFunction(org.apache.hadoop.conf.Configuration conf,
MasterServices srv) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
DispatchMergingRegionHandler.masterServices |
protected MasterServices |
TableEventHandler.masterServices |
private MasterServices |
EnableTableHandler.services |
Constructor and Description |
---|
CreateTableHandler(Server server,
MasterFileSystem fileSystemManager,
HTableDescriptor hTableDescriptor,
org.apache.hadoop.conf.Configuration conf,
HRegionInfo[] newRegions,
MasterServices masterServices) |
DispatchMergingRegionHandler(MasterServices services,
CatalogJanitor catalogJanitor,
HRegionInfo region_a,
HRegionInfo region_b,
boolean forcible) |
EnableTableHandler(MasterServices services,
TableName tableName,
AssignmentManager assignmentManager,
TableLockManager tableLockManager,
boolean skipTableStateCheck) |
TableEventHandler(EventType eventType,
TableName tableName,
Server server,
MasterServices masterServices) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
SimpleRegionNormalizer.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 |
---|---|
private MasterServices |
MasterProcedureUtil.NonceProcedureRunnable.master |
private MasterServices |
MasterProcedureEnv.master |
Modifier and Type | Method and Description |
---|---|
protected MasterServices |
MasterProcedureUtil.NonceProcedureRunnable.getMaster() |
MasterServices |
MasterProcedureEnv.getMasterServices() |
Constructor and Description |
---|
MasterProcedureEnv(MasterServices master) |
MasterProcedureUtil.NonceProcedureRunnable(MasterServices master,
long nonceGroup,
long nonce) |
Modifier and Type | Field and Description |
---|---|
private MasterServices |
SnapshotManager.master |
protected MasterServices |
TakeSnapshotHandler.master |
private MasterServices |
MasterSnapshotVerifier.services |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManager.initialize(MasterServices master,
MetricsMaster metricsMaster) |
Constructor and Description |
---|
CloneSnapshotHandler(MasterServices masterServices,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor hTableDescriptor) |
DisabledTableSnapshotHandler(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
MasterServices masterServices,
SnapshotManager snapshotManager) |
EnabledTableSnapshotHandler(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
MasterServices master,
SnapshotManager manager) |
MasterSnapshotVerifier(MasterServices services,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
org.apache.hadoop.fs.Path rootDir) |
RestoreSnapshotHandler(MasterServices masterServices,
org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.SnapshotDescription snapshot,
HTableDescriptor htd) |
SnapshotManager(MasterServices master,
ProcedureCoordinator coordinator,
ExecutorService pool,
int sentinelCleanInterval)
Fully specify all necessary components of a snapshot manager.
|
TakeSnapshotHandler(org.apache.hadoop.hbase.protobuf.generated.HBaseProtos.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,
ZooKeeperWatcher zkw) |
Modifier and Type | Method and Description |
---|---|
abstract void |
MasterProcedureManager.initialize(MasterServices master,
MetricsMaster metricsMaster)
Initialize a globally barriered procedure for master.
|
void |
MasterProcedureManagerHost.initialize(MasterServices master,
MetricsMaster metricsMaster) |
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 |
Constructor and Description |
---|
MasterQuotaManager(MasterServices masterServices) |
Modifier and Type | Method and Description |
---|---|
(package private) static void |
AccessControlLists.createACLTable(MasterServices master)
Create the ACL table
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.