Uses of Interface
org.apache.hadoop.hbase.Server
Package
Description
Tools to help define network clients and servers.
Multi Cluster Replication
-
Uses of Server in org.apache.hadoop.hbase.coordination
-
Uses of Server in org.apache.hadoop.hbase.executor
ModifierConstructorDescriptionEventHandler
(Server server, EventType eventType) Default base class constructor. -
Uses of Server in org.apache.hadoop.hbase.ipc
Modifier 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) ModifierConstructorDescriptionNettyRpcServer
(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
Modifier and TypeClassDescriptionclass
HMaster is the "master server" for HBase.static class
Modifier and TypeFieldDescription(package private) final Server
ActiveMasterManager.master
private final Server
CachedClusterId.server
Modifier and TypeMethodDescriptionprotected ActiveMasterManager
HMaster.createActiveMasterManager
(ZKWatcher zk, ServerName sn, Server server) Protected to have custom implementations in tests override the default ActiveMaster implementation.protected RpcServerInterface
MasterRpcServices.createRpcServer
(Server server, RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name) ModifierConstructorDescription(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
-
Uses of Server in org.apache.hadoop.hbase.master.zksyncer
ModifierConstructorDescriptionClientZKSyncer
(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
-
Uses of Server in org.apache.hadoop.hbase.procedure2.store.region
ModifierConstructorDescriptionRegionProcedureStore
(Server server, MasterRegion region, LeaseRecovery leaseRecovery) -
Uses of Server in org.apache.hadoop.hbase.regionserver
Modifier and TypeInterfaceDescriptioninterface
A curated subset of services provided byHRegionServer
.Modifier and TypeClassDescriptionclass
HRegionServer makes a set of HRegions available to clients.Modifier 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.ModifierConstructorDescriptionCompactedHFilesDischargeHandler
(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
Modifier and TypeFieldDescriptionprivate final Server
OpenRegionHandler.PostOpenDeployTasksThread.server
ModifierConstructorDescriptionCloseMetaHandler
(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, ClusterConnection connection, RpcRetryingCallerFactory rpcRetryingCallerFactory, RpcControllerFactory rpcControllerFactory, int operationTimeout, 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
Modifier 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) -
Uses of Server in org.apache.hadoop.hbase.replication.regionserver
Modifier and TypeFieldDescriptionprivate Server
Replication.server
protected Server
ReplicationSource.server
private final Server
ReplicationSourceManager.server
Modifier and TypeMethodDescriptionvoid
RecoveredReplicationSource.init
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, String peerClusterZnode, UUID clusterId, WALFileLengthProvider walFileLengthProvider, MetricsSource metrics) void
ReplicationSource.init
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, ReplicationSourceManager manager, ReplicationQueueStorage queueStorage, ReplicationPeer replicationPeer, Server server, String queueId, 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, String queueId, 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) ModifierConstructorDescriptionReplicationSourceManager
(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, MetricsReplicationGlobalSourceSource globalMetrics) Creates a replication manager and sets the watch on all the other registered region servers