类 DirectProxyHandler.ProxyBackendHandler

java.lang.Object
io.netty.channel.ChannelHandlerAdapter
io.netty.channel.ChannelInboundHandlerAdapter
org.apache.pulsar.common.protocol.PulsarDecoder
org.apache.pulsar.proxy.server.DirectProxyHandler.ProxyBackendHandler
所有已实现的接口:
io.netty.channel.ChannelHandler, io.netty.channel.ChannelInboundHandler
封闭类:
DirectProxyHandler

public class DirectProxyHandler.ProxyBackendHandler extends org.apache.pulsar.common.protocol.PulsarDecoder
  • 嵌套类概要

    从接口继承的嵌套类/接口 io.netty.channel.ChannelHandler

    io.netty.channel.ChannelHandler.Sharable
  • 字段概要

    字段
    修饰符和类型
    字段
    说明
    protected io.netty.channel.ChannelHandlerContext
     

    从类继承的字段 org.apache.pulsar.common.protocol.PulsarDecoder

    proxyMessage
  • 构造器概要

    构造器
    构造器
    说明
    ProxyBackendHandler(ProxyConfiguration config, int protocolVersion, String remoteHostName)
     
  • 方法概要

    修饰符和类型
    方法
    说明
    void
    channelActive(io.netty.channel.ChannelHandlerContext ctx)
     
    void
    channelInactive(io.netty.channel.ChannelHandlerContext ctx)
     
    void
    channelRead(io.netty.channel.ChannelHandlerContext ctx, Object msg)
     
    void
    channelWritabilityChanged(io.netty.channel.ChannelHandlerContext ctx)
     
    void
    exceptionCaught(io.netty.channel.ChannelHandlerContext ctx, 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
     

    从类继承的方法 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

    从类继承的方法 io.netty.channel.ChannelInboundHandlerAdapter

    channelReadComplete, channelRegistered, channelUnregistered, userEventTriggered

    从类继承的方法 io.netty.channel.ChannelHandlerAdapter

    ensureNotSharable, handlerAdded, handlerRemoved, isSharable

    从类继承的方法 java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    从接口继承的方法 io.netty.channel.ChannelHandler

    handlerAdded, handlerRemoved
  • 字段详细资料

    • ctx

      protected io.netty.channel.ChannelHandlerContext ctx
  • 构造器详细资料

    • ProxyBackendHandler

      public ProxyBackendHandler(ProxyConfiguration config, int protocolVersion, String remoteHostName)
  • 方法详细资料

    • channelActive

      public void channelActive(io.netty.channel.ChannelHandlerContext ctx) throws Exception
      指定者:
      channelActive 在接口中 io.netty.channel.ChannelInboundHandler
      覆盖:
      channelActive 在类中 io.netty.channel.ChannelInboundHandlerAdapter
      抛出:
      Exception
    • channelWritabilityChanged

      public void channelWritabilityChanged(io.netty.channel.ChannelHandlerContext ctx) throws Exception
      指定者:
      channelWritabilityChanged 在接口中 io.netty.channel.ChannelInboundHandler
      覆盖:
      channelWritabilityChanged 在类中 io.netty.channel.ChannelInboundHandlerAdapter
      抛出:
      Exception
    • channelRead

      public void channelRead(io.netty.channel.ChannelHandlerContext ctx, Object msg) throws Exception
      指定者:
      channelRead 在接口中 io.netty.channel.ChannelInboundHandler
      覆盖:
      channelRead 在类中 org.apache.pulsar.common.protocol.PulsarDecoder
      抛出:
      Exception
    • handleAuthChallenge

      protected void handleAuthChallenge(org.apache.pulsar.common.api.proto.CommandAuthChallenge authChallenge)
      覆盖:
      handleAuthChallenge 在类中 org.apache.pulsar.common.protocol.PulsarDecoder
    • messageReceived

      protected void messageReceived()
      指定者:
      messageReceived 在类中 org.apache.pulsar.common.protocol.PulsarDecoder
    • handleConnected

      protected void handleConnected(org.apache.pulsar.common.api.proto.CommandConnected connected)
      覆盖:
      handleConnected 在类中 org.apache.pulsar.common.protocol.PulsarDecoder
    • channelInactive

      public void channelInactive(io.netty.channel.ChannelHandlerContext ctx)
      指定者:
      channelInactive 在接口中 io.netty.channel.ChannelInboundHandler
      覆盖:
      channelInactive 在类中 io.netty.channel.ChannelInboundHandlerAdapter
    • exceptionCaught

      public void exceptionCaught(io.netty.channel.ChannelHandlerContext ctx, Throwable cause)
      指定者:
      exceptionCaught 在接口中 io.netty.channel.ChannelHandler
      指定者:
      exceptionCaught 在接口中 io.netty.channel.ChannelInboundHandler
      覆盖:
      exceptionCaught 在类中 io.netty.channel.ChannelInboundHandlerAdapter