| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.conf | |
| org.apache.hadoop.hbase.favored | |
| org.apache.hadoop.hbase.ipc | Tools to help define network clients and servers. | 
| org.apache.hadoop.hbase.master | |
| org.apache.hadoop.hbase.master.balancer | |
| org.apache.hadoop.hbase.master.cleaner | |
| 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.master.procedure | |
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.rsgroup | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | PropagatingConfigurationObserverThis extension to ConfigurationObserver allows the configuration to propagate to the children of
 the current  ConfigurationObserver. | 
| Modifier and Type | Field and Description | 
|---|---|
| private Set<ConfigurationObserver> | ConfigurationManager. configurationObservers | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ConfigurationManager. deregisterObserver(ConfigurationObserver observer)Deregister an observer class | 
| void | ConfigurationManager. registerObserver(ConfigurationObserver observer)Register an observer class | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FavoredNodeLoadBalancerAn implementation of the  LoadBalancerthat
 assigns favored nodes for each region. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NettyRpcServerAn RPC server with Netty4 implementation. | 
| class  | RpcServerAn RPC server that hosts protobuf described Services. | 
| class  | SimpleRpcSchedulerThe default scheduler. | 
| class  | SimpleRpcServerThe RPC server with native java NIO implementation deriving from Hadoop to
 host protobuf described Services. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | LoadBalancerMakes decisions about the placement and movement of Regions across
 RegionServers. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HMasterHMaster is the "master server" for HBase. | 
| static class  | HMasterCommandLine.LocalHMaster | 
| class  | MasterRpcServicesImplements the master RPC services. | 
| class  | RegionsRecoveryConfigManagerConfig manager for RegionsRecovery Chore - Dynamically reload config and update chore
 accordingly | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BaseLoadBalancerThe base class for load balancers. | 
| class  | FavoredStochasticBalancerAn implementation of the  LoadBalancerthat
 assigns favored nodes for each region. | 
| class  | SimpleLoadBalancerMakes decisions about the placement and movement of Regions across
 RegionServers. | 
| class  | StochasticLoadBalancerThis is a best effort load balancer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DirScanPoolThe thread pool used for scan directories | 
| class  | HFileCleanerThis Chore, every time it runs, will clear the HFiles in the hfile archive
 folder that are deletable for each HFile cleaner in the chain. | 
| class  | LogCleanerThis Chore, every time it runs, will attempt to delete the WALs and Procedure WALs in the old
 logs folder. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RegionNormalizerManagerThis class encapsulates the details of the  RegionNormalizersubsystem. | 
| (package private) class  | RegionNormalizerWorkerConsumes normalization request targets ( TableNames) off theRegionNormalizerWorkQueue, dispatches them to theRegionNormalizer,
 and executes the resultingNormalizationPlans. | 
| (package private) class  | SimpleRegionNormalizerSimple implementation of region normalizer. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MasterProcedureEnv | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RegionRegion is a subset of HRegion with operations required for the  Coprocessors. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CompactSplitCompact region on request and then run split if appropriate | 
| class  | HMobStoreThe store implementation to save MOBs (medium objects), it extends the HStore. | 
| class  | HRegionRegions store data for a certain region of a table. | 
| class  | HRegionServerHRegionServer makes a set of HRegions available to clients. | 
| class  | HStoreA Store holds a column family in a Region. | 
| class  | RSRpcServicesImplements the regionserver RPC services. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | RSGroupableBalancerMarker Interface. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | RSGroupBasedLoadBalancerGroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721)
 It does region balance based on a table's group membership. | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.