You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@camel.apache.org by towe <to...@cubeia.com> on 2012/08/23 10:56:22 UTC

shutting down Camel, in-flight messages gone

I am trying to set up a camel route that forwards jms messages from one
persistent (local) queue to another remote jms queue.

If the remote connection is down the incoming message should be left on the
in-queue.

I managed to get this to work using transactions. But the problem I have now
is that doing a graceful shutdown removes the in-flight messages (after
timing out on the DefaultShutdownStrategy).

Killing the Camel process the hard way (kill -9) preserves the messages on
the queue, which is what I want.

To summarize, what I want is:
1. forward from queue A to queue B
2. rollback A (leave in queue) if B is down
3. repeat trying forever
4. to be able to shutdown camel without dropping in-flight messages

/tw



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
You should remove the Camel error handler, and let the broker do the redelivery.
Don't do both.

A message broker can also be configured to perform redelivery of
messages, and it has a dead letter queues etc.

If you use ActiveMQ read and their links
http://activemq.apache.org/redelivery-policy.html
http://activemq.apache.org/message-redelivery-and-dlq-handling.html

And possible the Camel docs for the transactional client EIP (eg transaction)
http://camel.apache.org/transactional-client.html

On Thu, Aug 23, 2012 at 3:30 PM, towe <to...@cubeia.com> wrote:
> I am using transacted mode. But if I stop Camel during redelivery while the
> queue on B is down the message gets removed from the queue and is gone when
> I restart.
>
> To simulate an error I have a dummy consumer that throws an exception, but
> the problem is the same if I have a remote queue that is shut down.
>
> This is my Camel route (some beans left out for clarity):
>
>   [...]
>
>   <bean id="jmsConfig"
>      class="org.apache.camel.component.jms.JmsConfiguration">
>      <property name="connectionFactory" ref="poolConnectionFactory"/>
>      <property name="transactionManager" ref="jmsTransactionManager"/>
>      <property name="transacted" value="true"/>
>      <property name="concurrentConsumers" value="1"/>
>   </bean>
>
>   <bean id="jmsTransactionManager"
> class="org.springframework.jms.connection.JmsTransactionManager">
>     <property name="connectionFactory" ref="poolConnectionFactory" />
>   </bean>
>
>   <bean id="activemq"
> class="org.apache.activemq.camel.component.ActiveMQComponent">
>       <property name="configuration" ref="jmsConfig"/>
>   </bean>
>
>   <camelContext id="camel" xmlns="http://camel.apache.org/schema/spring">
>     <errorHandler id="camelErrorHandler">
>       <redeliveryPolicy maximumRedeliveries="-1" />
>     </errorHandler>
>
>     <onException>
>         <exception>java.lang.Exception</exception>
>         <rollback  markRollbackOnly="true" />
>     </onException>
>
>     <route errorHandlerRef="camelErrorHandler"
> shutdownRunningTask="CompleteCurrentTaskOnly">
>       <from uri="activemq:queue:events" />
>       <transacted ref="PROPAGATION_REQUIRED"/>
>       <to uri="bean:dummyConsumer?method=onMessage(${body})"/>
>     </route>
>   </camelContext>
>   [...]
>
>
> When shutting down I get the log below. The log basically says that it is
> waiting for an in-flight message left, then when it times out it forces a
> shutdown.
>
> --------------------------------------
> 2012-08-23 15:19:47,132 INFO  org.apache.camel.impl.DefaultShutdownStrategy
> - Waiting as there are still 1 inflight and pending exchanges to complete,
> timeout in 1 seconds.
> 2012-08-23 15:19:47,661 DEBUG org.apache.camel.processor.SendProcessor -
>>>>> Endpoint[bean://dummyConsumer?method=onMessage($%7Bbody%7D)]
> Exchange[JmsMessage[JmsMessageID:
> ID:tjock-xxl-41399-1345727978381-1:1:1:1:1]]
>
> --- DUMMY CONSUMER, message: message 1345727978573
>
> 2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.DefaultErrorHandler
> - Failed delivery for (MessageId: ID:tjock-xxl-41399-1345727978381-1:1:1:1:1
> on ExchangeId: ID-tjock-xxl-57097-1345727966790-0-1). On delivery attempt: 9
> caught: java.lang.RuntimeException: test error
> 2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.DefaultErrorHandler
> - Redelivery delay calculated as 1000
> 2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.RedeliveryPolicy -
> Sleeping for: 1000 millis until attempting redelivery
> 2012-08-23 15:19:48,130 WARN  org.apache.camel.impl.DefaultShutdownStrategy
> - Timeout occurred. Now forcing the routes to be shutdown now.
> 2012-08-23 15:19:48,130 WARN  org.apache.camel.impl.DefaultShutdownStrategy
> - Interrupted while waiting during graceful shutdown, will force shutdown
> now.
> 2012-08-23 15:19:48,663 DEBUG org.apache.camel.processor.SendProcessor -
>>>>> Endpoint[bean://dummyConsumer?method=onMessage($%7Bbody%7D)]
> Exchange[JmsMessage[JmsMessageID:
> ID:tjock-xxl-41399-1345727978381-1:1:1:1:1]]
>
> --- DUMMY CONSUMER, message: message 1345727978573
>
> 2012-08-23 15:19:48,665 WARN
> org.apache.camel.spring.spi.TransactionErrorHandler - Transaction rollback
> (0x8996666) redelivered(false) for (MessageId:
> ID:tjock-xxl-41399-1345727978381-1:1:1:1:1 on ExchangeId:
> ID-tjock-xxl-57097-1345727966790-0-1) caught: java.lang.RuntimeException:
> test error
> 2012-08-23 15:19:48,666 DEBUG org.apache.activemq.ActiveMQSession -
> ID:tjock-xxl-46934-1345727966509-3:1:1 Transaction Rollback,
> txid:TX:ID:tjock-xxl-46934-1345727966509-3:1:1
> 2012-08-23 15:19:48,666 DEBUG org.apache.activemq.TransactionContext -
> Rollback: TX:ID:tjock-xxl-46934-1345727966509-3:1:1 syncCount: 2
> 2012-08-23 15:19:48,668 DEBUG
> org.apache.activemq.transaction.LocalTransaction - rollback:
> TX:ID:tjock-xxl-46934-1345727966509-3:1:1 syncCount: 2
> 2012-08-23 15:19:48,669 DEBUG org.apache.activemq.ActiveMQMessageConsumer -
> remove: ID:tjock-xxl-46934-1345727966509-3:1:1:12,
> lastDeliveredSequenceId:31
> 2012-08-23 15:19:48,669 DEBUG org.apache.activemq.ActiveMQSession -
> ID:tjock-xxl-46934-1345727966509-3:1:1 Transaction Rollback, txid:null
> 2012-08-23 15:19:48,669 DEBUG
> org.apache.activemq.broker.region.AbstractRegion - localhost removing
> consumer: ID:tjock-xxl-46934-1345727966509-3:1:1:12 for destination:
> queue://events
> 2012-08-23 15:19:48,670 DEBUG org.apache.camel.component.jms.JmsConsumer -
> Stopping consumer: Consumer[activemq://queue:events]
> 2012-08-23 15:19:48,670 DEBUG org.apache.camel.component.jms.JmsConsumer -
> Stopping consumer: Consumer[activemq://queue:events]
> 2012-08-23 15:19:48,670 INFO  org.apache.camel.impl.DefaultShutdownStrategy
> - Graceful shutdown of 1 routes completed in 5 seconds
>
>
> /tw
>
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717944.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by Babak Vahdat <ba...@swissonline.ch>.
Hi

the AMQ useShutdownHook option defaults to "true" so that you can skip
setting it explicitly:

http://activemq.apache.org/broker-uri.html

Babak




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718363.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Just as a future reference to others with the same issue:

Using a depends-on from the broker to camel didn't work by itself without
useShutdownHook set to true.

I am now using both the shutdown hook and a depends-on to make completely
sure stuff is dismantled in the correct order. 

This is my working Spring xml for the broker:

  <amq:broker useJmx="true" persistent="true" useShutdownHook="true"
context:depends-on="camel" xmlns="http://activemq.apache.org/schema/core">
    <transportConnectors>
      <transportConnector uri="tcp://localhost:61616" />
    </transportConnectors>
    <persistenceAdapter>
      <kahaPersistenceAdapter directory="activemq-data"
maxDataFileLength="33554432" />
    </persistenceAdapter>
  </amq:broker> 







--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718282.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Problem solved!!!

I had "useShutdownHook" set to false in my embedded broker. Setting that to
true solved it. Now everything works like a charm.

I will add the depends-on as well to have them shutdown in the correct
order.

Thank you very much for your help!



Claus Ibsen-2 wrote
> 
> Yeah good point, you can use the depends-on attribute in the Spring
> XML file, to tell it to have the broker depend on <camelContext>.
> This is needed to have spring shutdown camel first.
> 




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718277.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
On Wed, Aug 29, 2012 at 5:12 PM, towe <to...@cubeia.com> wrote:
> I think you are on to something here! :-)
>
> One major difference I spotted between your test and mine is the standalone
> broker.
>
> When I run my own test against an external broker everything works as
> expected, the message is still there after camel shutdown!
>
> But when I run with an embedded broker started by Spring the message is
> gone.
>
> Maybe the shutdown (order) of camel and the broker when the spring context
> is destroyed has anything to do with it...
>

Yeah good point, you can use the depends-on attribute in the Spring
XML file, to tell it to have the broker depend on <camelContext>.
This is needed to have spring shutdown camel first.

>
>
> Claus Ibsen-2 wrote
>>
>> I created an unit test trying to reproduce an issue
>> http://svn.apache.org/viewvc?rev=1378526&view=rev
>>
>> It works for me. I start up a remote AMQ broker first. In this case
>> Apache ActiveMQ 5.6.0.
>> Running the test ensures the message is rolled back, and using the AMQ
>> web console I can see the message starts on the queue.
>>
>
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718272.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
I think you are on to something here! :-)

One major difference I spotted between your test and mine is the standalone
broker.

When I run my own test against an external broker everything works as
expected, the message is still there after camel shutdown!

But when I run with an embedded broker started by Spring the message is
gone.

Maybe the shutdown (order) of camel and the broker when the spring context
is destroyed has anything to do with it...  
 


Claus Ibsen-2 wrote
> 
> I created an unit test trying to reproduce an issue
> http://svn.apache.org/viewvc?rev=1378526&view=rev
> 
> It works for me. I start up a remote AMQ broker first. In this case
> Apache ActiveMQ 5.6.0.
> Running the test ensures the message is rolled back, and using the AMQ
> web console I can see the message starts on the queue.
> 




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718272.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Claus Ibsen-2 wrote
> 
> The log file cannot be downloaded from that link.
> 

Strange, works for me. 

Here is the log:
---------------------------------------------------------------------

2012-08-27 10:48:50,103 DEBUG
org.apache.activemq.transport.WireFormatNegotiator - Sending: WireFormatInfo
{ version=9, properties={MaxFrameSize=104857600, CacheSize=1024,
CacheEnabled=true, SizePrefixDisabled=false,
MaxInactivityDurationInitalDelay=10000, TcpNoDelayEnabled=true,
MaxInactivityDuration=30000, TightEncodingEnabled=true,
StackTraceEnabled=true}, magic=[A,c,t,i,v,e,M,Q]}
2012-08-27 10:48:50,105 DEBUG
org.apache.activemq.transport.InactivityMonitor - Using min of local:
WireFormatInfo { version=9, properties={MaxFrameSize=104857600,
CacheSize=1024, CacheEnabled=true, SizePrefixDisabled=false,
MaxInactivityDurationInitalDelay=10000, TcpNoDelayEnabled=true,
MaxInactivityDuration=30000, TightEncodingEnabled=true,
StackTraceEnabled=true}, magic=[A,c,t,i,v,e,M,Q]} and remote: WireFormatInfo
{ version=9, properties={CacheSize=1024, MaxFrameSize=104857600,
CacheEnabled=true, SizePrefixDisabled=false, TcpNoDelayEnabled=true,
MaxInactivityDurationInitalDelay=10000, MaxInactivityDuration=30000,
TightEncodingEnabled=true, StackTraceEnabled=true}, magic=[A,c,t,i,v,e,M,Q]}
2012-08-27 10:48:50,105 DEBUG
org.apache.activemq.transport.WireFormatNegotiator - Received WireFormat:
WireFormatInfo { version=9, properties={CacheSize=1024,
MaxFrameSize=104857600, CacheEnabled=true, SizePrefixDisabled=false,
TcpNoDelayEnabled=true, MaxInactivityDurationInitalDelay=10000,
MaxInactivityDuration=30000, TightEncodingEnabled=true,
StackTraceEnabled=true}, magic=[A,c,t,i,v,e,M,Q]}
2012-08-27 10:48:50,106 DEBUG
org.apache.activemq.transport.WireFormatNegotiator - tcp:///127.0.0.1:47139
before negotiation: OpenWireFormat{version=9, cacheEnabled=false,
stackTraceEnabled=false, tightEncodingEnabled=false,
sizePrefixDisabled=false, maxFrameSize=104857600}
2012-08-27 10:48:50,106 DEBUG
org.apache.activemq.transport.WireFormatNegotiator - tcp:///127.0.0.1:47139
after negotiation: OpenWireFormat{version=9, cacheEnabled=true,
stackTraceEnabled=true, tightEncodingEnabled=true, sizePrefixDisabled=false,
maxFrameSize=104857600}
2012-08-27 10:48:50,110 DEBUG org.apache.activemq.broker.TransportConnection
- Setting up new connection id: ID:tjock-xxl-48198-1346057329963-1:1,
address: tcp://127.0.0.1:47139, info: ConnectionInfo {commandId = 1,
responseRequired = true, connectionId =
ID:tjock-xxl-48198-1346057329963-1:1, clientId = example-client, clientIp =
null, userName = null, password = *****, brokerPath = null,
brokerMasterConnector = false, manageable = true, clientMaster = true,
faultTolerant = false, failoverReconnect = false}
2012-08-27 10:48:50,116 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost adding
consumer: ID:tjock-xxl-48198-1346057329963-1:1:-1:1 for destination:
ActiveMQ.Advisory.TempQueue,ActiveMQ.Advisory.TempTopic
2012-08-27 10:48:50,143 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost adding
destination: topic://ActiveMQ.Advisory.Producer.Queue.events
2012-08-27 10:48:50,155 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost removing
consumer: ID:tjock-xxl-48198-1346057329963-1:1:-1:1 for destination:
ActiveMQ.Advisory.TempQueue,ActiveMQ.Advisory.TempTopic
2012-08-27 10:48:50,155 DEBUG org.apache.activemq.broker.TransportConnection
- remove connection id: ID:tjock-xxl-48198-1346057329963-1:1
2012-08-27 10:48:50,155 TRACE
org.apache.activemq.broker.region.cursors.AbstractStoreCursor -
org.apache.activemq.broker.region.cursors.QueueStorePrefetch@4d611a1:events,batchResetNeeded=true,storeHasMessages=true,size=0,cacheEnabled=true
- fillBatch
2012-08-27 10:48:50,157 DEBUG org.apache.activemq.broker.TransportConnection
- Stopping connection: tcp://127.0.0.1:47139
2012-08-27 10:48:50,157 TRACE
org.apache.activemq.broker.region.PrefetchSubscription -
ID:tjock-xxl-41895-1346057322482-3:1:1:7 dispatched:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 - queue://events, dispatched: 1,
inflight: 1
2012-08-27 10:48:50,157 DEBUG org.apache.activemq.transport.tcp.TcpTransport
- Stopping transport tcp:///127.0.0.1:47139
2012-08-27 10:48:50,158 DEBUG org.apache.activemq.broker.TransportConnection
- Stopped transport: tcp://127.0.0.1:47139
2012-08-27 10:48:50,158 DEBUG org.apache.activemq.broker.TransportConnection
- Connection Stopped: tcp://127.0.0.1:47139
2012-08-27 10:48:50,159 TRACE org.apache.activemq.ActiveMQMessageConsumer -
ID:tjock-xxl-41895-1346057322482-3:1:1:7 received message: MessageDispatch
{commandId = 12, responseRequired = false, consumerId =
ID:tjock-xxl-41895-1346057322482-3:1:1:7, destination = queue://events,
message = ActiveMQTextMessage {commandId = 5, responseRequired = true,
messageId = ID:tjock-xxl-48198-1346057329963-1:1:1:1:1, originalDestination
= null, originalTransactionId = null, producerId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1, destination = queue://events,
transactionId = null, expiration = 0, timestamp = 1346057330146, arrival =
0, brokerInTime = 1346057330150, brokerOutTime = 1346057330157,
correlationId = null, replyTo = null, persistent = true, type = null,
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = null,
compressed = false, userID = null, content = null, marshalledProperties =
null, dataStructure = null, redeliveryCounter = 0, size = 1049, properties =
null, readOnlyProperties = true, readOnlyBody = true, droppable = false,
text = crashme 1346057330141}, redeliveryCounter = 0}
2012-08-27 10:48:50,159 DEBUG org.apache.activemq.TransactionContext -
Begin:TX:ID:tjock-xxl-41895-1346057322482-3:1:1
2012-08-27 10:48:50,159 TRACE
org.apache.camel.component.jms.EndpointMessageListener - onMessage START
2012-08-27 10:48:50,160 DEBUG
org.apache.camel.component.jms.EndpointMessageListener -
Endpoint[activemq://queue:events] consumer received JMS message:
ActiveMQTextMessage {commandId = 5, responseRequired = true, messageId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1, originalDestination = null,
originalTransactionId = null, producerId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1, destination = queue://events,
transactionId = null, expiration = 0, timestamp = 1346057330146, arrival =
0, brokerInTime = 1346057330150, brokerOutTime = 1346057330157,
correlationId = null, replyTo = null, persistent = true, type = null,
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = null,
compressed = false, userID = null, content = null, marshalledProperties =
null, dataStructure = null, redeliveryCounter = 0, size = 1049, properties =
null, readOnlyProperties = true, readOnlyBody = true, droppable = false,
text = crashme 1346057330141}
2012-08-27 10:48:50,161 TRACE
org.apache.camel.component.jms.EndpointMessageListener - onMessage.process
START
2012-08-27 10:48:50,161 TRACE
org.apache.camel.component.jms.EndpointMessageListener - Processing exchange
ID-tjock-xxl-50692-1346057322775-0-1 synchronously
2012-08-27 10:48:50,163 TRACE org.apache.camel.impl.DefaultUnitOfWork -
UnitOfWork created for ExchangeId: ID-tjock-xxl-50692-1346057322775-0-1 with
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,163 TRACE org.apache.camel.component.jms.JmsBinding -
Extracting body as a TextMessage from JMS message: ActiveMQTextMessage
{commandId = 5, responseRequired = true, messageId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1, originalDestination = null,
originalTransactionId = null, producerId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1, destination = queue://events,
transactionId = null, expiration = 0, timestamp = 1346057330146, arrival =
0, brokerInTime = 1346057330150, brokerOutTime = 1346057330157,
correlationId = null, replyTo = null, persistent = true, type = null,
priority = 4, groupID = null, groupSequence = 0, targetConsumerId = null,
compressed = false, userID = null, content = null, marshalledProperties =
null, dataStructure = null, redeliveryCounter = 0, size = 1049, properties =
null, readOnlyProperties = true, readOnlyBody = true, droppable = false,
text = crashme 1346057330141}
2012-08-27 10:48:50,167 TRACE org.apache.camel.processor.UnitOfWorkProcessor
- Processing exchange asynchronously: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,169 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Transaction begin
(0x3f2e288c) redelivered(false) for (MessageId:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1))
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.processor.Pipeline -
ExchangeId: ID-tjock-xxl-50692-1346057322775-0-1 should continue routing:
true
2012-08-27 10:48:50,171 TRACE org.apache.camel.processor.Pipeline -
Processing exchangeId: ID-tjock-xxl-50692-1346057322775-0-1 >>>
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,171 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,172 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,172 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,172 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,173 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,173 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,177 TRACE org.apache.camel.component.bean.BeanInfo -
Introspecting class: class com.odobo.databank.test.DummyConsumer
2012-08-27 10:48:50,177 TRACE org.apache.camel.component.bean.BeanInfo -
Method: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) is valid:
true
2012-08-27 10:48:50,177 TRACE org.apache.camel.component.bean.BeanInfo -
Introspecting class: class com.odobo.databank.test.DummyConsumer, method:
public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String)
2012-08-27 10:48:50,178 TRACE org.apache.camel.component.bean.BeanInfo -
Creating MethodInfo for class: class com.odobo.databank.test.DummyConsumer
method: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) having 1
parameters
2012-08-27 10:48:50,178 TRACE org.apache.camel.component.bean.BeanInfo -
Parameter #0: ParameterInfo[index=0, type=class java.lang.String,
annotations=[], expression=null]
2012-08-27 10:48:50,178 TRACE org.apache.camel.component.bean.BeanInfo -
Parameter #0 has @Body annotation
2012-08-27 10:48:50,178 TRACE org.apache.camel.component.bean.BeanInfo -
Parameter #0 is the body parameter using expression
mandatoryBodyAs[java.lang.String]
2012-08-27 10:48:50,178 TRACE org.apache.camel.component.bean.BeanInfo -
Parameter #0 has parameter info: 
2012-08-27 10:48:50,179 TRACE org.apache.camel.component.bean.MethodInfo -
Creating parameters expression for 1 parameters
2012-08-27 10:48:50,179 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 has expression: mandatoryBodyAs[java.lang.String]
2012-08-27 10:48:50,182 TRACE org.apache.camel.component.bean.BeanInfo -
Adding operation: onMessage for method: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String)
2012-08-27 10:48:50,182 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:50,182 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:50,183 TRACE org.apache.camel.util.ObjectHelper - Loading
class: org.apache.camel.language.simple.SimpleLanguage using classloader:
WebAppClassLoader=1338337548@4fc5690c
2012-08-27 10:48:50,189 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:50,190 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:50,198 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:50,198 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:50,198 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:50,198 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:50,199 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:50,199 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,199 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 27 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,200 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,200 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,200 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:50,200 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:50,200 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:50,200 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:50,200 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:50,200 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:50,201 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 0 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:50,201 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:50,201 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:51,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:51,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:51,004 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:51,203 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,203 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,203 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,203 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,203 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,204 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:51,204 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:51,204 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:51,204 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:51,205 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:51,205 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:51,205 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:51,205 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:51,205 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:51,206 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,206 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 3 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,206 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,206 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,206 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:51,206 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:51,206 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:51,206 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:51,206 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:51,206 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:51,207 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 1 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:51,207 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:51,207 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:52,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:52,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:52,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:52,207 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,207 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,207 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,208 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,208 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,208 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:52,208 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:52,208 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:52,208 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:52,209 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:52,209 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:52,209 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:52,209 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:52,209 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:52,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,210 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 3 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:52,210 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:52,210 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:52,210 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:52,210 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:52,210 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:52,210 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 2 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:52,210 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:52,210 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:53,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:53,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:53,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:53,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,210 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,211 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,211 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,211 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:53,211 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:53,211 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:53,211 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:53,212 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:53,212 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:53,212 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:53,212 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:53,212 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:53,212 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,212 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 2 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,212 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,212 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,212 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:53,212 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:53,213 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:53,213 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:53,213 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:53,213 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:53,213 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 3 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:53,213 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:53,213 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
^C2012-08-27 10:48:53,833 DEBUG org.apache.jasper.servlet.JspServlet -
JspServlet.destroy()
2012-08-27 10:48:53.836:INFO:/:Closing Spring root WebApplicationContext
2012-08-27 10:48:53,836 INFO 
org.springframework.web.context.support.XmlWebApplicationContext - Closing
Root WebApplicationContext: startup date [Mon Aug 27 10:48:41 CEST 2012];
root of context hierarchy
2012-08-27 10:48:53,836 DEBUG org.apache.camel.spring.SpringCamelContext -
onApplicationEvent:
org.springframework.context.event.ContextClosedEvent[source=Root
WebApplicationContext: startup date [Mon Aug 27 10:48:41 CEST 2012]; root of
context hierarchy]
2012-08-27 10:48:53,837 INFO 
org.springframework.beans.factory.support.DefaultListableBeanFactory -
Destroying singletons in
org.springframework.beans.factory.support.DefaultListableBeanFactory@676d5dac:
defining beans
[dummyConsumer,org.springframework.context.annotation.internalConfigurationAnnotationProcessor,org.springframework.context.annotation.internalAutowiredAnnotationProcessor,org.springframework.context.annotation.internalRequiredAnnotationProcessor,org.springframework.context.annotation.internalCommonAnnotationProcessor,org.springframework.beans.factory.config.PropertyPlaceholderConfigurer#0,org.apache.activemq.xbean.XBeanBrokerService#0,activemq,masterBroker,jmsConnectionFactory,poolConnectionFactory,jmsConfig,jmsTransactionManager,PROPAGATION_REQUIRED,shutdown,databankProps,org.apache.camel.spring.CamelRedeliveryPolicyFactoryBean#0,camelErrorHandler,template,consumerTemplate,camel:beanPostProcessor,camel,org.springframework.context.annotation.ConfigurationClassPostProcessor$ImportAwareBeanPostProcessor#0];
root of factory hierarchy
2012-08-27 10:48:53,839 INFO  org.apache.camel.spring.SpringCamelContext -
Apache Camel 2.10.0 (CamelContext: camel) is shutting down
2012-08-27 10:48:53,840 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Starting to graceful shutdown 1 routes (timeout 5 seconds)
2012-08-27 10:48:53,840 TRACE
org.apache.camel.management.DefaultManagementLifecycleStrategy - Checking
whether to register
org.apache.camel.util.concurrent.RejectableThreadPoolExecutor@4b4cc541[Running,
pool size = 0, active threads = 0, queued tasks = 0, completed tasks = 0]
from route: null
2012-08-27 10:48:53,840 DEBUG
org.apache.camel.impl.DefaultExecutorServiceManager - Created new ThreadPool
for source: org.apache.camel.impl.DefaultShutdownStrategy@21f7915d with
name: ShutdownTask. ->
org.apache.camel.util.concurrent.RejectableThreadPoolExecutor@4b4cc541[Running,
pool size = 0, active threads = 0, queued tasks = 0, completed tasks = 0]
2012-08-27 10:48:53,842 TRACE
org.apache.camel.util.concurrent.CamelThreadFactory - Created
thread[ShutdownTask]: Thread[Camel (camel) thread #2 - ShutdownTask,5,main]
2012-08-27 10:48:53,843 DEBUG org.apache.camel.impl.DefaultShutdownStrategy
- There are 1 routes to shutdown
2012-08-27 10:48:53,843 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Shutting down route: route1 with options [Default,CompleteCurrentTaskOnly]
2012-08-27 10:48:53,844 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Suspending: Consumer[activemq://queue:events]
2012-08-27 10:48:53,844 TRACE org.apache.camel.util.ServiceHelper -
Suspending service Consumer[activemq://queue:events]
2012-08-27 10:48:53,844 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Suspend complete for: Consumer[activemq://queue:events]
2012-08-27 10:48:53,845 DEBUG org.apache.camel.impl.DefaultShutdownStrategy
- Route: route1 suspended and shutdown deferred, was consuming from:
Endpoint[activemq://queue:events]
2012-08-27 10:48:53,845 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- 1 inflight and pending exchanges for route: route1
2012-08-27 10:48:53,845 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 5 seconds.
2012-08-27 10:48:54,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:54,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:54,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:54,213 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,213 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,213 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,214 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,214 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,214 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:54,214 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:54,214 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:54,215 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:54,215 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:54,215 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:54,215 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:54,215 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:54,215 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:54,215 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,215 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 2 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,216 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,216 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,216 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:54,216 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:54,216 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:54,216 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:54,216 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:54,216 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:54,216 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 4 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:54,216 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:54,216 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:54,845 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- 1 inflight and pending exchanges for route: route1
2012-08-27 10:48:54,845 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 4 seconds.
2012-08-27 10:48:55,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:55,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:55,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:55,217 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,217 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,217 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,217 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,217 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,217 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:55,217 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:55,218 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:55,218 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:55,218 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:55,218 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:55,218 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:55,218 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:55,219 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:55,219 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,219 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 2 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,219 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,219 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,219 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:55,219 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:55,219 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:55,219 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:55,219 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:55,219 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:55,219 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 5 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:55,220 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:55,220 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:55,845 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- 1 inflight and pending exchanges for route: route1
2012-08-27 10:48:55,846 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 3 seconds.
2012-08-27 10:48:56,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:56,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:56,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:56,220 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,220 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,220 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,220 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,220 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,221 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:56,221 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:56,221 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:56,221 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:56,222 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:56,222 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:56,222 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:56,222 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:56,222 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:56,222 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,222 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 2 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,222 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,222 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,222 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:56,222 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:56,222 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:56,223 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:56,223 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:56,223 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:56,223 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 6 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:56,223 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:56,223 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:56,846 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- 1 inflight and pending exchanges for route: route1
2012-08-27 10:48:56,846 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 2 seconds.
2012-08-27 10:48:57,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:57,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:57,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:57,223 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,223 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,223 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,224 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,224 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,224 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:57,224 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:57,225 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:57,225 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:57,225 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:57,225 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:57,226 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:57,226 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:57,226 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:57,226 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,226 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 3 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,226 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,226 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,227 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:57,227 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:57,227 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:57,227 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:57,227 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:57,227 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:57,227 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 7 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:57,227 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:57,227 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:57,846 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- 1 inflight and pending exchanges for route: route1
2012-08-27 10:48:57,846 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 1 seconds.
2012-08-27 10:48:58,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:58,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:58,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:58,228 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,228 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,228 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,228 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,228 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,229 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:58,229 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:58,229 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:58,229 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:58,230 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:58,230 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:58,230 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:58,230 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:58,230 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:58,231 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,231 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 3 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,231 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,231 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,231 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:58,231 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:58,231 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:58,231 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:58,231 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Finding best suited exception policy for thrown exception
java.lang.RuntimeException
2012-08-27 10:48:58,232 TRACE
org.apache.camel.processor.exceptionpolicy.DefaultExceptionPolicyStrategy -
Found 0 candidates
2012-08-27 10:48:58,232 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Failed delivery for
(MessageId: ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1). On delivery attempt: 8 caught:
java.lang.RuntimeException: test error
2012-08-27 10:48:58,232 DEBUG
org.apache.camel.spring.spi.TransactionErrorHandler - Redelivery delay
calculated as 1000
2012-08-27 10:48:58,232 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-27 10:48:58,843 WARN  org.apache.camel.impl.DefaultShutdownStrategy
- Timeout occurred. Now forcing the routes to be shutdown now.
2012-08-27 10:48:58,844 WARN  org.apache.camel.impl.DefaultShutdownStrategy
- Interrupted while waiting during graceful shutdown, will force shutdown
now.
2012-08-27 10:48:58,844 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Shutting down: Consumer[activemq://queue:events]
2012-08-27 10:48:58,844 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Shutting down: Consumer[activemq://queue:events]
2012-08-27 10:48:58,844 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Consumer[activemq://queue:events]
2012-08-27 10:48:58,844 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Consumer[activemq://queue:events]
2012-08-27 10:48:58,844 TRACE org.apache.camel.support.ServiceSupport -
Service already stopping
2012-08-27 10:48:58,844 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Shutdown complete for: Consumer[activemq://queue:events]
2012-08-27 10:48:58,845 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Route: route1 shutdown complete, was consuming from:
Endpoint[activemq://queue:events]
2012-08-27 10:48:59,003 TRACE org.apache.camel.support.TimerListenerManager
- Running scheduled TimerListener task
2012-08-27 10:48:59,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedCamelContext@58b94e98
2012-08-27 10:48:59,003 TRACE org.apache.camel.support.TimerListenerManager
- Invoking onTimer on
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:59,232 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,232 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,232 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,233 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,233 TRACE org.apache.camel.util.AsyncProcessorHelper -
Transacted Exchange must be routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,233 TRACE org.apache.camel.component.bean.BeanInfo -
Chosen method to invoke: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228
2012-08-27 10:48:59,233 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: ${body}
2012-08-27 10:48:59,233 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
before initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:59,233 TRACE
org.apache.camel.impl.DefaultCamelBeanPostProcessor - Camel bean processing
after initialization for bean:
org.apache.camel.language.simple.SimpleLanguage
2012-08-27 10:48:59,234 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.Object with value: crashme 1346057330141
2012-08-27 10:48:59,234 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:59,234 TRACE
org.apache.camel.impl.converter.DefaultTypeConverter - Converting
java.lang.String -> java.lang.String with value: crashme 1346057330141
2012-08-27 10:48:59,234 TRACE org.apache.camel.component.bean.MethodInfo -
Parameter #0 evaluated as: crashme 1346057330141 type: 
2012-08-27 10:48:59,234 TRACE org.apache.camel.component.bean.MethodInfo -
>>>> invoking: public void
com.odobo.databank.test.DummyConsumer.onMessage(java.lang.String) on bean:
com.odobo.databank.test.DummyConsumer@15cf4228 with arguments: {crashme
1346057330141} for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]

--- DUMMY CONSUMER, message: crashme 1346057330141
--- DUMMY CONSUMER, exception triggered
2012-08-27 10:48:59,234 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,234 TRACE
org.apache.camel.management.InstrumentationProcessor - to: Recording
duration: 2 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,234 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,235 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,235 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,235 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:59,235 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:59,235 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed as
ShutdownStrategy is forcing shutting down
2012-08-27 10:48:59,235 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed, will
reject executing exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,235 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,235 TRACE org.apache.camel.processor.Pipeline -
Processing exchangeId: ID-tjock-xxl-50692-1346057322775-0-1 is continued
being processed synchronously
2012-08-27 10:48:59,236 DEBUG org.apache.camel.processor.Pipeline - Message
exchange has failed: so breaking out of pipeline for exchange:
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]] Exception:
java.lang.RuntimeException: test error
2012-08-27 10:48:59,236 TRACE org.apache.camel.processor.Pipeline -
Processing complete for exchangeId: ID-tjock-xxl-50692-1346057322775-0-1 >>>
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,236 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,236 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:59,236 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:59,236 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed as
ShutdownStrategy is forcing shutting down
2012-08-27 10:48:59,236 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed, will
reject executing exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 interrupted? false
2012-08-27 10:48:59,237 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Is exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 done? false
2012-08-27 10:48:59,237 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed as
ShutdownStrategy is forcing shutting down
2012-08-27 10:48:59,237 TRACE
org.apache.camel.spring.spi.TransactionErrorHandler - Run not allowed, will
reject executing exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 WARN 
org.apache.camel.spring.spi.TransactionErrorHandler - Transaction rollback
(0x3f2e288c) redelivered(false) for (MessageId:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-50692-1346057322775-0-1) caught: java.lang.RuntimeException:
test error
2012-08-27 10:48:59,237 TRACE
org.apache.camel.management.InstrumentationProcessor - route: Recording
duration: 9076 millis for exchange: Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,237 TRACE org.apache.camel.impl.DefaultUnitOfWork -
UnitOfWork done for ExchangeId: ID-tjock-xxl-50692-1346057322775-0-1 with
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,238 TRACE org.apache.camel.util.AsyncProcessorHelper -
Exchange processed and is continued routed synchronously for exchangeId:
ID-tjock-xxl-50692-1346057322775-0-1 -> Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1]]
2012-08-27 10:48:59,238 TRACE
org.apache.camel.component.jms.EndpointMessageListener - onMessage.process
END
2012-08-27 10:48:59,238 TRACE
org.apache.camel.component.jms.EndpointMessageListener - onMessage END
throwing exception: java.lang.RuntimeException: test error
2012-08-27 10:48:59,239 DEBUG org.apache.activemq.ActiveMQSession -
ID:tjock-xxl-41895-1346057322482-3:1:1 Transaction Rollback,
txid:TX:ID:tjock-xxl-41895-1346057322482-3:1:1
2012-08-27 10:48:59,239 DEBUG org.apache.activemq.TransactionContext -
Rollback: TX:ID:tjock-xxl-41895-1346057322482-3:1:1 syncCount: 2
2012-08-27 10:48:59,239 TRACE
org.apache.activemq.broker.region.PrefetchSubscription - ack:MessageAck
{commandId = 18, responseRequired = false, ackType = 2, consumerId =
ID:tjock-xxl-41895-1346057322482-3:1:1:7, firstMessageId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1, lastMessageId =
ID:tjock-xxl-48198-1346057329963-1:1:1:1:1, destination = queue://events,
transactionId = TX:ID:tjock-xxl-41895-1346057322482-3:1:1, messageCount = 1,
poisonCause = null}
2012-08-27 10:48:59,242 DEBUG
org.apache.activemq.transaction.LocalTransaction - rollback:
TX:ID:tjock-xxl-41895-1346057322482-3:1:1 syncCount: 2
2012-08-27 10:48:59,243 DEBUG org.apache.activemq.ActiveMQMessageConsumer -
remove: ID:tjock-xxl-41895-1346057322482-3:1:1:7, lastDeliveredSequenceId:18
2012-08-27 10:48:59,243 DEBUG org.apache.activemq.ActiveMQSession -
ID:tjock-xxl-41895-1346057322482-3:1:1 Transaction Rollback, txid:null
2012-08-27 10:48:59,244 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost removing
consumer: ID:tjock-xxl-41895-1346057322482-3:1:1:7 for destination:
queue://events
2012-08-27 10:48:59,244 DEBUG org.apache.camel.component.jms.JmsConsumer -
Stopping consumer: Consumer[activemq://queue:events]
2012-08-27 10:48:59,244 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]
2012-08-27 10:48:59,245 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]
2012-08-27 10:48:59,246 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])
2012-08-27 10:48:59,246 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]]
2012-08-27 10:48:59,247 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]
2012-08-27 10:48:59,247 TRACE org.apache.camel.util.ServiceHelper - Stopping
service TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]
2012-08-27 10:48:59,248 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Instrumentation:transacted[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]
2012-08-27 10:48:59,248 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,249 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,249 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,249 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,249 TRACE org.apache.camel.util.ServiceHelper - Stopping
service TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]
2012-08-27 10:48:59,250 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Instrumentation:to[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,250 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])
2012-08-27 10:48:59,250 TRACE org.apache.camel.util.ServiceHelper - Stopping
service ProducerCache for source:
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]),
capacity: 1
2012-08-27 10:48:59,250 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,250 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,250 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,250 DEBUG
org.apache.camel.impl.SharedProducerServicePool - Stopping service pool:
org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,251 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Producer[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
2012-08-27 10:48:59,251 DEBUG org.apache.camel.impl.ProcessorEndpoint$1 -
Stopping producer:
Producer[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
2012-08-27 10:48:59,251 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
Producer[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
2012-08-27 10:48:59,251 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,251 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
org.apache.camel.processor.interceptor.DefaultTraceEventHandler@33afbc10
2012-08-27 10:48:59,251 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]
2012-08-27 10:48:59,251 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
RouteContextProcessor[TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
Instrumentation:to[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service ProducerCache for source:
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000]),
capacity: 1
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,252 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,252 DEBUG
org.apache.camel.impl.SharedProducerServicePool - Stopping service pool:
org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Producer[activemq://topic:events.public?timeToLive=172800000]
2012-08-27 10:48:59,252 DEBUG org.apache.camel.component.jms.JmsProducer -
Stopping producer:
Producer[activemq://topic:events.public?timeToLive=172800000]
2012-08-27 10:48:59,252 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: Producer[activemq://topic:events.public?timeToLive=172800000]
2012-08-27 10:48:59,252 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
org.apache.camel.processor.interceptor.DefaultTraceEventHandler@33afbc10
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
RouteContextProcessor[TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
org.apache.camel.processor.interceptor.DefaultTraceEventHandler@33afbc10
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
RouteContextProcessor[TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]
2012-08-27 10:48:59,253 TRACE org.apache.camel.impl.DefaultShutdownStrategy
- Shutdown complete for: Consumer[activemq://queue:events]
2012-08-27 10:48:59,253 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Graceful shutdown of 1 routes completed in 5 seconds
2012-08-27 10:48:59,253 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.RouteService@3538242d
2012-08-27 10:48:59,253 DEBUG org.apache.camel.support.TimerListenerManager
- Removed TimerListener:
org.apache.camel.management.mbean.ManagedSuspendableRoute@6f3f3cc1
2012-08-27 10:48:59,253 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=routes,name="route1"
2012-08-27 10:48:59,253 DEBUG org.apache.camel.impl.RouteService - Stopping
services on route: route1
2012-08-27 10:48:59,254 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 -> Consumer[activemq://queue:events]
2012-08-27 10:48:59,254 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=consumers,name=JmsConsumer(0x3685a260)
2012-08-27 10:48:59,254 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: Consumer[activemq://queue:events]
2012-08-27 10:48:59,254 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service Consumer[activemq://queue:events]
2012-08-27 10:48:59,254 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,254 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]
2012-08-27 10:48:59,254 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]
2012-08-27 10:48:59,255 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]
2012-08-27 10:48:59,255 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,255 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]
2012-08-27 10:48:59,255 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]
2012-08-27 10:48:59,255 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]
2012-08-27 10:48:59,255 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,256 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])
2012-08-27 10:48:59,256 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])
2012-08-27 10:48:59,256 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])
2012-08-27 10:48:59,256 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,257 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]]
2012-08-27 10:48:59,257 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]]
2012-08-27 10:48:59,257 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]]
2012-08-27 10:48:59,257 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,257 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]
2012-08-27 10:48:59,258 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]
2012-08-27 10:48:59,258 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]
2012-08-27 10:48:59,258 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,258 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,259 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,259 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,259 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,259 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,260 WARN 
org.apache.camel.management.DefaultManagementLifecycleStrategy - Could not
unregister error handler:
org.apache.camel.management.mbean.ManagedErrorHandler@3b21c238 as
ErrorHandler MBean.
org.apache.camel.RuntimeCamelException:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException(ObjectHelper.java:1280)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:64)
        at
org.apache.camel.impl.DefaultRouteContext.lookup(DefaultRouteContext.java:136)
        at
org.apache.camel.builder.ErrorHandlerBuilderRef.lookupErrorHandlerBuilder(ErrorHandlerBuilderRef.java:105)
        at
org.apache.camel.management.DefaultManagementNamingStrategy.getObjectNameForErrorHandler(DefaultManagementNamingStrategy.java:140)
        at
org.apache.camel.management.ManagedManagementStrategy.getManagedObjectName(ManagedManagementStrategy.java:102)
        at
org.apache.camel.management.ManagedManagementStrategy.unmanageObject(ManagedManagementStrategy.java:135)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.unmanageObject(DefaultManagementLifecycleStrategy.java:789)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.onErrorHandlerRemove(DefaultManagementLifecycleStrategy.java:588)
        at
org.apache.camel.impl.RouteService.stopChildService(RouteService.java:333)
        at org.apache.camel.impl.RouteService.doStop(RouteService.java:212)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:74)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:98)
        at
org.apache.camel.util.ServiceHelper.stopService(ServiceHelper.java:112)
        at
org.apache.camel.util.ServiceHelper.stopAndShutdownService(ServiceHelper.java:158)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1686)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1711)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1699)
        at
org.apache.camel.impl.DefaultCamelContext.doStop(DefaultCamelContext.java:1569)
        at
org.apache.camel.support.ServiceSupport.stop(ServiceSupport.java:91)
        at
org.apache.camel.core.xml.AbstractCamelContextFactoryBean.destroy(AbstractCamelContextFactoryBean.java:421)
        at
org.springframework.beans.factory.support.DisposableBeanAdapter.destroy(DisposableBeanAdapter.java:211)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroyBean(DefaultSingletonBeanRegistry.java:498)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingleton(DefaultSingletonBeanRegistry.java:474)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingletons(DefaultSingletonBeanRegistry.java:442)
        at
org.springframework.context.support.AbstractApplicationContext.destroyBeans(AbstractApplicationContext.java:1066)
        at
org.springframework.context.support.AbstractApplicationContext.doClose(AbstractApplicationContext.java:1040)
        at
org.springframework.context.support.AbstractApplicationContext.close(AbstractApplicationContext.java:988)
        at
org.springframework.web.context.ContextLoader.closeWebApplicationContext(ContextLoader.java:556)
        at
org.springframework.web.context.ContextLoaderListener.contextDestroyed(ContextLoaderListener.java:142)
        at
org.eclipse.jetty.server.handler.ContextHandler.doStop(ContextHandler.java:806)
        at
org.eclipse.jetty.servlet.ServletContextHandler.doStop(ServletContextHandler.java:153)
        at
org.eclipse.jetty.webapp.WebAppContext.doStop(WebAppContext.java:478)
        at
org.mortbay.jetty.plugin.JettyWebAppContext.doStop(JettyWebAppContext.java:264)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerWrapper.doStop(HandlerWrapper.java:102)
        at org.eclipse.jetty.server.Server.doStop(Server.java:324)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.util.thread.ShutdownThread.run(ShutdownThread.java:124)
Caused by:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:212)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:291)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:197)
        at
org.springframework.context.support.AbstractApplicationContext.getBean(AbstractApplicationContext.java:1097)
        at
org.apache.camel.spring.spi.ApplicationContextRegistry.lookup(ApplicationContextRegistry.java:43)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:62)
        ... 41 more
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,262 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,262 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,263 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,263 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]
2012-08-27 10:48:59,263 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,263 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,263 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])]
2012-08-27 10:48:59,264 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,264 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])
2012-08-27 10:48:59,264 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: ProducerCache for source:
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]),
capacity: 1
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service ProducerCache for source:
sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]),
capacity: 1
2012-08-27 10:48:59,264 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,264 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,264 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]
2012-08-27 10:48:59,264 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,264 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])
2012-08-27 10:48:59,265 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])
2012-08-27 10:48:59,265 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])
2012-08-27 10:48:59,265 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,265 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: ProducerCache for source:
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000]),
capacity: 1
2012-08-27 10:48:59,265 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service ProducerCache for source:
sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000]),
capacity: 1
2012-08-27 10:48:59,265 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,265 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]
2012-08-27 10:48:59,265 WARN 
org.apache.camel.management.DefaultManagementLifecycleStrategy - Could not
unregister error handler:
org.apache.camel.management.mbean.ManagedErrorHandler@3e2790e0 as
ErrorHandler MBean.
org.apache.camel.RuntimeCamelException:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException(ObjectHelper.java:1280)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:64)
        at
org.apache.camel.impl.DefaultRouteContext.lookup(DefaultRouteContext.java:136)
        at
org.apache.camel.builder.ErrorHandlerBuilderRef.lookupErrorHandlerBuilder(ErrorHandlerBuilderRef.java:105)
        at
org.apache.camel.management.DefaultManagementNamingStrategy.getObjectNameForErrorHandler(DefaultManagementNamingStrategy.java:140)
        at
org.apache.camel.management.ManagedManagementStrategy.getManagedObjectName(ManagedManagementStrategy.java:102)
        at
org.apache.camel.management.ManagedManagementStrategy.unmanageObject(ManagedManagementStrategy.java:135)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.unmanageObject(DefaultManagementLifecycleStrategy.java:789)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.onErrorHandlerRemove(DefaultManagementLifecycleStrategy.java:588)
        at
org.apache.camel.impl.RouteService.stopChildService(RouteService.java:333)
        at org.apache.camel.impl.RouteService.doStop(RouteService.java:212)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:74)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:98)
        at
org.apache.camel.util.ServiceHelper.stopService(ServiceHelper.java:112)
        at
org.apache.camel.util.ServiceHelper.stopAndShutdownService(ServiceHelper.java:158)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1686)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1711)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1699)
        at
org.apache.camel.impl.DefaultCamelContext.doStop(DefaultCamelContext.java:1569)
        at
org.apache.camel.support.ServiceSupport.stop(ServiceSupport.java:91)
        at
org.apache.camel.core.xml.AbstractCamelContextFactoryBean.destroy(AbstractCamelContextFactoryBean.java:421)
        at
org.springframework.beans.factory.support.DisposableBeanAdapter.destroy(DisposableBeanAdapter.java:211)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroyBean(DefaultSingletonBeanRegistry.java:498)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingleton(DefaultSingletonBeanRegistry.java:474)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingletons(DefaultSingletonBeanRegistry.java:442)
        at
org.springframework.context.support.AbstractApplicationContext.destroyBeans(AbstractApplicationContext.java:1066)
        at
org.springframework.context.support.AbstractApplicationContext.doClose(AbstractApplicationContext.java:1040)
        at
org.springframework.context.support.AbstractApplicationContext.close(AbstractApplicationContext.java:988)
        at
org.springframework.web.context.ContextLoader.closeWebApplicationContext(ContextLoader.java:556)
        at
org.springframework.web.context.ContextLoaderListener.contextDestroyed(ContextLoaderListener.java:142)
        at
org.eclipse.jetty.server.handler.ContextHandler.doStop(ContextHandler.java:806)
        at
org.eclipse.jetty.servlet.ServletContextHandler.doStop(ServletContextHandler.java:153)
        at
org.eclipse.jetty.webapp.WebAppContext.doStop(WebAppContext.java:478)
        at
org.mortbay.jetty.plugin.JettyWebAppContext.doStop(JettyWebAppContext.java:264)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerWrapper.doStop(HandlerWrapper.java:102)
        at org.eclipse.jetty.server.Server.doStop(Server.java:324)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.util.thread.ShutdownThread.run(ShutdownThread.java:124)
Caused by:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:212)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:291)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:197)
        at
org.springframework.context.support.AbstractApplicationContext.getBean(AbstractApplicationContext.java:1097)
        at
org.apache.camel.spring.spi.ApplicationContextRegistry.lookup(ApplicationContextRegistry.java:43)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:62)
        ... 41 more
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: TraceInterceptor[Transacted[ref:PROPAGATION_REQUIRED]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,266 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]
2012-08-27 10:48:59,266 WARN 
org.apache.camel.management.DefaultManagementLifecycleStrategy - Could not
unregister error handler:
org.apache.camel.management.mbean.ManagedErrorHandler@3f72b08 as
ErrorHandler MBean.
org.apache.camel.RuntimeCamelException:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException(ObjectHelper.java:1280)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:64)
        at
org.apache.camel.impl.DefaultRouteContext.lookup(DefaultRouteContext.java:136)
        at
org.apache.camel.builder.ErrorHandlerBuilderRef.lookupErrorHandlerBuilder(ErrorHandlerBuilderRef.java:105)
        at
org.apache.camel.management.DefaultManagementNamingStrategy.getObjectNameForErrorHandler(DefaultManagementNamingStrategy.java:140)
        at
org.apache.camel.management.ManagedManagementStrategy.getManagedObjectName(ManagedManagementStrategy.java:102)
        at
org.apache.camel.management.ManagedManagementStrategy.unmanageObject(ManagedManagementStrategy.java:135)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.unmanageObject(DefaultManagementLifecycleStrategy.java:789)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.onErrorHandlerRemove(DefaultManagementLifecycleStrategy.java:588)
        at
org.apache.camel.impl.RouteService.stopChildService(RouteService.java:333)
        at org.apache.camel.impl.RouteService.doStop(RouteService.java:212)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:74)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:98)
        at
org.apache.camel.util.ServiceHelper.stopService(ServiceHelper.java:112)
        at
org.apache.camel.util.ServiceHelper.stopAndShutdownService(ServiceHelper.java:158)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1686)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1711)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1699)
        at
org.apache.camel.impl.DefaultCamelContext.doStop(DefaultCamelContext.java:1569)
        at
org.apache.camel.support.ServiceSupport.stop(ServiceSupport.java:91)
        at
org.apache.camel.core.xml.AbstractCamelContextFactoryBean.destroy(AbstractCamelContextFactoryBean.java:421)
        at
org.springframework.beans.factory.support.DisposableBeanAdapter.destroy(DisposableBeanAdapter.java:211)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroyBean(DefaultSingletonBeanRegistry.java:498)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingleton(DefaultSingletonBeanRegistry.java:474)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingletons(DefaultSingletonBeanRegistry.java:442)
        at
org.springframework.context.support.AbstractApplicationContext.destroyBeans(AbstractApplicationContext.java:1066)
        at
org.springframework.context.support.AbstractApplicationContext.doClose(AbstractApplicationContext.java:1040)
        at
org.springframework.context.support.AbstractApplicationContext.close(AbstractApplicationContext.java:988)
        at
org.springframework.web.context.ContextLoader.closeWebApplicationContext(ContextLoader.java:556)
        at
org.springframework.web.context.ContextLoaderListener.contextDestroyed(ContextLoaderListener.java:142)
        at
org.eclipse.jetty.server.handler.ContextHandler.doStop(ContextHandler.java:806)
        at
org.eclipse.jetty.servlet.ServletContextHandler.doStop(ServletContextHandler.java:153)
        at
org.eclipse.jetty.webapp.WebAppContext.doStop(WebAppContext.java:478)
        at
org.mortbay.jetty.plugin.JettyWebAppContext.doStop(JettyWebAppContext.java:264)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerWrapper.doStop(HandlerWrapper.java:102)
        at org.eclipse.jetty.server.Server.doStop(Server.java:324)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.util.thread.ShutdownThread.run(ShutdownThread.java:124)
Caused by:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:212)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:291)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:197)
        at
org.springframework.context.support.AbstractApplicationContext.getBean(AbstractApplicationContext.java:1097)
        at
org.apache.camel.spring.spi.ApplicationContextRegistry.lookup(ApplicationContextRegistry.java:43)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:62)
        ... 41 more
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]
2012-08-27 10:48:59,266 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]]
2012-08-27 10:48:59,267 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]
2012-08-27 10:48:59,267 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]
2012-08-27 10:48:59,267 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,267 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]
2012-08-27 10:48:59,267 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
TraceInterceptor[To[bean:dummyConsumer?method=onMessage(${body})]]
2012-08-27 10:48:59,267 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,267 DEBUG org.apache.camel.impl.RouteService - Shutting
down child service on route: route1 ->
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]
2012-08-27 10:48:59,267 WARN 
org.apache.camel.management.DefaultManagementLifecycleStrategy - Could not
unregister error handler:
org.apache.camel.management.mbean.ManagedErrorHandler@3323eac8 as
ErrorHandler MBean.
org.apache.camel.RuntimeCamelException:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.apache.camel.util.ObjectHelper.wrapRuntimeCamelException(ObjectHelper.java:1280)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:64)
        at
org.apache.camel.impl.DefaultRouteContext.lookup(DefaultRouteContext.java:136)
        at
org.apache.camel.builder.ErrorHandlerBuilderRef.lookupErrorHandlerBuilder(ErrorHandlerBuilderRef.java:105)
        at
org.apache.camel.management.DefaultManagementNamingStrategy.getObjectNameForErrorHandler(DefaultManagementNamingStrategy.java:140)
        at
org.apache.camel.management.ManagedManagementStrategy.getManagedObjectName(ManagedManagementStrategy.java:102)
        at
org.apache.camel.management.ManagedManagementStrategy.unmanageObject(ManagedManagementStrategy.java:135)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.unmanageObject(DefaultManagementLifecycleStrategy.java:789)
        at
org.apache.camel.management.DefaultManagementLifecycleStrategy.onErrorHandlerRemove(DefaultManagementLifecycleStrategy.java:588)
        at
org.apache.camel.impl.RouteService.stopChildService(RouteService.java:333)
        at org.apache.camel.impl.RouteService.doStop(RouteService.java:212)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:74)
        at
org.apache.camel.support.ChildServiceSupport.stop(ChildServiceSupport.java:98)
        at
org.apache.camel.util.ServiceHelper.stopService(ServiceHelper.java:112)
        at
org.apache.camel.util.ServiceHelper.stopAndShutdownService(ServiceHelper.java:158)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1686)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1711)
        at
org.apache.camel.impl.DefaultCamelContext.shutdownServices(DefaultCamelContext.java:1699)
        at
org.apache.camel.impl.DefaultCamelContext.doStop(DefaultCamelContext.java:1569)
        at
org.apache.camel.support.ServiceSupport.stop(ServiceSupport.java:91)
        at
org.apache.camel.core.xml.AbstractCamelContextFactoryBean.destroy(AbstractCamelContextFactoryBean.java:421)
        at
org.springframework.beans.factory.support.DisposableBeanAdapter.destroy(DisposableBeanAdapter.java:211)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroyBean(DefaultSingletonBeanRegistry.java:498)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingleton(DefaultSingletonBeanRegistry.java:474)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.destroySingletons(DefaultSingletonBeanRegistry.java:442)
        at
org.springframework.context.support.AbstractApplicationContext.destroyBeans(AbstractApplicationContext.java:1066)
        at
org.springframework.context.support.AbstractApplicationContext.doClose(AbstractApplicationContext.java:1040)
        at
org.springframework.context.support.AbstractApplicationContext.close(AbstractApplicationContext.java:988)
        at
org.springframework.web.context.ContextLoader.closeWebApplicationContext(ContextLoader.java:556)
        at
org.springframework.web.context.ContextLoaderListener.contextDestroyed(ContextLoaderListener.java:142)
        at
org.eclipse.jetty.server.handler.ContextHandler.doStop(ContextHandler.java:806)
        at
org.eclipse.jetty.servlet.ServletContextHandler.doStop(ServletContextHandler.java:153)
        at
org.eclipse.jetty.webapp.WebAppContext.doStop(WebAppContext.java:478)
        at
org.mortbay.jetty.plugin.JettyWebAppContext.doStop(JettyWebAppContext.java:264)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerCollection.doStop(HandlerCollection.java:245)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.server.handler.HandlerWrapper.doStop(HandlerWrapper.java:102)
        at org.eclipse.jetty.server.Server.doStop(Server.java:324)
        at
org.eclipse.jetty.util.component.AbstractLifeCycle.stop(AbstractLifeCycle.java:84)
        at
org.eclipse.jetty.util.thread.ShutdownThread.run(ShutdownThread.java:124)
Caused by:
org.springframework.beans.factory.BeanCreationNotAllowedException: Error
creating bean with name 'camelErrorHandler': Singleton bean creation not
allowed while the singletons of this factory are in destruction (Do not
request a bean from a BeanFactory in a destroy method implementation!)
        at
org.springframework.beans.factory.support.DefaultSingletonBeanRegistry.getSingleton(DefaultSingletonBeanRegistry.java:212)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.doGetBean(AbstractBeanFactory.java:291)
        at
org.springframework.beans.factory.support.AbstractBeanFactory.getBean(AbstractBeanFactory.java:197)
        at
org.springframework.context.support.AbstractApplicationContext.getBean(AbstractApplicationContext.java:1097)
        at
org.apache.camel.spring.spi.ApplicationContextRegistry.lookup(ApplicationContextRegistry.java:43)
        at
org.apache.camel.impl.PropertyPlaceholderDelegateRegistry.lookup(PropertyPlaceholderDelegateRegistry.java:62)
        ... 41 more
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
TransactionErrorHandler:PROPAGATION_REQUIRED[TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped:
TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service:
TraceInterceptor[To[activemq:topic:events.public?timeToLive=172800000]]
2012-08-27 10:48:59,268 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,268 TRACE org.apache.camel.util.ServiceHelper - Stopping
service EventDrivenConsumerRoute[Endpoint[activemq://queue:events] ->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]]
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: EventDrivenConsumerRoute[Endpoint[activemq://queue:events] ->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]]
2012-08-27 10:48:59,269 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.RouteService@3538242d
2012-08-27 10:48:59,269 DEBUG org.apache.camel.impl.RouteService - Shutting
down services on route: route1
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: EventDrivenConsumerRoute[Endpoint[activemq://queue:events]
->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]]
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: EventDrivenConsumerRoute[Endpoint[activemq://queue:events] ->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]]
2012-08-27 10:48:59,269 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Endpoint[activemq://queue:events]
2012-08-27 10:48:59,269 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service: Endpoint[activemq://queue:events]
2012-08-27 10:48:59,269 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,270 TRACE
org.apache.camel.management.DefaultManagementLifecycleStrategy - The route
is not managed: EventDrivenConsumerRoute[Endpoint[activemq://queue:events]
->
Instrumentation:route[DelegateAsync[UnitOfWork(RouteContextProcessor[Channel[Wrap[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]
->
TransactionErrorHandler:PROPAGATION_REQUIRED[Pipeline[[Channel[sendTo(Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29])],
Channel[sendTo(Endpoint[activemq://topic:events.public?timeToLive=172800000])]]]]]])]]]
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Endpoint[spring-event://default]
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service Endpoint[spring-event://default]
2012-08-27 10:48:59,270 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
Endpoint[bean://dummyConsumer?method=onMessage%28%24%7Bbody%7D%29]
2012-08-27 10:48:59,270 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Stopping
service Endpoint[activemq://topic:events.public?timeToLive=172800000]
2012-08-27 10:48:59,270 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service Endpoint[activemq://topic:events.public?timeToLive=172800000]
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: Endpoint[activemq://queue:events]
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service Endpoint[activemq://queue:events]
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.component.event.EventComponent@72ba1044
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.component.event.EventComponent@72ba1044
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.component.properties.PropertiesComponent@76ccb606
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
org.apache.camel.component.properties.PropertiesComponent@76ccb606
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.activemq.camel.component.ActiveMQComponent@6f213028
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.activemq.camel.component.ActiveMQComponent@6f213028
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.component.bean.BeanComponent@57308da3
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.component.bean.BeanComponent@57308da3
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 DEBUG org.apache.camel.support.TimerListenerManager
- Removed TimerListener:
org.apache.camel.management.mbean.ManagedCamelContext@79c280d8
2012-08-27 10:48:59,271 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=context,name="camel"
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.DefaultPackageScanClassResolver@3baf5ea4
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.DefaultPackageScanClassResolver@3baf5ea4
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.DefaultShutdownStrategy@21f7915d
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.DefaultShutdownStrategy@21f7915d
2012-08-27 10:48:59,271 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,271 DEBUG
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableThreadPoolExecutor@4b4cc541[Running,
pool size = 1, active threads = 0, queued tasks = 0, completed tasks = 1]
2012-08-27 10:48:59,271 TRACE
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableThreadPoolExecutor@4b4cc541[Shutting
down, pool size = 1, active threads = 0, queued tasks = 0, completed tasks =
1] complete.
2012-08-27 10:48:59,271 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.DefaultInflightRepository@45b9b5e5
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.impl.DefaultInflightRepository - Shutting down with no
inflight exchanges.
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.DefaultInflightRepository@45b9b5e5
2012-08-27 10:48:59,272 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Service
already stopped: org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,272 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.impl.SharedProducerServicePool - Stopping service pool:
org.apache.camel.impl.SharedProducerServicePool@c8c681b
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.DefaultExecutorServiceManager@63eb32ed
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.DefaultExecutorServiceManager@63eb32ed
2012-08-27 10:48:59,272 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor@6b7cc370[Running,
pool size = 1, active threads = 0, queued tasks = 1, completed tasks = 16]
2012-08-27 10:48:59,272 TRACE
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor@6b7cc370[Shutting
down, pool size = 1, active threads = 0, queued tasks = 0, completed tasks =
16] complete.
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor@5679a244[Running,
pool size = 0, active threads = 0, queued tasks = 0, completed tasks = 0]
2012-08-27 10:48:59,272 TRACE
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService:
org.apache.camel.util.concurrent.RejectableScheduledThreadPoolExecutor@5679a244[Terminated,
pool size = 0, active threads = 0, queued tasks = 0, completed tasks = 0]
complete.
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService: java.util.concurrent.ThreadPoolExecutor@7f676896[Running,
pool size = 1, active threads = 0, queued tasks = 0, completed tasks = 1]
2012-08-27 10:48:59,272 TRACE
org.apache.camel.impl.DefaultExecutorServiceManager - ShutdownNow
ExecutorService: java.util.concurrent.ThreadPoolExecutor@7f676896[Shutting
down, pool size = 1, active threads = 0, queued tasks = 0, completed tasks =
1] complete.
2012-08-27 10:48:59,272 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=threadpools,name="JmsConsumer(0x3685a260)"
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Stopping
service EndpointRegistry for camel, capacity: 1000
2012-08-27 10:48:59,272 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.impl.converter.DefaultTypeConverter@58839e6e
2012-08-27 10:48:59,273 INFO 
org.apache.camel.impl.converter.DefaultTypeConverter - TypeConverterRegistry
utilization[attempts=43, hits=43, misses=0, failures=0] mappings[total=173,
misses=0]
2012-08-27 10:48:59,273 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service org.apache.camel.impl.converter.DefaultTypeConverter@58839e6e
2012-08-27 10:48:59,273 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,273 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.management.ManagedManagementStrategy@29167528
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=SharedProducerServicePool(0xc8c681b)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=tracer,name=Tracer(0x2dc0d543)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=errorhandlers,name="TransactionErrorHandlerBuilder(ref:camelErrorHandler)"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=DefaultExecutorServiceManager(0x63eb32ed)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=DefaultPackageScanClassResolver(0x3baf5ea4)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=EndpointRegistry(0x3c224837)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=threadpools,name="SpringCamelContext(0x2c832710)"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=DefaultShutdownStrategy(0x21f7915d)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=components,name="activemq"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=services,name=DefaultInflightRepository(0x45b9b5e5)
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=processors,name="to1"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=endpoints,name="spring-event://default"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=processors,name="to2"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=endpoints,name="bean://dummyConsumer\?method=onMessage%28%24%7Bbody%7D%29"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=components,name="bean"
2012-08-27 10:48:59,273 DEBUG
org.apache.camel.management.DefaultManagementAgent - Unregistered MBean with
ObjectName:
org.apache.camel:context=tjock-xxl/camel,type=endpoints,name="activemq://queue:events"
2012-08-27 10:48:59,273 TRACE org.apache.camel.util.ServiceHelper - Stopping
service
org.apache.camel.management.DefaultManagementLifecycleStrategy@3aa4195b
2012-08-27 10:48:59,273 TRACE org.apache.camel.util.ServiceHelper - Stopping
service org.apache.camel.support.TimerListenerManager@165aa2b
2012-08-27 10:48:59,274 TRACE org.apache.camel.util.ServiceHelper - Shutting
down service
org.apache.camel.management.DefaultManagementLifecycleStrategy@3aa4195b
2012-08-27 10:48:59,274 TRACE org.apache.camel.support.ServiceSupport -
Service already stopped
2012-08-27 10:48:59,274 INFO  org.apache.camel.spring.SpringCamelContext -
Apache Camel 2.10.0 (CamelContext: camel) is shutdown in 5.435 seconds.
Uptime 16.282 seconds.
2012-08-27 10:48:59,274 INFO  org.apache.activemq.broker.BrokerService -
ActiveMQ Message Broker (localhost, ID:tjock-xxl-41895-1346057322482-0:1) is
shutting down
2012-08-27 10:49:00,083 INFO  org.apache.activemq.broker.TransportConnector
- Connector tcp://localhost:61616 Stopped
2012-08-27 10:49:00,638 INFO  org.apache.activemq.broker.TransportConnector
- Connector stomp://localhost:61613 Stopped
2012-08-27 10:49:00,638 DEBUG
org.apache.activemq.transport.vm.VMTransportFactory - Shutting down VM
connectors for broker: localhost
2012-08-27 10:49:00,638 DEBUG org.apache.activemq.broker.TransportConnection
- Stopping connection: vm://localhost#0
2012-08-27 10:49:00,639 DEBUG org.apache.activemq.broker.TransportConnection
- Stopped transport: vm://localhost#0
2012-08-27 10:49:00,639 DEBUG org.apache.activemq.broker.TransportConnection
- Cleaning up connection resources: vm://localhost#0
2012-08-27 10:49:00,639 DEBUG org.apache.activemq.broker.TransportConnection
- remove connection id: ID:tjock-xxl-41895-1346057322482-3:1
2012-08-27 10:49:00,639 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost removing
consumer: ID:tjock-xxl-41895-1346057322482-3:1:-1:1 for destination:
ActiveMQ.Advisory.TempQueue,ActiveMQ.Advisory.TempTopic
2012-08-27 10:49:00,639 DEBUG org.apache.activemq.broker.TransportConnection
- Connection Stopped: vm://localhost#0
2012-08-27 10:49:00,640 INFO  org.apache.activemq.broker.TransportConnector
- Connector vm://localhost Stopped
2012-08-27 10:49:00,642 INFO 
org.apache.activemq.store.kahadb.plist.PListStore -
PListStore:[/home/w/Private/source/odobo/odobo-hg/server/integration/databank/operator-service/activemq-data/localhost/tmp_storage
] stopped
2012-08-27 10:49:00,653 INFO  org.apache.activemq.broker.BrokerService -
ActiveMQ JMS Message Broker (localhost,
ID:tjock-xxl-41895-1346057322482-0:1) stopped
2012-08-27 10:49:00.658:INFO:oejsl.ELContextCleaner:javax.el.BeanELResolver
purged
2012-08-27 10:49:00.658:INFO:oejsh.ContextHandler:stopped
o.m.j.p.JettyWebAppContext{/,file:/home/w/Private/source/odobo/odobo-hg/server/integration/databank/operator-service/src/main/webapp/},file:/home/w/Private/source/odobo/odobo-hg/server/integration/databank/operator-service/src/main/webapp/

 





--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718141.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

I created an unit test trying to reproduce an issue
http://svn.apache.org/viewvc?rev=1378526&view=rev

It works for me. I start up a remote AMQ broker first. In this case
Apache ActiveMQ 5.6.0.
Running the test ensures the message is rolled back, and using the AMQ
web console I can see the message starts on the queue.


-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

The log file cannot be downloaded from that link.



On Mon, Aug 27, 2012 at 11:41 AM, towe <to...@cubeia.com> wrote:
> I get an "onMessage START" and an "onMessage END" on each properly consumed
> message.
>
> For a message throwing an exception I get the "START" first, then no trace
> from the EndpointMessageListener as long as Camel tries to redeliver and
> finally the "END" when graceful shutdown has kicked in.
>
> Another anomalous thing that happens is that during shutdown, after the
> "END", Spring tries to create an error handler bean but fails as the context
> is in destruction. This might be completely unrelated but it is shown in the
> attached logs.
>
> Full log:
> http://camel.465427.n5.nabble.com/file/n5718129/activemq-camel-shutdown.log
> activemq-camel-shutdown.log
>
>
> Claus Ibsen-2 wrote
>>
>> If you enable TRACE logging on
>> org.apache.camel.component.jms.EndpointMessageListener
>>
>> Then the onMessage method (which is invoked when a msg is consumed)
>> has TRACE logging.
>> Can you see if you get a begin + end logs for each message.
>>
>
> /tw
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718129.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
I get an "onMessage START" and an "onMessage END" on each properly consumed
message.

For a message throwing an exception I get the "START" first, then no trace
from the EndpointMessageListener as long as Camel tries to redeliver and
finally the "END" when graceful shutdown has kicked in.

Another anomalous thing that happens is that during shutdown, after the
"END", Spring tries to create an error handler bean but fails as the context
is in destruction. This might be completely unrelated but it is shown in the
attached logs.

Full log: 
http://camel.465427.n5.nabble.com/file/n5718129/activemq-camel-shutdown.log
activemq-camel-shutdown.log 


Claus Ibsen-2 wrote
> 
> If you enable TRACE logging on
> org.apache.camel.component.jms.EndpointMessageListener
> 
> Then the onMessage method (which is invoked when a msg is consumed)
> has TRACE logging.
> Can you see if you get a begin + end logs for each message.
> 

/tw



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718129.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
If you enable TRACE logging on
org.apache.camel.component.jms.EndpointMessageListener

Then the onMessage method (which is invoked when a msg is consumed)
has TRACE logging.
Can you see if you get a begin + end logs for each message.

It may be that the broker does not get any rollback commands for the
message when Camel is forcing shutdown.
Which means the broker may think the message is inflight. It ought
however to know the message is no longer in-flight,
when the consumer is no longer active.

Anyway the TRACE logging may help a bit to see what goes on.

There is

On Mon, Aug 27, 2012 at 10:32 AM, towe <to...@cubeia.com> wrote:
> Hi,
>
> Nope, didn't make a difference. Exactly the same behaviour as before.
>
> /tw
>
>
> Claus Ibsen-2 wrote
>>
>> Try removing your     <onException> which has that mark rollback only.
>>
>> Spring JMS is a bit weird when it comes to marking a TX as rollback.
>> It tends to prefer a runtime exception being thrown over marking the
>> TX explicit as rollback only.
>>
>
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718117.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Hi,

Nope, didn't make a difference. Exactly the same behaviour as before.

/tw


Claus Ibsen-2 wrote
> 
> Try removing your     <onException> which has that mark rollback only.
> 
> Spring JMS is a bit weird when it comes to marking a TX as rollback.
> It tends to prefer a runtime exception being thrown over marking the
> TX explicit as rollback only.
> 




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718117.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

Try removing your     <onException> which has that mark rollback only.

Spring JMS is a bit weird when it comes to marking a TX as rollback.
It tends to prefer a runtime exception being thrown over marking the
TX explicit as rollback only.



On Mon, Aug 27, 2012 at 10:12 AM, towe <to...@cubeia.com> wrote:
> Hello,
>
> They don't end up in the DLQ in this case. :-(
>
> If I set maximumRedeliveries on the error handler to 5, for example, the
> messages will end up in the DLQ. But in my case I have maximum deliveries
> set to -1 (unlimited) and the timeout of the DefaultShutdownStrategy set to
> 5 seconds.
>
> When stopping the application by ctrl+c the message is completely gone after
> the 5s timeout.
>
> The only workaround so far is to set the timeout to -1. That will force the
> shutdown to keep trying forever. The application now needs to be killed the
> hard way, but at least the message is not lost. Unfortunately this means
> that hot-redeploy in an application server won't work.
>
> /tw
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718112.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Hello,

They don't end up in the DLQ in this case. :-(

If I set maximumRedeliveries on the error handler to 5, for example, the
messages will end up in the DLQ. But in my case I have maximum deliveries
set to -1 (unlimited) and the timeout of the DefaultShutdownStrategy set to
5 seconds.

When stopping the application by ctrl+c the message is completely gone after
the 5s timeout. 

The only workaround so far is to set the timeout to -1. That will force the
shutdown to keep trying forever. The application now needs to be killed the
hard way, but at least the message is not lost. Unfortunately this means
that hot-redeploy in an application server won't work. 

/tw



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5718112.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Babak Vahdat <ba...@swissonline.ch>.
Hi

and have you already checked the content of the dead letter queue? It's name
per default is "ActiveMQ.DLQ"?

Babak




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717993.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Upgraded to 2.10.0 but unfortunately the problem is still there. :-(

Message gone after graceful shutdown but left if process killed.




Claus Ibsen-2 wrote
> 
> Okay you need to upgrade to Camel 2.10 as we have improve the graceful
> shutdown
> * Graceful Shutdown is now more aggressive if timeout occurred during
> shutdown, rejecting continued processing of messages or redeliveries.
> http://camel.apache.org/camel-2100-release.html
> 




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717963.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

Okay you need to upgrade to Camel 2.10 as we have improve the graceful shutdown
* Graceful Shutdown is now more aggressive if timeout occurred during
shutdown, rejecting continued processing of messages or redeliveries.
http://camel.apache.org/camel-2100-release.html

I can't remember if we have backported the to the upcoming 2.9.3
release. We may have though, so if you are stuck on the 2.9 branch,
then you can try the 2.9.3-SNAPSHOT in the mean time.

Or wait a bit for the 2.9.3 to be released.



On Thu, Aug 23, 2012 at 4:54 PM, towe <to...@cubeia.com> wrote:
> Camel: 2.9.2
> ActiveMQ: 5.6.0
> Spring: 3.1.1
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717949.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Camel: 2.9.2
ActiveMQ: 5.6.0
Spring: 3.1.1



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717949.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
What version of Camel are you using?



On Thu, Aug 23, 2012 at 4:45 PM, towe <to...@cubeia.com> wrote:
>
> While Camel running the route and continuously rolling back and trying to
> redeliver. If I:
> 1. ctrl+c: graceful shutdown, message gone :-(
> 2. kill -9: process killed, message left in queue!
>
> This leads me to think that something in the graceful shutdown procedure
> removes the message. I can't see any config options to change this.
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717947.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
While Camel running the route and continuously rolling back and trying to
redeliver. If I:
1. ctrl+c: graceful shutdown, message gone :-(
2. kill -9: process killed, message left in queue!

This leads me to think that something in the graceful shutdown procedure
removes the message. I can't see any config options to change this. 



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717947.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
I am using transacted mode. But if I stop Camel during redelivery while the
queue on B is down the message gets removed from the queue and is gone when
I restart. 

To simulate an error I have a dummy consumer that throws an exception, but
the problem is the same if I have a remote queue that is shut down.

This is my Camel route (some beans left out for clarity):

  [...]

  <bean id="jmsConfig" 
     class="org.apache.camel.component.jms.JmsConfiguration">
     <property name="connectionFactory" ref="poolConnectionFactory"/>
     <property name="transactionManager" ref="jmsTransactionManager"/>
     <property name="transacted" value="true"/>
     <property name="concurrentConsumers" value="1"/>
  </bean>
  
  <bean id="jmsTransactionManager"
class="org.springframework.jms.connection.JmsTransactionManager">
    <property name="connectionFactory" ref="poolConnectionFactory" />
  </bean>
    
  <bean id="activemq"
class="org.apache.activemq.camel.component.ActiveMQComponent">
      <property name="configuration" ref="jmsConfig"/>
  </bean>  

  <camelContext id="camel" xmlns="http://camel.apache.org/schema/spring">
    <errorHandler id="camelErrorHandler">
      <redeliveryPolicy maximumRedeliveries="-1" />
    </errorHandler>
    
    <onException>
        <exception>java.lang.Exception</exception>
        <rollback  markRollbackOnly="true" />    
    </onException>

    <route errorHandlerRef="camelErrorHandler"
shutdownRunningTask="CompleteCurrentTaskOnly">
      <from uri="activemq:queue:events" />
      <transacted ref="PROPAGATION_REQUIRED"/>
      <to uri="bean:dummyConsumer?method=onMessage(${body})"/>
    </route>
  </camelContext>
  [...]


When shutting down I get the log below. The log basically says that it is
waiting for an in-flight message left, then when it times out it forces a
shutdown.

--------------------------------------
2012-08-23 15:19:47,132 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Waiting as there are still 1 inflight and pending exchanges to complete,
timeout in 1 seconds.
2012-08-23 15:19:47,661 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage($%7Bbody%7D)]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-41399-1345727978381-1:1:1:1:1]]

--- DUMMY CONSUMER, message: message 1345727978573

2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.DefaultErrorHandler
- Failed delivery for (MessageId: ID:tjock-xxl-41399-1345727978381-1:1:1:1:1
on ExchangeId: ID-tjock-xxl-57097-1345727966790-0-1). On delivery attempt: 9
caught: java.lang.RuntimeException: test error
2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.DefaultErrorHandler
- Redelivery delay calculated as 1000
2012-08-23 15:19:47,663 DEBUG org.apache.camel.processor.RedeliveryPolicy -
Sleeping for: 1000 millis until attempting redelivery
2012-08-23 15:19:48,130 WARN  org.apache.camel.impl.DefaultShutdownStrategy
- Timeout occurred. Now forcing the routes to be shutdown now.
2012-08-23 15:19:48,130 WARN  org.apache.camel.impl.DefaultShutdownStrategy
- Interrupted while waiting during graceful shutdown, will force shutdown
now.
2012-08-23 15:19:48,663 DEBUG org.apache.camel.processor.SendProcessor -
>>>> Endpoint[bean://dummyConsumer?method=onMessage($%7Bbody%7D)]
Exchange[JmsMessage[JmsMessageID:
ID:tjock-xxl-41399-1345727978381-1:1:1:1:1]]

--- DUMMY CONSUMER, message: message 1345727978573

2012-08-23 15:19:48,665 WARN 
org.apache.camel.spring.spi.TransactionErrorHandler - Transaction rollback
(0x8996666) redelivered(false) for (MessageId:
ID:tjock-xxl-41399-1345727978381-1:1:1:1:1 on ExchangeId:
ID-tjock-xxl-57097-1345727966790-0-1) caught: java.lang.RuntimeException:
test error
2012-08-23 15:19:48,666 DEBUG org.apache.activemq.ActiveMQSession -
ID:tjock-xxl-46934-1345727966509-3:1:1 Transaction Rollback,
txid:TX:ID:tjock-xxl-46934-1345727966509-3:1:1
2012-08-23 15:19:48,666 DEBUG org.apache.activemq.TransactionContext -
Rollback: TX:ID:tjock-xxl-46934-1345727966509-3:1:1 syncCount: 2
2012-08-23 15:19:48,668 DEBUG
org.apache.activemq.transaction.LocalTransaction - rollback:
TX:ID:tjock-xxl-46934-1345727966509-3:1:1 syncCount: 2
2012-08-23 15:19:48,669 DEBUG org.apache.activemq.ActiveMQMessageConsumer -
remove: ID:tjock-xxl-46934-1345727966509-3:1:1:12,
lastDeliveredSequenceId:31
2012-08-23 15:19:48,669 DEBUG org.apache.activemq.ActiveMQSession -
ID:tjock-xxl-46934-1345727966509-3:1:1 Transaction Rollback, txid:null
2012-08-23 15:19:48,669 DEBUG
org.apache.activemq.broker.region.AbstractRegion - localhost removing
consumer: ID:tjock-xxl-46934-1345727966509-3:1:1:12 for destination:
queue://events
2012-08-23 15:19:48,670 DEBUG org.apache.camel.component.jms.JmsConsumer -
Stopping consumer: Consumer[activemq://queue:events]
2012-08-23 15:19:48,670 DEBUG org.apache.camel.component.jms.JmsConsumer -
Stopping consumer: Consumer[activemq://queue:events]
2012-08-23 15:19:48,670 INFO  org.apache.camel.impl.DefaultShutdownStrategy
- Graceful shutdown of 1 routes completed in 5 seconds


/tw




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717944.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
On Thu, Aug 23, 2012 at 2:09 PM, towe <to...@cubeia.com> wrote:
> Hi,
>
> Not really, I want to be able to shutdown immediately (or with a small
> timeout). Any message picked up from A must be rolled back and stay in the
> queue.
>
> If I have the a of 5s Camel will keep trying to resend until timeout. Then
> it drops the message. But I want it to be left in A (as it has not been
> successfully delivered yet).
>
> Now I can't stop Camel when it is in the process of redelivering a message
> without losing it.
>

You are using the redelivery of the message broker and with transacted
ack mode of JMS,
then the message will not be lost, as its kept in the broker, also
during redelivery.



> /tw
>
>
> Claus Ibsen-2 wrote
>>
>> Hi
>>
>> You want to keep retry forever if B is down during shutdown of Camel?
>> You can set the timeout period to be 0 or a negative value. Then it
>> runs forever until it can shutdown without any inflight messages.
>> http://camel.apache.org/graceful-shutdown.html
>>
>>
>>
>> On Thu, Aug 23, 2012 at 10:56 AM, towe &lt;tobias.westerblom@&gt; wrote:
>>> I am trying to set up a camel route that forwards jms messages from one
>>> persistent (local) queue to another remote jms queue.
>>>
>>> If the remote connection is down the incoming message should be left on
>>> the
>>> in-queue.
>>>
>>> I managed to get this to work using transactions. But the problem I have
>>> now
>>> is that doing a graceful shutdown removes the in-flight messages (after
>>> timing out on the DefaultShutdownStrategy).
>>>
>>> Killing the Camel process the hard way (kill -9) preserves the messages
>>> on
>>> the queue, which is what I want.
>>>
>>> To summarize, what I want is:
>>> 1. forward from queue A to queue B
>>> 2. rollback A (leave in queue) if B is down
>>> 3. repeat trying forever
>>> 4. to be able to shutdown camel without dropping in-flight messages
>>>
>>> /tw
>>>
>>>
>>>
>>> --
>>> View this message in context:
>>> http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930.html
>>> Sent from the Camel - Users mailing list archive at Nabble.com.
>>
>>
>>
>> --
>> Claus Ibsen
>> -----------------
>> FuseSource
>> Email: cibsen@
>> Web: http://fusesource.com
>> Twitter: davsclaus, fusenews
>> Blog: http://davsclaus.com
>> Author of Camel in Action: http://www.manning.com/ibsen
>>
>
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717938.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Just clarify further:

I want to continuously poll a local queue A and forward to a remote queue B.

When B is down stuff should stay in A until B is up again.

When turning off Camel no message should be lost. And I want to be able to
shut down Camel at any time, messages in-flight should be rolled back and
stay in A.

All of the above works except from stopping Camel. The graceful shutdown
drops the last message on timeout if it is in-flight. But if I do a "kill
-9" everything is ok, no message lost. But I want to be able to stop Camel
the normal way even if B is down at the time.

/tw



--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717940.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by towe <to...@cubeia.com>.
Hi,

Not really, I want to be able to shutdown immediately (or with a small
timeout). Any message picked up from A must be rolled back and stay in the
queue.

If I have the a of 5s Camel will keep trying to resend until timeout. Then
it drops the message. But I want it to be left in A (as it has not been
successfully delivered yet). 

Now I can't stop Camel when it is in the process of redelivering a message
without losing it.

/tw


Claus Ibsen-2 wrote
> 
> Hi
> 
> You want to keep retry forever if B is down during shutdown of Camel?
> You can set the timeout period to be 0 or a negative value. Then it
> runs forever until it can shutdown without any inflight messages.
> http://camel.apache.org/graceful-shutdown.html
> 
> 
> 
> On Thu, Aug 23, 2012 at 10:56 AM, towe &lt;tobias.westerblom@&gt; wrote:
>> I am trying to set up a camel route that forwards jms messages from one
>> persistent (local) queue to another remote jms queue.
>>
>> If the remote connection is down the incoming message should be left on
>> the
>> in-queue.
>>
>> I managed to get this to work using transactions. But the problem I have
>> now
>> is that doing a graceful shutdown removes the in-flight messages (after
>> timing out on the DefaultShutdownStrategy).
>>
>> Killing the Camel process the hard way (kill -9) preserves the messages
>> on
>> the queue, which is what I want.
>>
>> To summarize, what I want is:
>> 1. forward from queue A to queue B
>> 2. rollback A (leave in queue) if B is down
>> 3. repeat trying forever
>> 4. to be able to shutdown camel without dropping in-flight messages
>>
>> /tw
>>
>>
>>
>> --
>> View this message in context:
>> http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930.html
>> Sent from the Camel - Users mailing list archive at Nabble.com.
> 
> 
> 
> -- 
> Claus Ibsen
> -----------------
> FuseSource
> Email: cibsen@
> Web: http://fusesource.com
> Twitter: davsclaus, fusenews
> Blog: http://davsclaus.com
> Author of Camel in Action: http://www.manning.com/ibsen
> 




--
View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930p5717938.html
Sent from the Camel - Users mailing list archive at Nabble.com.

Re: shutting down Camel, in-flight messages gone

Posted by Claus Ibsen <cl...@gmail.com>.
Hi

You want to keep retry forever if B is down during shutdown of Camel?
You can set the timeout period to be 0 or a negative value. Then it
runs forever until it can shutdown without any inflight messages.
http://camel.apache.org/graceful-shutdown.html



On Thu, Aug 23, 2012 at 10:56 AM, towe <to...@cubeia.com> wrote:
> I am trying to set up a camel route that forwards jms messages from one
> persistent (local) queue to another remote jms queue.
>
> If the remote connection is down the incoming message should be left on the
> in-queue.
>
> I managed to get this to work using transactions. But the problem I have now
> is that doing a graceful shutdown removes the in-flight messages (after
> timing out on the DefaultShutdownStrategy).
>
> Killing the Camel process the hard way (kill -9) preserves the messages on
> the queue, which is what I want.
>
> To summarize, what I want is:
> 1. forward from queue A to queue B
> 2. rollback A (leave in queue) if B is down
> 3. repeat trying forever
> 4. to be able to shutdown camel without dropping in-flight messages
>
> /tw
>
>
>
> --
> View this message in context: http://camel.465427.n5.nabble.com/shutting-down-Camel-in-flight-messages-gone-tp5717930.html
> Sent from the Camel - Users mailing list archive at Nabble.com.



-- 
Claus Ibsen
-----------------
FuseSource
Email: cibsen@fusesource.com
Web: http://fusesource.com
Twitter: davsclaus, fusenews
Blog: http://davsclaus.com
Author of Camel in Action: http://www.manning.com/ibsen