Class FailingNettyRpcServer.FailingConnection

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

  • Field Details

    • channel

      final org.apache.hbase.thirdparty.io.netty.channel.Channel channel
    • 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
    • setupHandler

      void setupHandler()
    • process

      void process(org.apache.hbase.thirdparty.io.netty.buffer.ByteBuf arg0) throws IOException, InterruptedException
      Throws:
      IOException
      InterruptedException
    • close

      public void close()
    • isConnectionOpen

      public boolean isConnectionOpen()
    • createCall

      public org.apache.hadoop.hbase.ipc.NettyServerCall 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.ExtendedCellScanner arg5, long arg6, InetAddress arg7, int arg8, org.apache.hadoop.hbase.ipc.RpcServer.CallCleanup arg9)
    • doRespond

      protected void doRespond(org.apache.hadoop.hbase.ipc.RpcResponse arg0)
    • 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()