Uses of Interface
org.apache.hadoop.hbase.conf.ConfigurationObserver
Packages that use ConfigurationObserver
Package
Description
Provides implementations of
HFile and HFile
BlockCache.Provides
BucketCache, an implementation of
BlockCache.Tools to help define network clients and servers.
The Region Normalizer subsystem is responsible for coaxing all the regions in a table toward
a "normal" size, according to their storefile size.
Multi Cluster Replication
-
Uses of ConfigurationObserver in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement ConfigurationObserverModifier and TypeClassDescriptionclassHBaseRpcServicesBase<S extends HBaseServerBase<?>>Base class for Master and RegionServer RpcServices.classHBaseServerBase<R extends HBaseRpcServicesBase<?>>Base class for hbase services, such as master or region server.static classDeprecated.Subclass so can get at protected methods (none at moment). -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.conf
Subinterfaces of ConfigurationObserver in org.apache.hadoop.hbase.confModifier and TypeInterfaceDescriptioninterfaceThis extension to ConfigurationObserver allows the configuration to propagate to the children of the currentConfigurationObserver.Fields in org.apache.hadoop.hbase.conf with type parameters of type ConfigurationObserverModifier and TypeFieldDescriptionprivate final Set<ConfigurationObserver>ConfigurationManager.configurationObserversMethods in org.apache.hadoop.hbase.conf with parameters of type ConfigurationObserverModifier and TypeMethodDescriptionbooleanConfigurationManager.containsObserver(ConfigurationObserver observer) Returns true if contains the observer, for unit test onlyvoidConfigurationManager.deregisterObserver(ConfigurationObserver observer) Deregister an observer classvoidConfigurationManager.registerObserver(ConfigurationObserver observer) Register an observer class -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.favored
Classes in org.apache.hadoop.hbase.favored that implement ConfigurationObserverModifier and TypeClassDescriptionclassAn implementation of theLoadBalancerthat assigns favored nodes for each region. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.io.asyncfs.monitor
Classes in org.apache.hadoop.hbase.io.asyncfs.monitor that implement ConfigurationObserverModifier and TypeClassDescriptionclassThe class to manage the excluded datanodes of the WALs on the regionserver.classClass for monitor the wal file flush performance. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.io.hfile
Subinterfaces of ConfigurationObserver in org.apache.hadoop.hbase.io.hfileModifier and TypeInterfaceDescriptioninterfaceBlock cache interface.interfaceIn-memory BlockCache that may be backed by secondary layer(s).interfaceBlockCache which is resizable.Classes in org.apache.hadoop.hbase.io.hfile that implement ConfigurationObserverModifier and TypeClassDescriptionclassStores all of the cache objects and configuration for a single HFile.classCombinedBlockCache is an abstraction layer that combinesFirstLevelBlockCacheandBucketCache.classclassAn on heap block cache implementation extended LruBlockCache and only cache index block.classThis realisation improve performance of classical LRU cache up to 3 times via reduce GC job.classA block cache implementation that is memory-aware usingHeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMapand with a non-blocking eviction thread giving constant-timeLruBlockCache.cacheBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, org.apache.hadoop.hbase.io.hfile.Cacheable, boolean)andLruBlockCache.getBlock(org.apache.hadoop.hbase.io.hfile.BlockCacheKey, boolean, boolean, boolean)operations.classClass to store blocks into memcached.final classA block cache that is memory-aware usingHeapSize, memory bounded using the W-TinyLFU eviction algorithm, and concurrent. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.io.hfile.bucket
Classes in org.apache.hadoop.hbase.io.hfile.bucket that implement ConfigurationObserverModifier and TypeClassDescriptionclassBucketCache usesBucketAllocatorto allocate/free blocks, and uses BucketCache#ramCache and BucketCache#backingMap in order to determine if a given element is in the cache. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.ipc
Classes in org.apache.hadoop.hbase.ipc that implement ConfigurationObserverModifier and TypeClassDescriptionclassAn RPC server with Netty4 implementation.classAn RPC server that hosts protobuf described Services.classThe default scheduler.classDeprecated.Since 2.4.14, 2.5.0, will be removed in 4.0.0. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master
Subinterfaces of ConfigurationObserver in org.apache.hadoop.hbase.masterModifier and TypeInterfaceDescriptioninterfaceMakes decisions about the placement and movement of Regions across RegionServers.Classes in org.apache.hadoop.hbase.master that implement ConfigurationObserverModifier and TypeClassDescriptionclassHMaster is the "master server" for HBase.static classclassImplements the master RPC services.classConfig manager for RegionsRecovery Chore - Dynamically reload config and update chore accordinglyclassThe ServerManager class manages info about region servers. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master.balancer
Subinterfaces of ConfigurationObserver in org.apache.hadoop.hbase.master.balancerModifier and TypeInterfaceDescriptioninterfaceThis is the cluster we want to balance.Classes in org.apache.hadoop.hbase.master.balancer that implement ConfigurationObserverModifier and TypeClassDescriptionclassThe base class for load balancers.classclassAn implementation of theLoadBalancerthat assigns favored nodes for each region.classa balancer which is only used in maintenance mode.classMaster based cluster info provider.classMakes decisions about the placement and movement of Regions across RegionServers.classThis is a best effort load balancer. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master.cleaner
Classes in org.apache.hadoop.hbase.master.cleaner that implement ConfigurationObserverModifier and TypeClassDescriptionclassThe thread pool used for scan directoriesclassThis Chore, every time it runs, will clear the HFiles in the hfile archive folder that are deletable for each HFile cleaner in the chain.classThis Chore, every time it runs, will attempt to delete the WALs and Procedure WALs in the old logs folder. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master.normalizer
Classes in org.apache.hadoop.hbase.master.normalizer that implement ConfigurationObserverModifier and TypeClassDescriptionclassThis class encapsulates the details of theRegionNormalizersubsystem.(package private) classConsumes normalization request targets (TableNames) off theRegionNormalizerWorkQueue, dispatches them to theRegionNormalizer, and executes the resultingNormalizationPlans.(package private) classSimple implementation of region normalizer. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master.procedure
Classes in org.apache.hadoop.hbase.master.procedure that implement ConfigurationObserver -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.master.replication
Classes in org.apache.hadoop.hbase.master.replication that implement ConfigurationObserverModifier and TypeClassDescriptionclassManages and performs all replication admin operations. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.quotas
Classes in org.apache.hadoop.hbase.quotas that implement ConfigurationObserver -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.regionserver
Subinterfaces of ConfigurationObserver in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterfaceRegion is a subset of HRegion with operations required for theCoprocessors.Classes in org.apache.hadoop.hbase.regionserver that implement ConfigurationObserverModifier and TypeClassDescriptionclassCompact region on request and then run split if appropriateclassThe store implementation to save MOBs (medium objects), it extends the HStore.classRegions store data for a certain region of a table.classHRegionServer makes a set of HRegions available to clients.classA Store holds a column family in a Region.classThread 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 classClass to submit requests for PrefetchExecutor depending on configuration changeclassImplements the regionserver RPC services. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.replication
Classes in org.apache.hadoop.hbase.replication that implement ConfigurationObserverModifier and TypeClassDescriptionclassclassThis provides an class for maintaining a set of peer clusters. -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.replication.regionserver
Classes in org.apache.hadoop.hbase.replication.regionserver that implement ConfigurationObserver -
Uses of ConfigurationObserver in org.apache.hadoop.hbase.rsgroup
Classes in org.apache.hadoop.hbase.rsgroup that implement ConfigurationObserverModifier and TypeClassDescriptionclassGroupBasedLoadBalancer, used when Region Server Grouping is configured (HBase-6721) It does region balance based on a table's group membership.