Uploaded image for project: 'ActiveMQ Classic'
  1. ActiveMQ Classic
  2. AMQ-2730

Transport failed: java.io.EOFException

    XMLWordPrintableJSON

Details

    • Bug
    • Status: Closed
    • Major
    • Resolution: Not A Problem
    • 5.3.1
    • None
    • None
    • None
    • Red hat enterprise

    Description

      We see many Exceptions of this type in the broker logs:
      2010-05-12 14:10:03,490 | DEBUG | Transport failed: java.io.EOFException | org.apache.activemq.broker.TransportConnection.Transport | ActiveMQ Transport: tcp:///10.231.233.55:50809
      java.io.EOFException
      at java.io.DataInputStream.readInt(DataInputStream.java:375)
      at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:269)
      at org.apache.activemq.transport.tcp.TcpTransport.readCommand(TcpTransport.java:211)
      at org.apache.activemq.transport.tcp.TcpTransport.doRun(TcpTransport.java:203)
      at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:186)
      at java.lang.Thread.run(Thread.java:619)

      This exception occurs with a lot of clients that run on different machines.

      One case where we almost always see this exception is when shutting down a bridge. We did a tcp dump on the broker and on the client machine: there a no packets lost.

      LOG ON BRIDGE:
      2010-05-12 14:10:02,634 INFO org.apache.activemq.broker.BrokerService - ActiveMQ Message Broker (solr-2073bridge, ID:solr-2073-50804-
      1273665033782-0:0) is shutting down
      2010-05-12 14:10:02,799 INFO org.apache.activemq.network.jms.JmsConnector - JMS Connector Connector:0 Stopped
      2010-05-12 14:10:02,819 INFO org.apache.activemq.broker.BrokerService - ActiveMQ JMS Message Broker (solr-2073bridge, ID:solr-2073-50
      804-1273665033782-0:0) stopped

      LOG ON BROKER:
      2010-05-12 14:10:03,490 | DEBUG | Transport failed: java.io.EOFException | org.apache.activemq.broker.TransportConnection.Transport | ActiveMQ Transport: tcp:///10.231.233.55:50809
      java.io.EOFException
      at java.io.DataInputStream.readInt(DataInputStream.java:375)
      at org.apache.activemq.openwire.OpenWireFormat.unmarshal(OpenWireFormat.java:269)
      at org.apache.activemq.transport.tcp.TcpTransport.readCommand(TcpTransport.java:211)
      at org.apache.activemq.transport.tcp.TcpTransport.doRun(TcpTransport.java:203)
      at org.apache.activemq.transport.tcp.TcpTransport.run(TcpTransport.java:186)
      at java.lang.Thread.run(Thread.java:619)
      2010-05-12 14:10:03,492 | DEBUG | Stopping connection: /10.231.233.55:50809 | org.apache.activemq.broker.TransportConnection | ActiveMQ Task
      2010-05-12 14:10:03,492 | DEBUG | Stopping transport tcp:///10.231.233.55:50809 | org.apache.activemq.transport.tcp.TcpTransport | ActiveMQ Task
      2010-05-12 14:10:03,493 | DEBUG | Stopped transport: /10.231.233.55:50809 | org.apache.activemq.broker.TransportConnection | ActiveMQ Task
      2010-05-12 14:10:03,493 | DEBUG | Cleaning up connection resources: /10.231.233.55:50809 | org.apache.activemq.broker.TransportConnection | ActiveMQ Task
      2010-05-12 14:10:03,493 | DEBUG | remove connection id: ID:solr-2073-50804-1273665033782-2:0 | org.apache.activemq.broker.TransportConnection | ActiveMQ Task
      2010-05-12 14:10:03,493 | DEBUG | jms1 removing consumer: ID:solr-2073-50804-1273665033782-2:0:225:1 for destination: temp-queue://ID:solr-2073-50804-1273665033782-2:0:105 | org.apache.activemq.broker.region.AbstractRegion | ActiveMQ Task
      2010-05-12 14:10:03,493 | DEBUG | remove sub: QueueSubscription: consumer=ID:solr-2073-50804-1273665033782-2:0:225:1, destinations=1, dispatched=0, delivered=0, pending=0, lastDeliveredSeqId: 0, dequeues: 0, dispatched: 0, inflight: 0 | org.apache.activemq.broker.region.Queue | ActiveMQ Task

      Attachments

        1. TCP Dump.jpg
          606 kB
          Dennis Klinkott

        Issue Links

          Activity

            People

              Unassigned Unassigned
              jteetel Dennis Klinkott
              Votes:
              5 Vote for this issue
              Watchers:
              14 Start watching this issue

              Dates

                Created:
                Updated:
                Resolved: