Class SyncCoprocessorRpcChannel

java.lang.Object
org.apache.hadoop.hbase.client.SyncCoprocessorRpcChannel
All Implemented Interfaces:
CoprocessorRpcChannel, org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel, org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel

@Deprecated @Public abstract class SyncCoprocessorRpcChannel extends Object implements CoprocessorRpcChannel
Deprecated.
Please stop using this class again, as it is too low level, which is part of the rpc framework for HBase. Will be deleted in 4.0.0.
Base class which provides clients with an RPC connection to call coprocessor endpoint Services. Note that clients should not use this class directly, except through Table.coprocessorService(byte[]).
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    private static final org.slf4j.Logger
    Deprecated.
     
  • Constructor Summary

    Constructors
    Constructor
    Description
    Deprecated.
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.hbase.thirdparty.com.google.protobuf.Message
    callBlockingMethod(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype)
    Deprecated.
     
    protected abstract org.apache.hbase.thirdparty.com.google.protobuf.Message
    callExecService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype)
    Deprecated.
     
    void
    callMethod(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback)
    Deprecated.
     

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Field Details

    • LOG

      private static final org.slf4j.Logger LOG
      Deprecated.
  • Constructor Details

  • Method Details

    • callMethod

      @Private public void callMethod(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype, org.apache.hbase.thirdparty.com.google.protobuf.RpcCallback<org.apache.hbase.thirdparty.com.google.protobuf.Message> callback)
      Deprecated.
      Specified by:
      callMethod in interface org.apache.hbase.thirdparty.com.google.protobuf.RpcChannel
    • callBlockingMethod

      @Private public org.apache.hbase.thirdparty.com.google.protobuf.Message callBlockingMethod(org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype) throws org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
      Deprecated.
      Specified by:
      callBlockingMethod in interface org.apache.hbase.thirdparty.com.google.protobuf.BlockingRpcChannel
      Throws:
      org.apache.hbase.thirdparty.com.google.protobuf.ServiceException
    • callExecService

      protected abstract org.apache.hbase.thirdparty.com.google.protobuf.Message callExecService(org.apache.hbase.thirdparty.com.google.protobuf.RpcController controller, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor method, org.apache.hbase.thirdparty.com.google.protobuf.Message request, org.apache.hbase.thirdparty.com.google.protobuf.Message responsePrototype) throws IOException
      Deprecated.
      Throws:
      IOException