Uses of Interface
org.apache.hadoop.hbase.Server

Packages that use org.apache.hadoop.hbase.Server
Package
Description
 
Tools to help define network clients and servers.
 
 
Multi Cluster Replication
  • Uses of org.apache.hadoop.hbase.Server in org.apache.hadoop.hbase.coordination

    Constructors in org.apache.hadoop.hbase.coordination with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier
    Constructor
    Description
     
    ZkCoordinatedStateManager(org.apache.hadoop.hbase.Server server)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.Server in org.apache.hadoop.hbase.ipc

    Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.Server
    RpcServer.server
     
    Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Method
    Description
    static org.apache.hadoop.hbase.ipc.RpcServer
    RpcServerFactory.createRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler)
     
    static org.apache.hadoop.hbase.ipc.RpcServer
    RpcServerFactory.createRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler, boolean reservoirEnabled)
     
    Constructors in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier
    Constructor
    Description
     
    NettyRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler, boolean reservoirEnabled)
     
     
    RpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler, boolean reservoirEnabled)
    Constructs a server listening on the named port and address.
     
    SimpleRpcServer(org.apache.hadoop.hbase.Server server, String name, List<org.apache.hadoop.hbase.ipc.RpcServer.BlockingServiceAndInterface> services, InetSocketAddress bindAddress, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.RpcScheduler scheduler, boolean reservoirEnabled)
    Deprecated.
    Constructs a server listening on the named port and address.
  • Uses of org.apache.hadoop.hbase.Server in org.apache.hadoop.hbase.master

    Subinterfaces of org.apache.hadoop.hbase.Server in in org.apache.hadoop.hbase.master
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.master.MasterServices
    A curated subset of services provided by HMaster.
    Classes in org.apache.hadoop.hbase.master that implement org.apache.hadoop.hbase.Server 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
     
    Methods in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.master.ActiveMasterManager
    HMaster.createActiveMasterManager(org.apache.hadoop.hbase.zookeeper.ZKWatcher zk, org.apache.hadoop.hbase.ServerName sn, org.apache.hadoop.hbase.Server server)
    Protected to have custom implementations in tests override the default ActiveMaster implementation.
    protected org.apache.hadoop.hbase.ipc.RpcServerInterface
    MasterRpcServices.createRpcServer(org.apache.hadoop.hbase.Server server, org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name)
     
    Constructors in org.apache.hadoop.hbase.master with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier
    Constructor
    Description
     
    CachedClusterId(org.apache.hadoop.hbase.Server server, org.apache.hadoop.conf.Configuration conf)
     
  • Uses of org.apache.hadoop.hbase.Server in org.apache.hadoop.hbase.regionserver

    Subinterfaces of org.apache.hadoop.hbase.Server in in org.apache.hadoop.hbase.regionserver
    Modifier and Type
    Interface
    Description
    interface 
    org.apache.hadoop.hbase.regionserver.RegionServerServices
    A curated subset of services provided by HRegionServer.
    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.HRegionServer
    HRegionServer makes a set of HRegions available to clients.
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.ipc.RpcServerInterface
    RSRpcServices.createRpcServer(org.apache.hadoop.hbase.Server server, org.apache.hadoop.hbase.regionserver.RpcSchedulerFactory rpcSchedulerFactory, InetSocketAddress bindAddress, String name)
     
    void
    ReplicationService.initialize(org.apache.hadoop.hbase.Server rs, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logdir, org.apache.hadoop.fs.Path oldLogDir, org.apache.hadoop.hbase.wal.WALFactory walFactory)
    Initializes the replication service object.
    Constructors in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier
    Constructor
    Description
     
    CompactedHFilesDischargeHandler(org.apache.hadoop.hbase.Server server, org.apache.hadoop.hbase.executor.EventType eventType, org.apache.hadoop.hbase.regionserver.HStore store)
     
     
    SplitLogWorker(org.apache.hadoop.hbase.Server hserver, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.regionserver.RegionServerServices server, org.apache.hadoop.hbase.regionserver.SplitLogWorker.TaskExecutor splitTaskExecutor)
    Deprecated.
     
  • Uses of org.apache.hadoop.hbase.Server in org.apache.hadoop.hbase.replication

    Methods in org.apache.hadoop.hbase.replication with parameters of type org.apache.hadoop.hbase.Server in in
    Modifier and Type
    Method
    Description
    void
    ReplicationSinkServiceImpl.initialize(org.apache.hadoop.hbase.Server server, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path logdir, org.apache.hadoop.fs.Path oldLogDir, org.apache.hadoop.hbase.wal.WALFactory walFactory)