Uses of Class
org.apache.hadoop.hbase.ipc.RpcScheduler

Packages that use org.apache.hadoop.hbase.ipc.RpcScheduler
Package
Description
Tools to help define network clients and servers.
 
 
  • Uses of org.apache.hadoop.hbase.ipc.RpcScheduler in org.apache.hadoop.hbase.ipc

    Subclasses of org.apache.hadoop.hbase.ipc.RpcScheduler in in org.apache.hadoop.hbase.ipc
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.ipc.DelegatingRpcScheduler
    Users of the hbase.region.server.rpc.scheduler.factory.class customization config can return an implementation which extends this class in order to minimize impact of breaking interface changes.
    class 
    org.apache.hadoop.hbase.ipc.FifoRpcScheduler
    A very simple RpcScheduler} that serves incoming requests in order.
    class 
    org.apache.hadoop.hbase.ipc.MasterFifoRpcScheduler
    A special RpcScheduler} only used for master.
    class 
    org.apache.hadoop.hbase.ipc.SimpleRpcScheduler
    The default scheduler.
    Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.ipc.RpcScheduler in in
    Modifier and Type
    Field
    Description
    protected org.apache.hadoop.hbase.ipc.RpcScheduler
    DelegatingRpcScheduler.delegate
     
    protected final org.apache.hadoop.hbase.ipc.RpcScheduler
    RpcServer.scheduler
     
    Methods in org.apache.hadoop.hbase.ipc that return org.apache.hadoop.hbase.ipc.RpcScheduler in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.ipc.RpcScheduler
    RpcServer.getScheduler()
     
    org.apache.hadoop.hbase.ipc.RpcScheduler
    RpcServerInterface.getScheduler()
     
    Methods in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.ipc.RpcScheduler 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.ipc.RpcScheduler in in
    Modifier
    Constructor
    Description
     
    DelegatingRpcScheduler(org.apache.hadoop.hbase.ipc.RpcScheduler delegate)
     
     
    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.ipc.RpcScheduler in org.apache.hadoop.hbase.quotas

    Methods in org.apache.hadoop.hbase.quotas with parameters of type org.apache.hadoop.hbase.ipc.RpcScheduler in in
    Modifier and Type
    Method
    Description
    void
    RegionServerRpcQuotaManager.start(org.apache.hadoop.hbase.ipc.RpcScheduler rpcScheduler)
     
  • Uses of org.apache.hadoop.hbase.ipc.RpcScheduler in org.apache.hadoop.hbase.regionserver

    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.ipc.RpcScheduler in in
    Modifier and Type
    Method
    Description
    org.apache.hadoop.hbase.ipc.RpcScheduler
    FifoRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority)
    Deprecated.
    org.apache.hadoop.hbase.ipc.RpcScheduler
    FifoRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server)
     
    org.apache.hadoop.hbase.ipc.RpcScheduler
    MasterFifoRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server)
     
    org.apache.hadoop.hbase.ipc.RpcScheduler
    RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority)
    Deprecated.
    since 1.0.0.
    org.apache.hadoop.hbase.ipc.RpcScheduler
    RpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server)
    Constructs a RpcScheduler.
    org.apache.hadoop.hbase.ipc.RpcScheduler
    SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority)
    Deprecated.
    since 1.0.0.
    org.apache.hadoop.hbase.ipc.RpcScheduler
    SimpleRpcSchedulerFactory.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server)
     
    org.apache.hadoop.hbase.ipc.RpcScheduler
    RSRpcServices.getRpcScheduler()