Uses of Interface
org.apache.hadoop.hbase.conf.ConfigurationObserver

Packages that use org.apache.hadoop.hbase.conf.ConfigurationObserver
  • 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.conf
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.conf.PropagatingConfigurationObserver
    This extension to ConfigurationObserver allows the configuration to propagate to the children of the current ConfigurationObserver.
    Methods in org.apache.hadoop.hbase.conf with parameters of type org.apache.hadoop.hbase.conf.ConfigurationObserver in in
    Modifier and Type
    Method
    Description
    void
    ConfigurationManager.deregisterObserver(org.apache.hadoop.hbase.conf.ConfigurationObserver observer)
    Deregister an observer class
    void
    ConfigurationManager.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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.favored.FavoredNodeLoadBalancer
    An implementation of the LoadBalancer that 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.io.asyncfs.monitor.ExcludeDatanodeManager
    The class to manage the excluded datanodes of the WALs on the regionserver.
    class 
    org.apache.hadoop.hbase.io.asyncfs.monitor.StreamSlowMonitor
    Class 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.io.hfile.CacheConfig
    Stores 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ipc.NettyRpcServer
    An RPC server with Netty4 implementation.
    class 
    org.apache.hadoop.hbase.ipc.RpcServer
    An RPC server that hosts protobuf described Services.
    class 
    org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
    The default scheduler.
    class 
    org.apache.hadoop.hbase.ipc.SimpleRpcServer
    Deprecated.
  • 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.master
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.master.LoadBalancer
    Makes 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.master.HMaster
    HMaster is the "master server" for HBase.
    static class 
    org.apache.hadoop.hbase.master.HMasterCommandLine.LocalHMaster
     
    class 
    org.apache.hadoop.hbase.master.MasterRpcServices
    Implements the master RPC services.
    class 
    org.apache.hadoop.hbase.master.RegionsRecoveryConfigManager
    Config manager for RegionsRecovery Chore - Dynamically reload config and update chore accordingly
    class 
    org.apache.hadoop.hbase.master.ServerManager
    The 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.master.balancer.BaseLoadBalancer
    The 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.regionserver
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.regionserver.Region
    Region is a subset of HRegion with operations required for the Coprocessors.
    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.CompactSplit
    Compact region on request and then run split if appropriate
    class 
    org.apache.hadoop.hbase.regionserver.HMobStore
    The store implementation to save MOBs (medium objects), it extends the HStore.
    class 
    org.apache.hadoop.hbase.regionserver.HRegion
    Regions store data for a certain region of a table.
    class 
    org.apache.hadoop.hbase.regionserver.HRegionServer
    HRegionServer makes a set of HRegions available to clients.
    class 
    org.apache.hadoop.hbase.regionserver.HStore
    A Store holds a column family in a Region.
    class 
    org.apache.hadoop.hbase.regionserver.MemStoreFlusher
    Thread 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 class 
    org.apache.hadoop.hbase.regionserver.PrefetchExecutorNotifier
    Class to submit requests for PrefetchExecutor depending on configuration change
    class 
    org.apache.hadoop.hbase.regionserver.RSRpcServices
    Implements 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 in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.replication.ReplicationPeerImpl
     
    class 
    org.apache.hadoop.hbase.replication.ReplicationPeers
    This 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.rsgroup
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.rsgroup.RSGroupableBalancer
    Marker Interface.
    Classes in org.apache.hadoop.hbase.rsgroup that implement org.apache.hadoop.hbase.conf.ConfigurationObserver in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.rsgroup.RSGroupBasedLoadBalancer
    GroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.