You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@servicemix.apache.org by robottaway <ro...@musiciansfriend.com> on 2006/09/29 04:04:51 UTC

Problem when publishing 500 messages to topic queue

So when I hit up the topic with 500 messages I get the following:

ERROR - EIPComponent                   - Error processing exchange InOnly[
  id: ID:srsprod-mfback.musiciansfriend.com-52646-1159494610099-10:375
  status: Active
  role: provider
  service: {http://www.musiciansfriend.com}pipelineXsltFilemaker
  endpoint: pipelineXsltFilemaker
  in: Unable to display: org.xml.sax.SAXParseException: Premature end of
file.
]
javax.jbi.messaging.MessagingException:
SedaQueue{[container=ServiceMix,name=ID:srsprod-mfback.musiciansfriend.com-52647-1159494613257-0:1]}
Failed to enqueue exchange: InOut[
  id: ID:srsprod-mfback.musiciansfriend.com-52646-1159494610099-8:352
  status: Active
  role: provider
  service: {http://www.musiciansfriend.com}xsltFilemaker
  endpoint: xsltFilemaker
  in: <?xml version="1.0" encoding="UTF-8"?><message>189</message>
]
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaFlow.enqueuePacket(SedaFlow.java:201)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaFlow.doSend(SedaFlow.java:172)
        at
org.apache.servicemix.jbi.nmr.flow.AbstractFlow.send(AbstractFlow.java:121)
        at
org.apache.servicemix.jbi.nmr.DefaultBroker.sendExchangePacket(DefaultBroker.java:298)
        at
org.apache.servicemix.jbi.security.SecuredBroker.sendExchangePacket(SecuredBroker.java:80)
        at
org.apache.servicemix.jbi.container.JBIContainer.sendExchange(JBIContainer.java:793)
        at
org.apache.servicemix.jbi.messaging.DeliveryChannelImpl.doSend(DeliveryChannelImpl.java:375)
        at
org.apache.servicemix.jbi.messaging.DeliveryChannelImpl.send(DeliveryChannelImpl.java:411)
        at
org.apache.servicemix.common.AsyncBaseLifeCycle.sendConsumerExchange(AsyncBaseLifeCycle.java:460)
        at org.apache.servicemix.eip.EIPEndpoint.send(EIPEndpoint.java:205)
        at
org.apache.servicemix.eip.patterns.Pipeline.processAsync(Pipeline.java:243)
        at
org.apache.servicemix.eip.EIPEndpoint.process(EIPEndpoint.java:241)
        at
org.apache.servicemix.common.AsyncBaseLifeCycle.processExchange(AsyncBaseLifeCycle.java:410)
        at
org.apache.servicemix.common.BaseLifeCycle.onMessageExchange(BaseLifeCycle.java:43)
        at
org.apache.servicemix.jbi.messaging.DeliveryChannelImpl.processInBound(DeliveryChannelImpl.java:623)
        at
org.apache.servicemix.jbi.nmr.flow.AbstractFlow.doRouting(AbstractFlow.java:169)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaFlow.doRouting(SedaFlow.java:177)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue$1.run(SedaQueue.java:227)
        at
org.apache.geronimo.connector.work.WorkerContext.run(WorkerContext.java:291)
        at
EDU.oswego.cs.dl.util.concurrent.PooledExecutor$RunWhenBlocked.blockedAction(Unknown
Source)
        at EDU.oswego.cs.dl.util.concurrent.PooledExecutor.execute(Unknown
Source)
        at
org.jencks.factory.GeronimoExecutorWrapper.execute(GeronimoExecutorWrapper.java:31)
        at
org.apache.geronimo.connector.work.pool.ScheduleWorkExecutor.doExecute(ScheduleWorkExecutor.java:34)
        at
org.apache.geronimo.connector.work.GeronimoWorkManager.executeWork(GeronimoWorkManager.java:199)
        at
org.apache.geronimo.connector.work.GeronimoWorkManager.scheduleWork(GeronimoWorkManager.java:170)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue.run(SedaQueue.java:219)
        at
org.apache.geronimo.connector.work.WorkerContext.run(WorkerContext.java:291)
        at
EDU.oswego.cs.dl.util.concurrent.PooledExecutor$Worker.run(Unknown Source)
        at java.lang.Thread.run(Thread.java:613)
Caused by: java.lang.InterruptedException
        at java.lang.Object.wait(Native Method)
        at java.lang.Object.wait(Object.java:474)
        at
org.apache.servicemix.jbi.util.BoundedLinkedQueue.put(BoundedLinkedQueue.java:307)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue.enqueue(SedaQueue.java:138)
        at
org.apache.servicemix.jbi.nmr.flow.seda.SedaFlow.enqueuePacket(SedaFlow.java:198)
        ... 28 more

I am testing out a SA I created. It seems to work fine for a few messages,
but I decided I needed to put some strain on the assembly. In production it
could be hit with a large amount of messages. Two JMS consumers read from
the topic, each forwarding to an eip:pipeline endpoint. Each pipeline uses a
xslt component to transform the message and send it to a queue. This way I
am able to form two different documents tailored to the processes which will
be reading from the queues.
-- 
View this message in context: http://www.nabble.com/Problem-when-publishing-500-messages-to-topic-queue-tf2354600.html#a6558234
Sent from the ServiceMix - User mailing list archive at Nabble.com.