| Package | Description |
|---|---|
| org.apache.hadoop.hbase | |
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.balancer | |
| org.apache.hadoop.hbase.master.http | |
| org.apache.hadoop.hbase.master.http.api_v1 | |
| org.apache.hadoop.hbase.master.http.jersey | |
| org.apache.hadoop.hbase.master.locking | |
| org.apache.hadoop.hbase.master.normalizer |
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
|
| org.apache.hadoop.hbase.mob | |
| org.apache.hadoop.hbase.quotas | |
| org.apache.hadoop.hbase.security.access | |
| org.apache.hadoop.hbase.util |
| Modifier and Type | Field and Description |
|---|---|
private Class<? extends HMaster> |
LocalHBaseCluster.masterClass |
| Modifier and Type | Method and Description |
|---|---|
HMaster |
LocalHBaseCluster.getActiveMaster()
Gets the current active master, if available.
|
HMaster |
LocalHBaseCluster.getMaster(int serverNumber)
Returns the HMaster thread
|
| Modifier and Type | Method and Description |
|---|---|
private static Class<? extends HMaster> |
LocalHBaseCluster.getMasterImplementation(org.apache.hadoop.conf.Configuration conf) |
| Constructor and Description |
|---|
LocalHBaseCluster(org.apache.hadoop.conf.Configuration conf,
int noMasters,
int noRegionServers,
Class<? extends HMaster> masterClass,
Class<? extends HRegionServer> regionServerClass) |
LocalHBaseCluster(org.apache.hadoop.conf.Configuration conf,
int noMasters,
int noAlwaysStandByMasters,
int noRegionServers,
Class<? extends HMaster> masterClass,
Class<? extends HRegionServer> regionServerClass)
Constructor.
|
| Modifier and Type | Class and Description |
|---|---|
static class |
HMasterCommandLine.LocalHMaster |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
RegionsRecoveryConfigManager.hMaster |
private HMaster |
RegionsRecoveryChore.hMaster |
private HMaster |
MetricsMasterWrapperImpl.master |
private HMaster |
ClusterStatusPublisher.master |
private HMaster |
MasterRpcServices.master |
private HMaster |
MasterInitializationMonitor.master |
| Modifier and Type | Field and Description |
|---|---|
private Class<? extends HMaster> |
HMasterCommandLine.masterClass |
| Modifier and Type | Method and Description |
|---|---|
static HMaster |
HMaster.constructMaster(Class<? extends HMaster> masterClass,
org.apache.hadoop.conf.Configuration conf)
Utility for constructing an instance of the passed HMaster class.
|
| Modifier and Type | Method and Description |
|---|---|
static HMaster |
HMaster.constructMaster(Class<? extends HMaster> masterClass,
org.apache.hadoop.conf.Configuration conf)
Utility for constructing an instance of the passed HMaster class.
|
| Constructor and Description |
|---|
ClusterStatusPublisher(HMaster master,
org.apache.hadoop.conf.Configuration conf,
Class<? extends ClusterStatusPublisher.Publisher> publisherClass) |
MasterInitializationMonitor(HMaster master)
Creates a Thread that monitors the
#isInitialized() state. |
MasterRpcServices(HMaster m) |
MetricsMasterWrapperImpl(HMaster master) |
RegionsRecoveryChore(Stoppable stopper,
org.apache.hadoop.conf.Configuration configuration,
HMaster hMaster)
Construct RegionsRecoveryChore with provided params
|
RegionsRecoveryConfigManager(HMaster hMaster) |
| Constructor and Description |
|---|
HMasterCommandLine(Class<? extends HMaster> masterClass) |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
ClusterStatusChore.master |
private HMaster |
BalancerChore.master |
| Constructor and Description |
|---|
BalancerChore(HMaster master) |
ClusterStatusChore(HMaster master,
LoadBalancer balancer) |
| Modifier and Type | Method and Description |
|---|---|
private void |
MasterDumpServlet.dumpRIT(HMaster master,
PrintWriter out) |
private void |
MasterDumpServlet.dumpServers(HMaster master,
PrintWriter out) |
private Map<String,Integer> |
MasterStatusServlet.getFragmentationInfo(HMaster master,
org.apache.hadoop.conf.Configuration conf) |
private ServerName |
MasterStatusServlet.getMetaLocationOrNull(HMaster master) |
| Modifier and Type | Method and Description |
|---|---|
static org.apache.hbase.thirdparty.org.glassfish.jersey.server.ResourceConfig |
ResourceConfigFactory.createResourceConfig(org.apache.hadoop.conf.Configuration conf,
HMaster master) |
| Modifier and Type | Field and Description |
|---|---|
private Supplier<HMaster> |
MasterFeature.supplier |
| Constructor and Description |
|---|
MasterFeature(HMaster master) |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
LockManager.master |
| Constructor and Description |
|---|
LockManager(HMaster master) |
| Modifier and Type | Method and Description |
|---|---|
static RegionNormalizerManager |
RegionNormalizerFactory.createNormalizerManager(org.apache.hadoop.conf.Configuration conf,
ZKWatcher zkWatcher,
HMaster master) |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
MobFileCompactionChore.master |
private HMaster |
MobFileCleanerChore.master |
| Constructor and Description |
|---|
MobFileCleanerChore(HMaster master) |
MobFileCompactionChore(HMaster master) |
| Constructor and Description |
|---|
QuotaObserverChore(HMaster master,
MetricsMaster metrics) |
SnapshotQuotaObserverChore(HMaster master,
MetricsMaster metrics) |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
SnapshotScannerHDFSAclCleaner.master |
| Modifier and Type | Field and Description |
|---|---|
private HMaster |
JVMClusterUtil.MasterThread.master |
| Modifier and Type | Method and Description |
|---|---|
HMaster |
JVMClusterUtil.MasterThread.getMaster()
Returns the master
|
| Modifier and Type | Method and Description |
|---|---|
static Map<String,Integer> |
FSUtils.getTableFragmentation(HMaster master)
Runs through the HBase rootdir and checks how many stores for each table have more than one
file in them.
|
static int |
FSUtils.getTotalTableFragmentation(HMaster master)
Returns the total overall fragmentation percentage.
|
| Modifier and Type | Method and Description |
|---|---|
static JVMClusterUtil.MasterThread |
JVMClusterUtil.createMasterThread(org.apache.hadoop.conf.Configuration c,
Class<? extends HMaster> hmc,
int index)
Creates a
JVMClusterUtil.MasterThread. |
| Constructor and Description |
|---|
MasterThread(HMaster m,
int index) |
Copyright © 2007–2020 The Apache Software Foundation. All rights reserved.