Package org.apache.pulsar.proxy.server
Class 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
-
- All Implemented Interfaces:
io.netty.channel.ChannelHandler,io.netty.channel.ChannelInboundHandler,io.netty.util.concurrent.FutureListener<java.lang.Void>,io.netty.util.concurrent.GenericFutureListener<io.netty.util.concurrent.Future<java.lang.Void>>,java.util.EventListener
- Enclosing class:
- DirectProxyHandler
public class DirectProxyHandler.ProxyBackendHandler extends org.apache.pulsar.common.protocol.PulsarDecoder implements io.netty.util.concurrent.FutureListener<java.lang.Void>
-
-
Field Summary
Fields Modifier and Type Field Description protected io.netty.channel.ChannelHandlerContextctx
-
Constructor Summary
Constructors Constructor Description ProxyBackendHandler(ProxyConfiguration config, int protocolVersion)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidchannelActive(io.netty.channel.ChannelHandlerContext ctx)voidchannelInactive(io.netty.channel.ChannelHandlerContext ctx)voidchannelRead(io.netty.channel.ChannelHandlerContext ctx, java.lang.Object msg)voidexceptionCaught(io.netty.channel.ChannelHandlerContext ctx, java.lang.Throwable cause)protected voidhandleAuthChallenge(org.apache.pulsar.common.api.proto.CommandAuthChallenge authChallenge)protected voidhandleConnected(org.apache.pulsar.common.api.proto.CommandConnected connected)protected voidmessageReceived()voidoperationComplete(io.netty.util.concurrent.Future<java.lang.Void> future)voidsetRemoteHostName(java.lang.String remoteHostName)-
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, handleUnsubscribe, interceptCommand
-
Methods inherited from class io.netty.channel.ChannelInboundHandlerAdapter
channelReadComplete, channelRegistered, channelUnregistered, channelWritabilityChanged, userEventTriggered
-
Methods inherited from class io.netty.channel.ChannelHandlerAdapter
ensureNotSharable, handlerAdded, handlerRemoved, isSharable
-
-
-
-
Constructor Detail
-
ProxyBackendHandler
public ProxyBackendHandler(ProxyConfiguration config, int protocolVersion)
-
-
Method Detail
-
channelActive
public void channelActive(io.netty.channel.ChannelHandlerContext ctx) throws java.lang.Exception- Specified by:
channelActivein interfaceio.netty.channel.ChannelInboundHandler- Overrides:
channelActivein classio.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:
channelReadin interfaceio.netty.channel.ChannelInboundHandler- Overrides:
channelReadin classorg.apache.pulsar.common.protocol.PulsarDecoder- Throws:
java.lang.Exception
-
handleAuthChallenge
protected void handleAuthChallenge(org.apache.pulsar.common.api.proto.CommandAuthChallenge authChallenge)
- Overrides:
handleAuthChallengein classorg.apache.pulsar.common.protocol.PulsarDecoder
-
operationComplete
public void operationComplete(io.netty.util.concurrent.Future<java.lang.Void> future) throws java.lang.Exception- Specified by:
operationCompletein interfaceio.netty.util.concurrent.GenericFutureListener<io.netty.util.concurrent.Future<java.lang.Void>>- Throws:
java.lang.Exception
-
messageReceived
protected void messageReceived()
- Specified by:
messageReceivedin classorg.apache.pulsar.common.protocol.PulsarDecoder
-
handleConnected
protected void handleConnected(org.apache.pulsar.common.api.proto.CommandConnected connected)
- Overrides:
handleConnectedin classorg.apache.pulsar.common.protocol.PulsarDecoder
-
channelInactive
public void channelInactive(io.netty.channel.ChannelHandlerContext ctx)
- Specified by:
channelInactivein interfaceio.netty.channel.ChannelInboundHandler- Overrides:
channelInactivein classio.netty.channel.ChannelInboundHandlerAdapter
-
exceptionCaught
public void exceptionCaught(io.netty.channel.ChannelHandlerContext ctx, java.lang.Throwable cause)- Specified by:
exceptionCaughtin interfaceio.netty.channel.ChannelHandler- Specified by:
exceptionCaughtin interfaceio.netty.channel.ChannelInboundHandler- Overrides:
exceptionCaughtin classio.netty.channel.ChannelInboundHandlerAdapter
-
setRemoteHostName
public void setRemoteHostName(java.lang.String remoteHostName)
-
-