Uses of Interface
org.apache.hadoop.hbase.conf.ConfigurationObserver
Packages that use org.apache.hadoop.hbase.conf.ConfigurationObserver
Package
Description
Provides implementations of
HFile and HFile
BlockCache.Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.conf
Subinterfaces of org.apache.hadoop.hbase.conf.ConfigurationObserver in in org.apache.hadoop.hbase.confModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.conf.PropagatingConfigurationObserverThis extension to ConfigurationObserver allows the configuration to propagate to the children of the currentConfigurationObserver.Methods in org.apache.hadoop.hbase.conf with parameters of type org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeMethodDescriptionvoidConfigurationManager.deregisterObserver(org.apache.hadoop.hbase.conf.ConfigurationObserver observer) Deregister an observer classvoidConfigurationManager.registerObserver(org.apache.hadoop.hbase.conf.ConfigurationObserver observer) Register an observer class -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.favored
Classes in org.apache.hadoop.hbase.favored that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.favored.FavoredNodeLoadBalancerAn implementation of theLoadBalancerthat assigns favored nodes for each region. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.io.asyncfs.monitor
Classes in org.apache.hadoop.hbase.io.asyncfs.monitor that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManagerThe class to manage the excluded datanodes of the WALs on the regionserver.classorg.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitorClass for monitor the wal file flush performance. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.io.hfile
Classes in org.apache.hadoop.hbase.io.hfile that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.io.hfile.CacheConfigStores all of the cache objects and configuration for a single HFile. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.ipc
Classes in org.apache.hadoop.hbase.ipc that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.ipc.NettyRpcServerAn RPC server with Netty4 implementation.classorg.apache.hadoop.hbase.ipc.RpcServerAn RPC server that hosts protobuf described Services.classorg.apache.hadoop.hbase.ipc.SimpleRpcSchedulerThe default scheduler.classorg.apache.hadoop.hbase.ipc.SimpleRpcServerDeprecated. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.master
Subinterfaces of org.apache.hadoop.hbase.conf.ConfigurationObserver in in org.apache.hadoop.hbase.masterModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.master.LoadBalancerMakes decisions about the placement and movement of Regions across RegionServers.Classes in org.apache.hadoop.hbase.master that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.HMasterHMaster is the "master server" for HBase.static classorg.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMasterclassorg.apache.hadoop.hbase.master.MasterRpcServicesImplements the master RPC services.classorg.apache.hadoop.hbase.master.RegionsRecoveryConfigManagerConfig manager for RegionsRecovery Chore - Dynamically reload config and update chore accordinglyclassorg.apache.hadoop.hbase.master.ServerManagerThe ServerManager class manages info about region servers. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.master.balancer
Classes in org.apache.hadoop.hbase.master.balancer that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.master.balancer.BaseLoadBalancerThe base class for load balancers. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.regionserver
Subinterfaces of org.apache.hadoop.hbase.conf.ConfigurationObserver in in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.regionserver.RegionRegion is a subset of HRegion with operations required for theCoprocessors.Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.regionserver.CompactSplitCompact region on request and then run split if appropriateclassorg.apache.hadoop.hbase.regionserver.HMobStoreThe store implementation to save MOBs (medium objects), it extends the HStore.classorg.apache.hadoop.hbase.regionserver.HRegionRegions store data for a certain region of a table.classorg.apache.hadoop.hbase.regionserver.HRegionServerHRegionServer makes a set of HRegions available to clients.classorg.apache.hadoop.hbase.regionserver.HStoreA Store holds a column family in a Region.classorg.apache.hadoop.hbase.regionserver.MemStoreFlusherThread that flushes cache on request NOTE: This class extends Thread rather than Chore because the sleep time can be interrupted when there is something to do, rather than the Chore sleep time which is invariant.final classorg.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifierClass to submit requests for PrefetchExecutor depending on configuration changeclassorg.apache.hadoop.hbase.regionserver.RSRpcServicesImplements the regionserver RPC services. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.replication
Classes in org.apache.hadoop.hbase.replication that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.replication.ReplicationPeerImplclassorg.apache.hadoop.hbase.replication.ReplicationPeersThis provides an class for maintaining a set of peer clusters. -
Uses of org.apache.hadoop.hbase.conf.ConfigurationObserver in org.apache.hadoop.hbase.rsgroup
Subinterfaces of org.apache.hadoop.hbase.conf.ConfigurationObserver in in org.apache.hadoop.hbase.rsgroupModifier and TypeInterfaceDescriptioninterfaceorg.apache.hadoop.hbase.rsgroup.RSGroupableBalancerMarker Interface.Classes in org.apache.hadoop.hbase.rsgroup that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in inModifier and TypeClassDescriptionclassorg.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancerGroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.