Class AbstractTestIPC.FailingSimpleRpcServer.FailingConnection

java.lang.Object
org.apache.hadoop.hbase.ipc.AbstractTestIPC.FailingSimpleRpcServer.FailingConnection
All Implemented Interfaces:
Closeable, AutoCloseable
Enclosing class:
AbstractTestIPC.FailingSimpleRpcServer

  • Field Details

    • channel

      final SocketChannel channel
      Deprecated.
    • responder

      final org.apache.hadoop.hbase.ipc.SimpleRpcServerResponder responder
      Deprecated.
    • useWrap

      boolean useWrap
      Deprecated.
    • responseQueue

      final ConcurrentLinkedDeque<org.apache.hadoop.hbase.ipc.RpcResponse> responseQueue
      Deprecated.
    • responseWriteLock

      final Lock responseWriteLock
      Deprecated.
    • lastSentTime

      long lastSentTime
      Deprecated.
    • rpcServer

      protected final org.apache.hadoop.hbase.ipc.RpcServer rpcServer
    • connectionHeaderRead

      protected boolean connectionHeaderRead
    • callCleanup

      protected org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup callCleanup
    • hostAddress

      protected String hostAddress
    • remotePort

      protected int remotePort
    • addr

      protected InetAddress addr
    • connectionHeader

      protected org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.ConnectionHeader connectionHeader
    • connectionAttributes

      protected Map<String,byte[]> connectionAttributes
    • codec

      protected org.apache.hadoop.hbase.codec.Codec codec
    • compressionCodec

      protected org.apache.hadoop.io.compress.CompressionCodec compressionCodec
    • service

      protected org.apache.hbase.thirdparty.com.google.protobuf.BlockingService service
    • provider

      protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProvider provider
    • skipInitialSaslHandshake

      protected boolean skipInitialSaslHandshake
    • useSasl

      protected boolean useSasl
    • saslServer

      protected org.apache.hadoop.hbase.security.HBaseSaslRpcServer saslServer
    • authenticatedWithFallback

      protected boolean authenticatedWithFallback
    • retryImmediatelySupported

      protected boolean retryImmediatelySupported
    • user

      protected org.apache.hadoop.hbase.security.User user
    • ugi

      protected org.apache.hadoop.security.UserGroupInformation ugi
    • saslProviders

      protected org.apache.hadoop.hbase.security.provider.SaslServerAuthenticationProviders saslProviders
    • clientCertificateChain

      protected X509Certificate[] clientCertificateChain
  • Constructor Details

  • Method Details

    • processRequest

      public void processRequest(org.apache.hadoop.hbase.nio.ByteBuff buf) throws IOException, InterruptedException
      Throws:
      IOException
      InterruptedException
    • setLastContact

      public void setLastContact(long arg0)
      Deprecated.
    • getLastContact

      public long getLastContact()
      Deprecated.
    • isIdle

      boolean isIdle()
      Deprecated.
    • decRpcCount

      protected void decRpcCount()
      Deprecated.
    • incRpcCount

      protected void incRpcCount()
      Deprecated.
    • readAndProcess

      public int readAndProcess() throws IOException, InterruptedException
      Deprecated.
      Throws:
      IOException
      InterruptedException
    • channelDataRead

      protected int channelDataRead(ReadableByteChannel arg0, org.apache.hadoop.hbase.nio.ByteBuff arg1) throws IOException
      Deprecated.
      Throws:
      IOException
    • close

      public void close()
      Deprecated.
    • isConnectionOpen

      public boolean isConnectionOpen()
      Deprecated.
    • createCall

      public org.apache.hadoop.hbase.ipc.SimpleServerCall createCall(int arg0, org.apache.hbase.thirdparty.com.google.protobuf.BlockingService arg1, org.apache.hbase.thirdparty.com.google.protobuf.Descriptors.MethodDescriptor arg2, org.apache.hadoop.hbase.shaded.protobuf.generated.RPCProtos.RequestHeader arg3, org.apache.hbase.thirdparty.com.google.protobuf.Message arg4, org.apache.hadoop.hbase.CellScanner arg5, long arg6, InetAddress arg7, int arg8, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9)
      Deprecated.
    • doRespond

      protected void doRespond(org.apache.hadoop.hbase.ipc.RpcResponse arg0) throws IOException
      Deprecated.
      Throws:
      IOException
    • toString

      public String toString()
      Overrides:
      toString in class Object
    • getHostAddress

      public String getHostAddress()
    • getHostInetAddress

      public InetAddress getHostInetAddress()
    • getRemotePort

      public int getRemotePort()
    • getVersionInfo

      public org.apache.hadoop.hbase.shaded.protobuf.generated.HBaseProtos.VersionInfo getVersionInfo()
    • disposeSasl

      protected final void disposeSasl()
    • doRawSaslReply

      protected final void doRawSaslReply(org.apache.hadoop.hbase.security.SaslStatus arg0, org.apache.hadoop.io.Writable arg1, String arg2, String arg3) throws IOException
      Throws:
      IOException
    • getOrCreateSaslServer

      org.apache.hadoop.hbase.security.HBaseSaslRpcServer getOrCreateSaslServer() throws IOException
      Throws:
      IOException
    • finishSaslNegotiation

      void finishSaslNegotiation() throws IOException
      Throws:
      IOException
    • processOneRpc

      public void processOneRpc(org.apache.hadoop.hbase.nio.ByteBuff arg0) throws IOException, InterruptedException
      Throws:
      IOException
      InterruptedException
    • getErrorResponse

      protected final org.apache.hadoop.hbase.ipc.RpcResponse getErrorResponse(String arg0, Exception arg1) throws IOException
      Throws:
      IOException
    • callCleanupIfNeeded

      protected final void callCleanupIfNeeded()
    • processPreamble

      protected final org.apache.hadoop.hbase.ipc.ServerRpcConnection.PreambleResponse processPreamble(ByteBuffer arg0) throws IOException
      Throws:
      IOException
    • isSimpleAuthentication

      boolean isSimpleAuthentication()