Uses of Interface
org.apache.hadoop.hbase.ipc.PriorityFunction

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

    Fields in org.apache.hadoop.hbase.ipc declared as org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier and Type
    Field
    Description
    protected final org.apache.hadoop.hbase.ipc.PriorityFunction
    PluggableBlockingQueue.priority
     
    Constructors in org.apache.hadoop.hbase.ipc with parameters of type org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier
    Constructor
    Description
     
    BalancedQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    BalancedQueueRpcExecutor(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    FastPathBalancedQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    FastPathBalancedQueueRpcExecutor(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    FastPathRWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    MetaRWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    PluggableBlockingQueue(int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf)
     
     
    RpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    RpcExecutor(String name, int handlerCount, String callQueueType, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    RWQueueRpcExecutor(String name, int handlerCount, int maxQueueLength, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.hbase.Abortable abortable)
     
     
    SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf, int handlerCount, int priorityHandlerCount, int replicationHandlerCount, int metaTransitionHandler, org.apache.hadoop.hbase.ipc.PriorityFunction priority, org.apache.hadoop.hbase.Abortable server, int highPriorityLevel)
     
     
    SimpleRpcScheduler(org.apache.hadoop.conf.Configuration conf, int handlerCount, int priorityHandlerCount, int replicationHandlerCount, org.apache.hadoop.hbase.ipc.PriorityFunction priority, int highPriorityLevel)
     
  • Uses of org.apache.hadoop.hbase.ipc.PriorityFunction in org.apache.hadoop.hbase.master

    Classes in org.apache.hadoop.hbase.master that implement org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.master.MasterAnnotationReadingPriorityFunction
    Priority function specifically for the master.
    class 
    org.apache.hadoop.hbase.master.MasterRpcServices
    Implements the master RPC services.
    Methods in org.apache.hadoop.hbase.master that return org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.ipc.PriorityFunction
    MasterRpcServices.createPriority()
     
  • Uses of org.apache.hadoop.hbase.ipc.PriorityFunction in org.apache.hadoop.hbase.regionserver

    Classes in org.apache.hadoop.hbase.regionserver that implement org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier and Type
    Class
    Description
    class 
    org.apache.hadoop.hbase.regionserver.AnnotationReadingPriorityFunction
    Reads special method annotations and table names to figure a priority for use by QoS facility in ipc; e.g: rpcs to hbase:meta get priority.
    class 
    org.apache.hadoop.hbase.regionserver.RSRpcServices
    Implements the regionserver RPC services.
    Methods in org.apache.hadoop.hbase.regionserver that return org.apache.hadoop.hbase.ipc.PriorityFunction in in
    Modifier and Type
    Method
    Description
    protected org.apache.hadoop.hbase.ipc.PriorityFunction
    RSRpcServices.createPriority()
     
    org.apache.hadoop.hbase.ipc.PriorityFunction
    RSRpcServices.getPriority()
     
    Methods in org.apache.hadoop.hbase.regionserver with parameters of type org.apache.hadoop.hbase.ipc.PriorityFunction 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)