You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@activemq.apache.org by Adam Kaminiecki <ad...@dgt.com.pl> on 2011/01/20 20:07:58 UTC

Strange behavior

Hi all,

Happened to me a strange situation in which one of the clients received 
the 5 copies of the same message.
All logs are from the same machine.
Log from my application maybe will help:
Message sender:

Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515181:AMQ.INFO: BrokerUri set = 
tcp://localhost:61616
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515182:AMQ.INFO: Connecting to: 
tcp://localhost:61616/
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515184:AMQ.DEBUG: Opening socket 
to: localhost on port: 61616
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515185:AMQ.DEBUG: Connected to 
localhost:61616 using InterNetwork protocol.
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515194:AMQ.DEBUG: Creating 
Inactivity Monitor
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515303:AMQ.DEBUG: Inactivity: Read 
Check time interval: 30000
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515303:AMQ.DEBUG: Inactivity: 
Initial Delay time interval: 0
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515304:AMQ.DEBUG: Inactivity: Write 
Check time interval: 10000
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515305:AMQ.DEBUG: Message sent 
since last write check. Resetting flag
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515306:AMQ.DEBUG: A receive is in 
progress or already failed.
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515764:AMQ.DEBUG: MessageProducer 
created with a Window Size of: 1024000
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515773:AMQ.INFO: BrokerUri set = 
tcp://localhost:61616
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515773:AMQ.INFO: Connecting to: 
tcp://localhost:61616/
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515773:AMQ.DEBUG: Opening socket 
to: localhost on port: 61616
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515773:AMQ.DEBUG: Connected to 
localhost:61616 using InterNetwork protocol.
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515773:AMQ.DEBUG: Creating 
Inactivity Monitor
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515774:AMQ.DEBUG: Inactivity: Read 
Check time interval: 30000
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515774:AMQ.DEBUG: Inactivity: 
Initial Delay time interval: 0
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515775:AMQ.DEBUG: Inactivity: Write 
Check time interval: 10000
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515775:AMQ.DEBUG: Message sent 
since last write check. Resetting flag
Jan 19 17:45:15 127.0.0.1 [SUDWEB]: 4515775:AMQ.DEBUG: A receive is in 
progress or already failed.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516230:AMQ.DEBUG: MessageProducer 
created with a Window Size of: 1024000
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516246:AMQ.DEBUG: MemoryUsage: 
Increase Usage to: 2135 bytes.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: Object 
sent:SUDWebPingAliveRequest[ConsumerID=-112805952, Gateway=192.168.44.133]
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516249:AMQ.DEBUG: Closing down the 
Consumer
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516252:AMQ.DEBUG: Consumer instance 
Closed.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516253:AMQ.INFO: Closing Connection.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516254:AMQ.INFO: Asynchronously 
disposing of Connection.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516254:AMQ.INFO: Oneway command 
sent to broker.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516254:AMQ.INFO: Disposing of the 
Transport.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: BEFORE RECEIVE
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: AFTER RECEIVE
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516261:AMQ.DEBUG: Closing down the 
Consumer
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516262:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516262:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516262:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516262:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.DEBUG: Consumer instance 
Closed.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.ERROR: No such consumer 
active: ID:sud-37492-634310559151963650-1:1:1:1
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.INFO: Closing Connection.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.INFO: Asynchronously 
disposing of Connection.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.INFO: Oneway command 
sent to broker.
Jan 19 17:45:16 127.0.0.1 [SUDWEB]: 4516264:AMQ.INFO: Disposing of the 
Transport.


Message reciver:
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): New message 
received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): 
Aastra6739iContext(00-08-5D-13-E1-0B): new Task Added
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): New message 
received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): 
Aastra6739iContext(00-08-5D-13-E1-0B): new Task Added
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): New message 
received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): 
Aastra6739iContext(00-08-5D-13-E1-0B): new Task Added
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): New message 
received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): 
Aastra6739iContext(00-08-5D-13-E1-0B): new Task Added
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): New message 
received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ContextPoolManager  (32): 
Aastra6739iContext(00-08-5D-13-E1-0B): new Task Added
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New message 
received(ContextServiceRequest)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): Starting 
processing context Aastra6739iContext(00-08-5D-13-E1-0B)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New exclusive 
message received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): PingAlive 
package received from Aastra[00-08-5D-13-E1-0B] { RegisterState = 200 }
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): 
Aastra6739iContext.validateAastraXMLObject(AastraXMLIPPhoneExecute)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New exclusive 
message received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): PingAlive 
package received from Aastra[00-08-5D-13-E1-0B] { RegisterState = 200 }
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): 
Aastra6739iContext.validateAastraXMLObject(AastraXMLIPPhoneExecute)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New exclusive 
message received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): PingAlive 
package received from Aastra[00-08-5D-13-E1-0B] { RegisterState = 200 }
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): 
Aastra6739iContext.validateAastraXMLObject(AastraXMLIPPhoneExecute)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New exclusive 
message received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): PingAlive 
package received from Aastra[00-08-5D-13-E1-0B] { RegisterState = 200 }
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): 
Aastra6739iContext.validateAastraXMLObject(AastraXMLIPPhoneExecute)
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): New exclusive 
message received(SUDWebPingAliveRequest[ConsumerID=-112805952, 
Gateway=192.168.44.133])
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): PingAlive 
package received from Aastra[00-08-5D-13-E1-0B] { RegisterState = 200 }
Jan 19 17:45:16 sud SUD[26814]: ServingThread       (06): 
Aastra6739iContext.validateAastraXMLObject(AastraXMLIPPhoneExecute)


I have 4 broker in cluster
Log from broker 44.133
2011-01-19 17:45:16,231 | DEBUG | localhost adding consumer: 
ID:sud-37492-634310559151963650-1:1:1:1 for destination: 
topic://WEB.topic | org.apache.activemq.broker.region.AbstractRegion | 
ActiveMQ Transport: tcp:///127.0.0.1:35618
2011-01-19 17:45:16,245 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-12:2:1:5, destination 
topic://SUD.topic, brokerPath: [ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 5, responseRequired = false, 
messageId = ID:sud-37492-634310559151963650-1:0:1:1:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-12:1:1:1, destination = topic://SUD.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516235, arrival 
= 0, brokerInTime = 1295455516245, brokerOutTime = 1295455516245, 
correlationId = null, replyTo = null, persistent = false, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@346bda, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 2135, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#18
2011-01-19 17:45:16,246 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:5, destination 
topic://SUD.topic, brokerPath: [ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 5, responseRequired = false, 
messageId = ID:sud-37492-634310559151963650-1:0:1:1:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://SUD.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516235, arrival 
= 0, brokerInTime = 1295455516245, brokerOutTime = 1295455516246, 
correlationId = null, replyTo = null, persistent = false, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@346bda, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 2135, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,246 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:3, destination 
topic://SUD.topic, brokerPath: [ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 5, responseRequired = false, 
messageId = ID:sud-37492-634310559151963650-1:0:1:1:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://SUD.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516235, arrival 
= 0, brokerInTime = 1295455516245, brokerOutTime = 1295455516246, 
correlationId = null, replyTo = null, persistent = false, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@346bda, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 2135, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,250 | DEBUG | Expiring messages .. | 
org.apache.activemq.broker.region.Queue | ActiveMQ Broker[localhost] 
Scheduler
2011-01-19 17:45:16,250 | DEBUG | asystentAdam@CZABANMSI toPageIn: 0, 
Inflight: 0, pagedInMessages.size 0, enqueueCount: 0, dequeueCount: 0 | 
org.apache.activemq.broker.region.Queue | ActiveMQ Broker[localhost] 
Scheduler
2011-01-19 17:45:16,250 | DEBUG | Expiring messages .. | 
org.apache.activemq.broker.region.Queue | ActiveMQ Broker[localhost] 
Scheduler
2011-01-19 17:45:16,250 | DEBUG | ActiveMQ.DLQ toPageIn: 37, Inflight: 
0, pagedInMessages.size 0, enqueueCount: 37, dequeueCount: 0 | 
org.apache.activemq.broker.region.Queue | ActiveMQ Broker[localhost] 
Scheduler
2011-01-19 17:45:16,250 | DEBUG | ActiveMQ.DLQ toPageIn: 37, Inflight: 
0, pagedInMessages.size 0, enqueueCount: 37, dequeueCount: 0 | 
org.apache.activemq.broker.region.Queue | Queue:ActiveMQ.DLQ
2011-01-19 17:45:16,252 | DEBUG | localhost removing consumer: 
ID:sud-37492-634310559151963650-1:0:1:1 for destination: 
topic://SUD.topic | org.apache.activemq.broker.region.AbstractRegion | 
ActiveMQ Transport: tcp:///127.0.0.1:35617
2011-01-19 17:45:16,254 | DEBUG | remove connection id: 
ID:sud-37492-634310559151963650-1:0 | 
org.apache.activemq.broker.TransportConnection | ActiveMQ Transport: 
tcp:///127.0.0.1:35617
2011-01-19 17:45:16,255 | DEBUG | Stopping connection: /127.0.0.1:35617 
| org.apache.activemq.broker.TransportConnection | ActiveMQ Task
2011-01-19 17:45:16,255 | DEBUG | Stopping transport 
tcp:///127.0.0.1:35617 | org.apache.activemq.transport.tcp.TcpTransport 
| ActiveMQ Task
2011-01-19 17:45:16,257 | DEBUG | Stopped transport: /127.0.0.1:35617 | 
org.apache.activemq.broker.TransportConnection | ActiveMQ Task
2011-01-19 17:45:16,259 | DEBUG | Connection Stopped: /127.0.0.1:35617 | 
org.apache.activemq.broker.TransportConnection | ActiveMQ Task
2011-01-19 17:45:16,260 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:1229, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_p-59933-1295021914007-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 394038, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:67:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516255, arrival 
= 0, brokerInTime = 1295455516260, brokerOutTime = 1295455516260, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@1460902, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,261 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:1229, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_p-59933-1295021914007-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 394039, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:68:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516256, arrival 
= 0, brokerInTime = 1295455516260, brokerOutTime = 1295455516261, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@f9911e, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,261 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:1229, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_p-59933-1295021914007-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 394040, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:69:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516257, arrival 
= 0, brokerInTime = 1295455516260, brokerOutTime = 1295455516261, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@a67320, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,261 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:4, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_l-48559-1295021913503-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 231201, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:67:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516255, arrival 
= 0, brokerInTime = 1295455516260, brokerOutTime = 1295455516261, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@1d07ad5, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,261 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:4, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_l-48559-1295021913503-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 231202, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:68:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516256, arrival 
= 0, brokerInTime = 1295455516261, brokerOutTime = 1295455516261, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@30681e, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,265 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:1229, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_p-59933-1295021914007-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 394044, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:70:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516258, arrival 
= 0, brokerInTime = 1295455516262, brokerOutTime = 1295455516262, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@6af2d2, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,265 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-3:2:1:1229, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_p-59933-1295021914007-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 394045, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:71:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-3:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516259, arrival 
= 0, brokerInTime = 1295455516262, brokerOutTime = 1295455516265, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@16bf4b4, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#2
2011-01-19 17:45:16,266 | DEBUG | Transport failed: 
java.net.SocketException: Broken pipe | 
org.apache.activemq.broker.TransportConnection.Transport | Async 
Exception Handler
java.net.SocketException: Broken pipe
     at java.net.SocketOutputStream.socketWrite0(Native Method)
     at java.net.SocketOutputStream.socketWrite(Unknown Source)
     at java.net.SocketOutputStream.write(Unknown Source)
     at 
org.apache.activemq.transport.tcp.TcpBufferedOutputStream.flush(TcpBufferedOutputStream.java:115)
     at java.io.DataOutputStream.flush(Unknown Source)
     at 
org.apache.activemq.transport.tcp.TcpTransport.oneway(TcpTransport.java:182)
     at 
org.apache.activemq.transport.InactivityMonitor.oneway(InactivityMonitor.java:255)
     at 
org.apache.activemq.transport.TransportFilter.oneway(TransportFilter.java:85)
     at 
org.apache.activemq.transport.WireFormatNegotiator.oneway(WireFormatNegotiator.java:104)
     at 
org.apache.activemq.transport.MutexTransport.oneway(MutexTransport.java:40)
     at 
org.apache.activemq.broker.TransportConnection.dispatch(TransportConnection.java:1249)
     at 
org.apache.activemq.broker.TransportConnection.processDispatch(TransportConnection.java:810)
     at 
org.apache.activemq.broker.TransportConnection.iterate(TransportConnection.java:846)
     at 
org.apache.activemq.thread.DedicatedTaskRunner.runTask(DedicatedTaskRunner.java:98)
     at 
org.apache.activemq.thread.DedicatedTaskRunner$1.run(DedicatedTaskRunner.java:36)
2011-01-19 17:45:16,266 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:4, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_l-48559-1295021913503-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 231204, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:69:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516257, arrival 
= 0, brokerInTime = 1295455516262, brokerOutTime = 1295455516266, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@be292d, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,266 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:4, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_l-48559-1295021913503-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 231207, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:70:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516258, arrival 
= 0, brokerInTime = 1295455516266, brokerOutTime = 1295455516266, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@816eaa, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,267 | DEBUG | bridging (localhost -> localhost, 
consumer: ID:sud-56354-1295064310147-4:2:1:4, destination 
topic://WEB.topic, brokerPath: [ID:dgtl-38008-1295021911958-0:1, 
ID:dgt2_l-48559-1295021913503-0:1, ID:sud-56354-1295064310147-0:1], 
message: ActiveMQObjectMessage {commandId = 231208, responseRequired = 
false, messageId = ID:sud-37823-634310558783521020-1:0:1:71:1, 
originalDestination = null, originalTransactionId = null, producerId = 
ID:sud-56354-1295064310147-4:1:1:1, destination = topic://WEB.topic, 
transactionId = null, expiration = 0, timestamp = 1295455516259, arrival 
= 0, brokerInTime = 1295455516266, brokerOutTime = 1295455516267, 
correlationId = null, replyTo = null, persistent = true, type = null, 
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = 
null, compressed = false, userID = null, content = 
org.apache.activemq.util.ByteSequence@18879ee, marshalledProperties = 
null, dataStructure = null, redeliveryCounter = 0, size = 1973, 
properties = null, readOnlyProperties = false, readOnlyBody = false, 
droppable = false} | 
org.apache.activemq.network.DemandForwardingBridgeSupport | ActiveMQ 
Connection Dispatcher: vm://localhost#4
2011-01-19 17:45:16,269 | DEBUG | Stopping connection: /127.0.0.1:35618 
| org.apache.activemq.broker.TransportConnection | ActiveMQ Task
2011-01-19 17:45:16,269 | DEBUG | Stopping transport 
tcp:///127.0.0.1:35618 | org.apache.activemq.transport.tcp.TcpTransport 
| ActiveMQ Task



Hope this helps. If u need more log tell me.


Regards,
Adam

-- 
This message has been scanned for viruses and
dangerous content by MailScanner, and is
believed to be clean.