Class DirectProxyHandler.ProxyBackendHandler

  • All Implemented Interfaces:
    io.netty.channel.ChannelHandler, io.netty.channel.ChannelInboundHandler
    Enclosing class:
    DirectProxyHandler

    public class DirectProxyHandler.ProxyBackendHandler
    extends org.apache.pulsar.common.protocol.PulsarDecoder
    • Nested Class Summary

      • Nested classes/interfaces inherited from interface io.netty.channel.ChannelHandler

        io.netty.channel.ChannelHandler.Sharable
    • Field Summary

      Fields 
      Modifier and Type Field Description
      protected io.netty.channel.ChannelHandlerContext ctx  
      • Fields inherited from class org.apache.pulsar.common.protocol.PulsarDecoder

        proxyMessage
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      void channelActive​(io.netty.channel.ChannelHandlerContext ctx)  
      void channelInactive​(io.netty.channel.ChannelHandlerContext ctx)  
      void channelRead​(io.netty.channel.ChannelHandlerContext ctx, java.lang.Object msg)  
      void channelWritabilityChanged​(io.netty.channel.ChannelHandlerContext ctx)  
      void exceptionCaught​(io.netty.channel.ChannelHandlerContext ctx, java.lang.Throwable cause)  
      protected void handleAuthChallenge​(org.apache.pulsar.common.api.proto.CommandAuthChallenge authChallenge)  
      protected void handleConnected​(org.apache.pulsar.common.api.proto.CommandConnected connected)  
      protected void messageReceived()  
      • Methods inherited from class org.apache.pulsar.common.protocol.PulsarDecoder

        handleAck, handleAckResponse, handleActiveConsumerChange, handleAddPartitionToTxn, handleAddPartitionToTxnResponse, handleAddSubscriptionToTxn, handleAddSubscriptionToTxnResponse, handleAuthResponse, handleCloseConsumer, handleCloseProducer, handleConnect, handleConsumerStats, handleConsumerStatsResponse, handleEndTxn, handleEndTxnOnPartition, handleEndTxnOnPartitionResponse, handleEndTxnOnSubscription, handleEndTxnOnSubscriptionResponse, handleEndTxnResponse, handleError, handleFlow, handleGetLastMessageId, handleGetLastMessageIdSuccess, handleGetOrCreateSchema, handleGetOrCreateSchemaResponse, handleGetSchema, handleGetSchemaResponse, handleGetTopicsOfNamespace, handleGetTopicsOfNamespaceSuccess, handleLookup, handleLookupResponse, handleMessage, handleNewTxn, handleNewTxnResponse, handlePartitionMetadataRequest, handlePartitionResponse, handlePing, handlePong, handleProducer, handleProducerSuccess, handleReachedEndOfTopic, handleRedeliverUnacknowledged, handleSeek, handleSend, handleSendError, handleSendReceipt, handleSubscribe, handleSuccess, handleTcClientConnectRequest, handleTcClientConnectResponse, handleUnsubscribe, interceptCommand
      • Methods inherited from class io.netty.channel.ChannelInboundHandlerAdapter

        channelReadComplete, channelRegistered, channelUnregistered, userEventTriggered
      • Methods inherited from class io.netty.channel.ChannelHandlerAdapter

        ensureNotSharable, handlerAdded, handlerRemoved, isSharable
      • Methods inherited from class java.lang.Object

        clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
      • Methods inherited from interface io.netty.channel.ChannelHandler

        handlerAdded, handlerRemoved
    • Field Detail

      • ctx

        protected io.netty.channel.ChannelHandlerContext ctx
    • Constructor Detail

      • ProxyBackendHandler

        public ProxyBackendHandler​(ProxyConfiguration config,
                                   int protocolVersion,
                                   java.lang.String remoteHostName)
    • Method Detail

      • channelActive

        public void channelActive​(io.netty.channel.ChannelHandlerContext ctx)
                           throws java.lang.Exception
        Specified by:
        channelActive in interface io.netty.channel.ChannelInboundHandler
        Overrides:
        channelActive in class io.netty.channel.ChannelInboundHandlerAdapter
        Throws:
        java.lang.Exception
      • channelWritabilityChanged

        public void channelWritabilityChanged​(io.netty.channel.ChannelHandlerContext ctx)
                                       throws java.lang.Exception
        Specified by:
        channelWritabilityChanged in interface io.netty.channel.ChannelInboundHandler
        Overrides:
        channelWritabilityChanged in class io.netty.channel.ChannelInboundHandlerAdapter
        Throws:
        java.lang.Exception
      • channelRead

        public void channelRead​(io.netty.channel.ChannelHandlerContext ctx,
                                java.lang.Object msg)
                         throws java.lang.Exception
        Specified by:
        channelRead in interface io.netty.channel.ChannelInboundHandler
        Overrides:
        channelRead in class org.apache.pulsar.common.protocol.PulsarDecoder
        Throws:
        java.lang.Exception
      • handleAuthChallenge

        protected void handleAuthChallenge​(org.apache.pulsar.common.api.proto.CommandAuthChallenge authChallenge)
        Overrides:
        handleAuthChallenge in class org.apache.pulsar.common.protocol.PulsarDecoder
      • messageReceived

        protected void messageReceived()
        Specified by:
        messageReceived in class org.apache.pulsar.common.protocol.PulsarDecoder
      • handleConnected

        protected void handleConnected​(org.apache.pulsar.common.api.proto.CommandConnected connected)
        Overrides:
        handleConnected in class org.apache.pulsar.common.protocol.PulsarDecoder
      • channelInactive

        public void channelInactive​(io.netty.channel.ChannelHandlerContext ctx)
        Specified by:
        channelInactive in interface io.netty.channel.ChannelInboundHandler
        Overrides:
        channelInactive in class io.netty.channel.ChannelInboundHandlerAdapter
      • exceptionCaught

        public void exceptionCaught​(io.netty.channel.ChannelHandlerContext ctx,
                                    java.lang.Throwable cause)
        Specified by:
        exceptionCaught in interface io.netty.channel.ChannelHandler
        Specified by:
        exceptionCaught in interface io.netty.channel.ChannelInboundHandler
        Overrides:
        exceptionCaught in class io.netty.channel.ChannelInboundHandlerAdapter