Uploaded image for project: 'ServiceMix Components'
  1. ServiceMix Components
  2. SMXCOMP-359

servicemix-cxf service with outbound attachment and jms transport generates XMLStreamReader error

    XMLWordPrintableJSON

Details

    Description

      Modified cxf-wsdl-first with outbound attachment and jms transport generates XMLStreamReader error. See stack trace below. A sample test case has been attached. FYI, this test case works when run on IONA FUSE ESB 3.3.1.0. It is broken when run on IONA FUSE ESB 3.3.1.3 and Apache SMX 3.2.2.

      Aug 10, 2008 2:06:54 AM org.apache.cxf.transport.jms.JMSDestination$JMSExecutor run
      INFO: run the incoming message in the threadpool
      Aug 10, 2008 2:06:54 AM org.apache.cxf.transport.jbi.JBITransportFactory setDeliveryChannel
      INFO: configuring DeliveryChannel: org.apache.servicemix.common.EndpointDeliveryChannel@14790be
      Aug 10, 2008 2:06:56 AM org.apache.cxf.transport.jbi.JBITransportFactory setDeliveryChannel
      INFO: configuring DeliveryChannel: org.apache.servicemix.common.EndpointDeliveryChannel@14790be
      Aug 10, 2008 2:06:56 AM org.apache.cxf.phase.PhaseInterceptorChain doIntercept
      INFO: Interceptor has thrown exception, unwinding now
      org.apache.cxf.binding.soap.SoapFault: Error reading XMLStreamReader.
      at org.apache.cxf.binding.soap.interceptor.ReadHeadersInterceptor.handleMessage(ReadHeadersInterceptor.java:183)

      at org.apache.cxf.binding.soap.interceptor.ReadHeadersInterceptor.handleMessage(ReadHeadersInterceptor.java:54)
      at org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:221)
      at org.apache.servicemix.cxfbc.CxfBcProviderMessageObserver.onMessage(CxfBcProviderMessageObserver.java:141)
      at org.apache.cxf.transport.jms.JMSConduit$JMSOutputStream.handleResponse(JMSConduit.java:388)
      at org.apache.cxf.transport.jms.JMSConduit$JMSOutputStream.doClose(JMSConduit.java:258)
      at org.apache.cxf.io.CachedOutputStream.close(CachedOutputStream.java:156)
      at org.apache.servicemix.cxfbc.CxfBcProvider.process(CxfBcProvider.java:230)
      at org.apache.servicemix.common.AsyncBaseLifeCycle.doProcess(AsyncBaseLifeCycle.java:538)
      at org.apache.servicemix.common.AsyncBaseLifeCycle.processExchange(AsyncBaseLifeCycle.java:490)
      at org.apache.servicemix.common.BaseLifeCycle.onMessageExchange(BaseLifeCycle.java:46)
      at org.apache.servicemix.jbi.messaging.DeliveryChannelImpl.processInBound(DeliveryChannelImpl.java:610)
      at org.apache.servicemix.jbi.nmr.flow.AbstractFlow.doRouting(AbstractFlow.java:172)
      at org.apache.servicemix.jbi.nmr.flow.seda.SedaFlow.doRouting(SedaFlow.java:167)
      at org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue$1.run(SedaQueue.java:134)
      at java.util.concurrent.ThreadPoolExecutor$Worker.runTask(ThreadPoolExecutor.java:650)
      at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:675)
      at java.lang.Thread.run(Thread.java:595)
      Caused by: com.ctc.wstx.exc.WstxUnexpectedCharException: Unexpected character '-' (code 45) in prolog; expected '<'
      at [row,col

      {unknown-source}

      ]: [2,1]
      at com.ctc.wstx.sr.StreamScanner.throwUnexpectedChar(StreamScanner.java:623)
      at com.ctc.wstx.sr.BasicStreamReader.nextFromProlog(BasicStreamReader.java:2047)
      at com.ctc.wstx.sr.BasicStreamReader.next(BasicStreamReader.java:1069)
      at com.ctc.wstx.sr.BasicStreamReader.nextTag(BasicStreamReader.java:1095)
      at org.apache.cxf.binding.soap.interceptor.ReadHeadersInterceptor.handleMessage(ReadHeadersInterceptor.java:83)
      ... 17 more

      Attachments

        Activity

          People

            ffang Freeman Yue Fang
            rgavlin Ron Gavlin
            Votes:
            0 Vote for this issue
            Watchers:
            0 Start watching this issue

            Dates

              Created:
              Updated:
              Resolved: