You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@rocketmq.apache.org by GitBox <gi...@apache.org> on 2020/12/02 03:13:17 UTC

[GitHub] [rocketmq] BootsShu opened a new issue #2470: 偶尔出现 “集群所有地址连接失败”

BootsShu opened a new issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470


   环境:
     1、centos7.4
     2、foxiswho/rocketmq:server 
     3、foxiswho/rocketmq:broker
   
   ![image](https://user-images.githubusercontent.com/31271052/100823536-5969b680-348f-11eb-90f8-cf13cfec27e0.png)
   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] wuguanyu commented on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
wuguanyu commented on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-981573988


   java.lang.IllegalStateException: org.apache.rocketmq.remoting.exception.RemotingSendRequestException: send request to <XXXXX> failed
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:679)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:509)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:358)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance$3.run(MQClientInstance.java:275)
       at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515)
       at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305)
       at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305)
       at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128)
       at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628)
       at java.lang.Thread.run(Thread.java:834)
   org.apache.rocketmq.remoting.exception.RemotingSendRequestException: send request to <ocketmq-v2-namesrv-0.rocketmq-v2-namesrv-headless.infra.svc/10.28.69.222:9876> failed
       at org.apache.rocketmq.remoting.netty.NettyRemotingAbstract.invokeSyncImpl(NettyRemotingAbstract.java:439)
       at org.apache.rocketmq.remoting.netty.NettyRemotingClient.invokeSync(NettyRemotingClient.java:377)
       at org.apache.rocketmq.client.impl.MQClientAPIImpl.getTopicRouteInfoFromNameServer(MQClientAPIImpl.java:1363)
       at org.apache.rocketmq.client.impl.MQClientAPIImpl.getTopicRouteInfoFromNameServer(MQClientAPIImpl.java:1353)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:622)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:509)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:358)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance$3.run(MQClientInstance.java:275)
       at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515)
       at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305)
       at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305)
       at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128)
       at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628)
       at java.lang.Thread.run(Thread.java:834)
   java.nio.channels.ClosedChannelException: null
       at io.netty.channel.AbstractChannel$AbstractUnsafe.newClosedChannelException(AbstractChannel.java:957)
       at io.netty.channel.AbstractChannel$AbstractUnsafe.write(AbstractChannel.java:865)
       at io.netty.channel.DefaultChannelPipeline$HeadContext.write(DefaultChannelPipeline.java:1367)
       at io.netty.channel.AbstractChannelHandlerContext.invokeWrite0(AbstractChannelHandlerContext.java:715)
       at io.netty.channel.AbstractChannelHandlerContext.invokeWrite(AbstractChannelHandlerContext.java:707)
       at io.netty.channel.AbstractChannelHandlerContext$WriteTask.run(AbstractChannelHandlerContext.java:1087)
       at io.netty.util.concurrent.AbstractEventExecutor.safeExecute(AbstractEventExecutor.java:164)
       at io.netty.util.concurrent.SingleThreadEventExecutor.runAllTasks(SingleThreadEventExecutor.java:472)
       at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:500)
       at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:989)
       at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
       at java.lang.Thread.run(Thread.java:834)
   
   version 4.7.1


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: dev-unsubscribe@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] duhenglucky closed issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
duhenglucky closed issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470


   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] BootsShu edited a comment on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
BootsShu edited a comment on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-737071879


   查阅RocketMQ日志,发现有一个错误信息,如下所示:
   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]
   
   
   有熟悉RocketMQ的小伙伴麻烦不吝赐教   感谢感谢!!!


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] BootsShu removed a comment on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
BootsShu removed a comment on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-737071879


   查阅RocketMQ日志,发现有一个错误信息,如下所示:
   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]
   
   
   有熟悉RocketMQ的小伙伴麻烦不吝赐教   感谢感谢!!!


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] wuguanyu edited a comment on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
wuguanyu edited a comment on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-981573988


   java.lang.IllegalStateException: org.apache.rocketmq.remoting.exception.RemotingSendRequestException: send request to <XXXXX> failed
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:679)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:509)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:358)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance$3.run(MQClientInstance.java:275)
       at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515)
       at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305)
       at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305)
       at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128)
       at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628)
       at java.lang.Thread.run(Thread.java:834)
   org.apache.rocketmq.remoting.exception.RemotingSendRequestException: send request to <xxxxxxx> failed
       at org.apache.rocketmq.remoting.netty.NettyRemotingAbstract.invokeSyncImpl(NettyRemotingAbstract.java:439)
       at org.apache.rocketmq.remoting.netty.NettyRemotingClient.invokeSync(NettyRemotingClient.java:377)
       at org.apache.rocketmq.client.impl.MQClientAPIImpl.getTopicRouteInfoFromNameServer(MQClientAPIImpl.java:1363)
       at org.apache.rocketmq.client.impl.MQClientAPIImpl.getTopicRouteInfoFromNameServer(MQClientAPIImpl.java:1353)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:622)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:509)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance.updateTopicRouteInfoFromNameServer(MQClientInstance.java:358)
       at org.apache.rocketmq.client.impl.factory.MQClientInstance$3.run(MQClientInstance.java:275)
       at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:515)
       at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:305)
       at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:305)
       at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1128)
       at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:628)
       at java.lang.Thread.run(Thread.java:834)
   java.nio.channels.ClosedChannelException: null
       at io.netty.channel.AbstractChannel$AbstractUnsafe.newClosedChannelException(AbstractChannel.java:957)
       at io.netty.channel.AbstractChannel$AbstractUnsafe.write(AbstractChannel.java:865)
       at io.netty.channel.DefaultChannelPipeline$HeadContext.write(DefaultChannelPipeline.java:1367)
       at io.netty.channel.AbstractChannelHandlerContext.invokeWrite0(AbstractChannelHandlerContext.java:715)
       at io.netty.channel.AbstractChannelHandlerContext.invokeWrite(AbstractChannelHandlerContext.java:707)
       at io.netty.channel.AbstractChannelHandlerContext$WriteTask.run(AbstractChannelHandlerContext.java:1087)
       at io.netty.util.concurrent.AbstractEventExecutor.safeExecute(AbstractEventExecutor.java:164)
       at io.netty.util.concurrent.SingleThreadEventExecutor.runAllTasks(SingleThreadEventExecutor.java:472)
       at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:500)
       at io.netty.util.concurrent.SingleThreadEventExecutor$4.run(SingleThreadEventExecutor.java:989)
       at io.netty.util.internal.ThreadExecutorMap$2.run(ThreadExecutorMap.java:74)
       at java.lang.Thread.run(Thread.java:834)
   
   version 4.7.1


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: dev-unsubscribe@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] maywe commented on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
maywe commented on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-1046515378


   大佬,这是怎么解决的,我也遇到了这种问题,让运维排查网络也没有啥问题,没有头绪。。请大佬指导下
   
   
   org.apache.rocketmq.remoting.exception.RemotingSendRequestException: send request to <XX.XX.XX.XX:10909> failed
   	at org.apache.rocketmq.remoting.netty.NettyRemotingAbstract.invokeSyncImpl(NettyRemotingAbstract.java:389)
   	at org.apache.rocketmq.remoting.netty.NettyRemotingClient.invokeSync(NettyRemotingClient.java:369)
   	at org.apache.rocketmq.client.impl.MQClientAPIImpl.sendMessageSync(MQClientAPIImpl.java:351)
   	at org.apache.rocketmq.client.impl.MQClientAPIImpl.sendMessage(MQClientAPIImpl.java:335)
   	at org.apache.rocketmq.client.impl.MQClientAPIImpl.sendMessage(MQClientAPIImpl.java:298)
   	at org.apache.rocketmq.client.impl.producer.DefaultMQProducerImpl.sendKernelImpl(DefaultMQProducerImpl.java:696)
   	at org.apache.rocketmq.client.impl.producer.DefaultMQProducerImpl.sendSelectImpl(DefaultMQProducerImpl.java:914)
   	at org.apache.rocketmq.client.impl.producer.DefaultMQProducerImpl.send(DefaultMQProducerImpl.java:891)
   	at org.apache.rocketmq.client.impl.producer.DefaultMQProducerImpl.send(DefaultMQProducerImpl.java:886)
   	at org.apache.rocketmq.client.producer.DefaultMQProducer.send(DefaultMQProducer.java:389)


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: dev-unsubscribe@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] BootsShu commented on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
BootsShu commented on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-738495202


   > @BootsShu 仅仅偶尔是 Connection reset by peer 是正常的,上面的那个报错请问是哪里的?具体的要看下客户端的日志,在~/logs/rocketmq_client.log 里面,欢迎在[邮件列表](https://rocketmq.apache.org/about/contact/)里面讨论,这样可以沉淀下来:)
   
   
   目前使用RocketMQ,频繁出现“集群所有地址连接失败”,排查RocketMQ日志,有很多频繁出现的ErrorMsg:
   
   
   broker.log 几分钟出现一次,头疼:
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - processRequestWrapper response to /120.76.102.210:54412 failed
   java.nio.channels.ClosedChannelException: null
   	at io.netty.channel.AbstractChannel$AbstractUnsafe.write(...)(Unknown Source) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=11, language=CPP, version=275, opaque=4255146, flag(B)=0, remark=PULL_MESSAGE, extFields={queueId=5, maxMsgNums=32, suspendTimeoutMillis=15000, sysFlag=6, commitOffset=95, topic=GlobalPurchase_Common_Log_Service_Topic, queueOffset=95, subscription=*, subVersion=1606773467287, consumerGroup=GlobalPurchase_Common_Log_Service_Group}, serializeTypeCurrentRPC=JSON]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=19, language=JAVA, version=317, opaque=4255146, flag(B)=1, remark=OFFSET_OVERFLOW_ONE, extFields=null, serializeTypeCurrentRPC=JSON]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - processRequestWrapper response to /120.76.102.210:54412 failed
   java.nio.channels.ClosedChannelException: null
   	at io.netty.channel.AbstractChannel$AbstractUnsafe.write(...)(Unknown Source) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=11, language=CPP, version=275, opaque=4255144, flag(B)=0, remark=PULL_MESSAGE, extFields={queueId=6, maxMsgNums=32, suspendTimeoutMillis=15000, sysFlag=6, commitOffset=91, topic=GlobalPurchase_Common_Log_Service_Topic, queueOffset=91, subscription=*, subVersion=1606773467287, consumerGroup=GlobalPurchase_Common_Log_Service_Group}, serializeTypeCurrentRPC=JSON]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=19, language=JAVA, version=317, opaque=4255144, flag(B)=1, remark=OFFSET_OVERFLOW_ONE, extFields=null, serializeTypeCurrentRPC=JSON]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - processRequestWrapper response to /120.76.102.210:54412 failed
   java.nio.channels.ClosedChannelException: null
   	at io.netty.channel.AbstractChannel$AbstractUnsafe.write(...)(Unknown Source) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=11, language=CPP, version=275, opaque=4255145, flag(B)=0, remark=PULL_MESSAGE, extFields={queueId=7, maxMsgNums=32, suspendTimeoutMillis=15000, sysFlag=6, commitOffset=91, topic=GlobalPurchase_Common_Log_Service_Topic, queueOffset=91, subscription=*, subVersion=1606773467287, consumerGroup=GlobalPurchase_Common_Log_Service_Group}, serializeTypeCurrentRPC=JSON]
   2020-12-03 03:36:40 ERROR NettyServerNIOSelector_3_1 - RemotingCommand [code=19, language=JAVA, version=317, opaque=4255145, flag(B)=1, remark=OFFSET_OVERFLOW_ONE, extFields=null, serializeTypeCurrentRPC=JSON]
   
   
   
   namesrv.log 几分钟出现一次,头疼:
   2020-11-30 23:11:18 WARN NettyServerCodecThread_8 - NETTY SERVER PIPELINE: exceptionCaught exception.
   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]
   2020-11-30 23:11:18 INFO NettyServerCodecThread_8 - NETTY SERVER PIPELINE: channelInactive, the channel[180.102.120.14:31539]
   2020-11-30 23:11:18 INFO NettyServerCodecThread_8 - NETTY SERVER PIPELINE: channelUnregistered, the channel[180.102.120.14:31539]
   2020-11-30 23:11:18 INFO NettyServerNIOSelector_3_1 - closeChannel: close the connection to remote address[180.102.120.14:31539] result: true
   2020-11-30 23:11:18 WARN NettyServerCodecThread_7 - NETTY SERVER PIPELINE: exceptionCaught 180.102.120.14:31538
   2020-11-30 23:11:18 WARN NettyServerCodecThread_7 - NETTY SERVER PIPELINE: exceptionCaught exception.
   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]
   2020-11-30 23:11:18 INFO NettyServerCodecThread_7 - NETTY SERVER PIPELINE: channelInactive, the channel[180.102.120.14:31538]
   2020-11-30 23:11:18 INFO NettyServerCodecThread_7 - NETTY SERVER PIPELINE: channelUnregistered, the channel[180.102.120.14:31538]
   2020-11-30 23:11:18 INFO NettyServerNIOSelector_3_3 - closeChannel: close the connection to remote address[180.102.120.14:31538] result: true
   2020-11-30 23:11:18 WARN NettyServerCodecThread_1 - NETTY SERVER PIPELINE: exceptionCaught 180.102.120.14:31541
   2020-11-30 23:11:18 WARN NettyServerCodecThread_1 - NETTY SERVER PIPELINE: exceptionCaught exception.
   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]
   
   
   请问该类RocketMQ问题应该如何解决呢?
   
   


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] duhenglucky commented on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
duhenglucky commented on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-738483179


   @BootsShu 仅仅偶尔是 Connection reset by peer 是正常的,上面的那个报错请问是哪里的?具体的要看下客户端的日志,在~/logs/rocketmq_client.log 里面,欢迎在[邮件列表](https://rocketmq.apache.org/about/contact/)里面讨论,这样可以沉淀下来:)


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [rocketmq] BootsShu commented on issue #2470: 偶尔出现 “集群所有地址连接失败”

Posted by GitBox <gi...@apache.org>.
BootsShu commented on issue #2470:
URL: https://github.com/apache/rocketmq/issues/2470#issuecomment-737071879


   java.io.IOException: Connection reset by peer
   	at sun.nio.ch.FileDispatcherImpl.read0(Native Method) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketDispatcher.read(SocketDispatcher.java:39) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.readIntoNativeBuffer(IOUtil.java:223) ~[na:1.8.0_222]
   	at sun.nio.ch.IOUtil.read(IOUtil.java:192) ~[na:1.8.0_222]
   	at sun.nio.ch.SocketChannelImpl.read(SocketChannelImpl.java:380) ~[na:1.8.0_222]
   	at io.netty.buffer.PooledUnsafeDirectByteBuf.setBytes(PooledUnsafeDirectByteBuf.java:221) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.buffer.AbstractByteBuf.writeBytes(AbstractByteBuf.java:899) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.socket.nio.NioSocketChannel.doReadBytes(NioSocketChannel.java:275) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.AbstractNioByteChannel$NioByteUnsafe.read(AbstractNioByteChannel.java:119) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKey(NioEventLoop.java:652) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeysOptimized(NioEventLoop.java:575) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.processSelectedKeys(NioEventLoop.java:489) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.channel.nio.NioEventLoop.run(NioEventLoop.java:451) ~[netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at io.netty.util.concurrent.SingleThreadEventExecutor$2.run(SingleThreadEventExecutor.java:140) [netty-all-4.0.42.Final.jar:4.0.42.Final]
   	at java.lang.Thread.run(Thread.java:748) [na:1.8.0_222]


----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

For queries about this service, please contact Infrastructure at:
users@infra.apache.org