Uses of Interface
org.apache.hadoop.hbase.Server
Packages that use Server
Package
Description
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of Server in org.apache.hadoop.hbase
Classes in org.apache.hadoop.hbase that implement ServerModifier and TypeClassDescriptionclass
HBaseServerBase<R extends HBaseRpcServicesBase<?>>
Base class for hbase services, such as master or region server.static class
Deprecated.Subclass so can get at protected methods (none at moment).class
Basic mock region server services. -
Uses of Server in org.apache.hadoop.hbase.coordination
Constructors in org.apache.hadoop.hbase.coordination with parameters of type Server -
Uses of Server in org.apache.hadoop.hbase.executor
Fields in org.apache.hadoop.hbase.executor declared as ServerConstructors in org.apache.hadoop.hbase.executor with parameters of type ServerModifierConstructorDescriptionEventHandler
(Server server, EventType eventType) Default base class constructor. -
Uses of Server in org.apache.hadoop.hbase.ipc
Fields in org.apache.hadoop.hbase.ipc declared as ServerMethods in org.apache.hadoop.hbase.ipc with parameters of type ServerModifier and TypeMethodDescriptionstatic RpcServer
RpcServerFactory.createRpcServer
(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler) static RpcServer
RpcServerFactory.createRpcServer
(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) Constructors in org.apache.hadoop.hbase.ipc with parameters of type ServerModifierConstructorDescriptionNettyRpcServer
(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) RpcServer
(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) Constructs a server listening on the named port and address.SimpleRpcServer
(Server server, String name, List<RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, RpcScheduler scheduler, boolean reservoirEnabled) Deprecated.Constructs a server listening on the named port and address. -
Uses of Server in org.apache.hadoop.hbase.master
Subinterfaces of Server in org.apache.hadoop.hbase.masterClasses in org.apache.hadoop.hbase.master that implement ServerModifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Fields in org.apache.hadoop.hbase.master declared as ServerModifier and TypeFieldDescription(package private) final Server
ActiveMasterManager.master
private final Server
CachedClusterId.server
Methods in org.apache.hadoop.hbase.master with parameters of type ServerModifier and TypeMethodDescriptionprotected ActiveMasterManager
HMaster.createActiveMasterManager
(ZKWatcher zk, ServerName sn, Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.Constructors in org.apache.hadoop.hbase.master with parameters of type ServerModifierConstructorDescription(package private)
ActiveMasterManager
(ZKWatcher watcher, ServerName sn, Server master) CachedClusterId
(Server server, org.apache.hadoop.conf.Configuration conf) -
Uses of Server in org.apache.hadoop.hbase.master.region
Fields in org.apache.hadoop.hbase.master.region declared as ServerModifier and TypeFieldDescriptionprivate final Server
MasterRegion.server
private Server
MasterRegionParams.server
Methods in org.apache.hadoop.hbase.master.region that return ServerMethods in org.apache.hadoop.hbase.master.region with parameters of type ServerConstructors in org.apache.hadoop.hbase.master.region with parameters of type ServerModifierConstructorDescriptionprivate
MasterRegion
(Server server, HRegion region, WALFactory walFactory, MasterRegionFlusherAndCompactor flusherAndCompactor, MasterRegionWALRoller walRoller) -
Uses of Server in org.apache.hadoop.hbase.master.zksyncer
Fields in org.apache.hadoop.hbase.master.zksyncer declared as ServerConstructors in org.apache.hadoop.hbase.master.zksyncer with parameters of type ServerModifierConstructorDescriptionClientZKSyncer
(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) MasterAddressSyncer
(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) MetaLocationSyncer
(ZKWatcher watcher, ZKWatcher clientZkWatcher, Server server) -
Uses of Server in org.apache.hadoop.hbase.procedure
Constructors in org.apache.hadoop.hbase.procedure with parameters of type Server -
Uses of Server in org.apache.hadoop.hbase.procedure2.store.region
Fields in org.apache.hadoop.hbase.procedure2.store.region declared as ServerConstructors in org.apache.hadoop.hbase.procedure2.store.region with parameters of type ServerModifierConstructorDescriptionRegionProcedureStore
(Server server, MasterRegion region, LeaseRecovery leaseRecovery) -
Uses of Server in org.apache.hadoop.hbase.regionserver
Subinterfaces of Server in org.apache.hadoop.hbase.regionserverModifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Classes in org.apache.hadoop.hbase.regionserver that implement ServerModifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.Fields in org.apache.hadoop.hbase.regionserver declared as ServerMethods in org.apache.hadoop.hbase.regionserver with parameters of type ServerModifier and TypeMethodDescriptionprotected RpcServerInterface
RSRpcServices.createRpcServer
(Server server, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) void
ReplicationService.initialize
(Server rs, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logdir, org.apache.hadoop.fs.Path oldLogDir, WALFactory walFactory) Initializes the replication service object.Constructors in org.apache.hadoop.hbase.regionserver with parameters of type ServerModifierConstructorDescriptionCompactedHFilesDischargeHandler
(Server server, EventType eventType, HStore store) (package private)
HeapMemoryManager
(BlockCache blockCache, FlushRequester memStoreFlusher, Server server, RegionServerAccounting regionServerAccounting) SplitLogWorker
(Server hserver, org.apache.hadoop.conf.Configuration conf, RegionServerServices server, SplitLogWorker.TaskExecutor splitTaskExecutor) Deprecated. -
Uses of Server in org.apache.hadoop.hbase.regionserver.handler
Fields in org.apache.hadoop.hbase.regionserver.handler declared as ServerModifier and TypeFieldDescriptionprivate final Server
OpenRegionHandler.PostOpenDeployTasksThread.server
Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type ServerModifierConstructorDescriptionCloseMetaHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort) protected
CloseRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort, EventType eventType, ServerName destination) CloseRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, boolean abort, ServerName destination) This method used internally by the RegionServer to close out regions.OpenMetaHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) OpenPriorityRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) OpenRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime) Deprecated.protected
OpenRegionHandler
(Server server, RegionServerServices rsServices, RegionInfo regionInfo, TableDescriptor htd, long masterSystemTime, EventType eventType) Deprecated.(package private)
PostOpenDeployTasksThread
(HRegion region, Server server, RegionServerServices services, AtomicBoolean signaller, long masterSystemTime) RegionReplicaFlushHandler
(Server server, HRegion region) WALSplitterHandler
(Server server, SplitLogWorkerCoordination coordination, SplitLogWorkerCoordination.SplitTaskDetails splitDetails, CancelableProgressable reporter, AtomicInteger inProgressTasks, SplitLogWorker.TaskExecutor splitTaskExecutor) Deprecated. -
Uses of Server in org.apache.hadoop.hbase.replication
Fields in org.apache.hadoop.hbase.replication declared as ServerModifier and TypeFieldDescriptionprivate final Server
ReplicationEndpoint.Context.server
private Server
ReplicationSinkServiceImpl.server
Methods in org.apache.hadoop.hbase.replication that return ServerMethods in org.apache.hadoop.hbase.replication with parameters of type ServerModifier and TypeMethodDescriptionvoid
ReplicationSinkServiceImpl.initialize
(Server server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logdir, org.apache.hadoop.fs.Path oldLogDir, WALFactory walFactory) Constructors in org.apache.hadoop.hbase.replication with parameters of type ServerModifierConstructorDescriptionContext
(Server server, org.apache.hadoop.conf.Configuration localConf, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, String peerId, UUID clusterId, ReplicationPeer replicationPeer, MetricsSource metrics, TableDescriptors tableDescriptors, Abortable abortable) -
Uses of Server in org.apache.hadoop.hbase.replication.regionserver
Classes in org.apache.hadoop.hbase.replication.regionserver that implement ServerFields in org.apache.hadoop.hbase.replication.regionserver declared as ServerModifier and TypeFieldDescriptionprivate Server
Replication.server
protected Server
ReplicationSource.server
private final Server
ReplicationSourceManager.server
Methods in org.apache.hadoop.hbase.replication.regionserver that return ServerMethods in org.apache.hadoop.hbase.replication.regionserver with parameters of type ServerModifier and TypeMethodDescriptionvoid
ReplicationSource.init
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, ReplicationQueueData queueData, UUID clusterId, WALFileLengthProvider walFileLengthProvider, MetricsSource metrics) Instantiation method used by region serversvoid
ReplicationSourceInterface.init
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, ReplicationQueueData queueData, UUID clusterId, WALFileLengthProvider walFileLengthProvider, MetricsSource metrics) Initializer for the sourcevoid
Replication.initialize
(Server server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logDir, org.apache.hadoop.fs.Path oldLogDir, WALFactory walFactory) Constructors in org.apache.hadoop.hbase.replication.regionserver with parameters of type ServerModifierConstructorDescriptionReplicationSourceManager
(ReplicationQueueStorage queueStorage, ReplicationPeers replicationPeers, org.apache.hadoop.conf.Configuration conf, Server server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logDir, org.apache.hadoop.fs.Path oldLogDir, UUID clusterId, WALFactory walFactory, SyncReplicationPeerMappingManager syncReplicationPeerMappingManager, MetricsReplicationGlobalSourceSource globalMetrics) Creates a replication manager and sets the watch on all the other registered region servers