You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@servicemix.apache.org by mayurd <ma...@yahoo.com> on 2008/04/10 07:01:36 UTC

Soap Client, CXF BC and JMS

I have a SOAP Client sending InOut messages to cxf bc and getting response
back (cxf se has implemented the business logic).

Now I need to modify this to forward the request to a jms provider end
point. A bean is listening on the queue (implementing
MessageExchangeListener, onMessageExchange) and send the response back to
soap client. 

Currently I am receiving following exception on sending the soap message

ERROR - SedaQueue                      -
org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue$1@1c07f3a got error
processin
g InOut[
  id: ID:10.1.1.107-11936a57ccc-4:0
  status: Active
  role: provider
  interface: {http://www.abcenergy.com/ABCWorkHandler/}ABCWorkHandlerInt
  service: {http://www.abcenergy.com/ABCWorkHandler/}jms
  endpoint: myProvider
  operation: {http://www.abcenergy.com/ABCWorkHandler/}GetRegister
  in: <?xml version="1.0" encoding="UTF-8" standalone="no"?><jbi:message
xmlns:jbi="http://java.sun.com/xml/ns/jbi/wsdl-
11-wrapper" xmlns:msg="http://www.abcenergy.com/ABCWorkHandler/"
name="GetRegisterRequest" type="msg:GetRegisterRequest"
 version="1.0"><jbi:part><abc:GetRegister
xmlns:abc="http://www.abcenergy.com/ABCWorkHandler/">
         <name>mayur</name>
         <address>address</address>
         <license>license</license>
         <workAreas>workarea</workAreas>
      </abc:GetRegister></jbi:part></jbi:message>
]
java.lang.NoClassDefFoundError:
org/apache/servicemix/soap/marshalers/SoapWriter
        at
org.apache.servicemix.soap.marshalers.SoapMarshaler.createWriter(SoapMarshaler.java:167)
        at
org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:78)
        at
org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:106)
        at
org.apache.servicemix.jms.AbstractJmsProcessor.fromNMS(AbstractJmsProcessor.java:164)
        at
org.apache.servicemix.jms.multiplexing.MultiplexingProviderProcessor.process(MultiplexingProviderProcessor.ja
va:136)
        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:170)
        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:885)
        at
java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
        at java.lang.Thread.run(Thread.java:619)
Caused by: java.lang.ClassNotFoundException:
org.apache.servicemix.soap.marshalers.SoapWriter in classloader org.apache.
servicemix.soap.marshalers.SoapWriter
        at
org.apache.xbean.classloader.MultiParentClassLoader.loadClass(MultiParentClassLoader.java:206)
        at java.lang.ClassLoader.loadClass(ClassLoader.java:251)
        at java.lang.ClassLoader.loadClassInternal(ClassLoader.java:319)
        ... 15 more
Apr 9, 2008 9:47:42 PM org.apache.cxf.phase.PhaseInterceptorChain
doIntercept
INFO: Interceptor has thrown exception, unwinding now
org.apache.cxf.interceptor.Fault
        at
org.apache.servicemix.cxfbc.CxfBcConsumer$JbiPostInvokerInterceptor.handleMessage(CxfBcConsumer.java:454)
        at
org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
        at
org.apache.cxf.phase.PhaseInterceptorChain.resume(PhaseInterceptorChain.java:184)
        at
org.apache.servicemix.cxfbc.CxfBcConsumer.process(CxfBcConsumer.java:183)
        at
org.apache.servicemix.cxfbc.CxfBcConsumer$JbiInvokerInterceptor.handleMessage(CxfBcConsumer.java:430)
        at
org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
        at
org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:73)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPDestination.serviceRequest(JettyHTTPDestination.java:268)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPDestination.doService(JettyHTTPDestination.java:224)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPHandler.handle(JettyHTTPHandler.java:54)
        at
org.mortbay.jetty.handler.ContextHandler.handle(ContextHandler.java:712)
        at
org.mortbay.jetty.handler.ContextHandlerCollection.handle(ContextHandlerCollection.java:211)
        at
org.mortbay.jetty.handler.HandlerWrapper.handle(HandlerWrapper.java:139)
        at org.mortbay.jetty.Server.handle(Server.java:313)
        at
org.mortbay.jetty.HttpConnection.handleRequest(HttpConnection.java:506)
        at
org.mortbay.jetty.HttpConnection$RequestHandler.content(HttpConnection.java:844)
        at org.mortbay.jetty.HttpParser.parseNext(HttpParser.java:644)
        at org.mortbay.jetty.HttpParser.parseAvailable(HttpParser.java:211)
        at org.mortbay.jetty.HttpConnection.handle(HttpConnection.java:381)
        at
org.mortbay.io.nio.SelectChannelEndPoint.run(SelectChannelEndPoint.java:396)
        at
org.mortbay.thread.BoundedThreadPool$PoolThread.run(BoundedThreadPool.java:442)

Any help would be highly apprecaited.



-- 
View this message in context: http://www.nabble.com/Soap-Client%2C-CXF-BC-and-JMS-tp16602162p16602162.html
Sent from the ServiceMix - User mailing list archive at Nabble.com.


Re: Soap Client, CXF BC and JMS

Posted by mayurd <ma...@yahoo.com>.
I modified the cxf-se-bean to act as a JMS client. cxf-se-bean is creating a
queue for input and output and putting the message (original message recd by
se was SOAP, the message its putting on queue is just a xml message). On
calling requestor.request (see snippet below) it throws following exception:

I am using servicemix 3.2.1

===code snippet from inside cxf-se

		System.out.println("Connecting to JMS server.");
		factory = new ActiveMQConnectionFactory("tcp://localhost:61616");
		Destination inQueue = new ActiveMQQueue(inQueueName);
		Destination outQueue = new ActiveMQQueue(outQueueName);
						//+ (int) (1000 * Math.random()));
		requestor = MultiplexingRequestor.newInstance(factory,
				new JmsProducerConfig(), inQueue, outQueue);
			System.out.println("Preparing request.");
						
			Message out = requestor
					.getSession()
					.createTextMessage(
							"<RegisterData><name>" + getRegister.getName() + "</name><address>" +
getRegister.getAddress() + "</address><license>" + getRegister.getLicense()
+ "</license><workareas>" + getRegister.getWorkAreas() +
"</workareas></RegisterData>");
			System.out.println("request initialized.");
			System.out.println("Sending request. out=" + out.toString());

			Message in = requestor.request(null, out);

			System.out.println("request sent. waiting for response");

===code snippet from inside cxf-se

===start exception

Apr 10, 2008 12:27:21 PM org.apache.cxf.transport.jbi.JBITransportFactory
setDeliveryChannel
INFO: configuring DeliveryChannel:     
org.apache.servicemix.common.EndpointDeliveryChannel@1222652
Warning:  The encoding 'UTF-8' is not supported by the Java runtime.
Connecting to JMS server.
Preparing request.
request initialized.
Sending request. out=ActiveMQTextMessage {commandId = 0, responseRequired =
false, messageId = null, originalDestination
 = null, originalTransactionId = null, producerId = null, destination =
null, transactionId = null, expiration = 0, time
stamp = 0, arrival = 0, correlationId = null, replyTo = null, persistent =
false, type = null, priority = 0, groupID = n
ull, groupSequence = 0, targetConsumerId = null, compressed = false, userID
= null, content = null, marshalledProperties
 = null, dataStructure = null, redeliveryCounter = 0, size = 0, properties =
null, readOnlyProperties = false, readOnlyB
ody = false, droppable = false, text =
<RegisterData><name>dembla</name><address>address</address><license>lic</license>
<workareas>wa</workareas></RegisterData>}
Apr 10, 2008 12:27:31 PM org.apache.cxf.phase.PhaseInterceptorChain
doIntercept
INFO: Interceptor has thrown exception, unwinding now
org.apache.cxf.interceptor.Fault
        at
org.apache.servicemix.cxfbc.CxfBcConsumer$JbiPostInvokerInterceptor.handleMessage(CxfBcConsumer.java:454)
        at
org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
        at
org.apache.cxf.phase.PhaseInterceptorChain.resume(PhaseInterceptorChain.java:184)
        at
org.apache.servicemix.cxfbc.CxfBcConsumer.process(CxfBcConsumer.java:183)
        at
org.apache.servicemix.cxfbc.CxfBcConsumer$JbiInvokerInterceptor.handleMessage(CxfBcConsumer.java:430)
        at
org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
        at
org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:73)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPDestination.serviceRequest(JettyHTTPDestination.java:268)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPDestination.doService(JettyHTTPDestination.java:224)
        at
org.apache.cxf.transport.http_jetty.JettyHTTPHandler.handle(JettyHTTPHandler.java:54)
        at
org.mortbay.jetty.handler.ContextHandler.handle(ContextHandler.java:712)
        at
org.mortbay.jetty.handler.ContextHandlerCollection.handle(ContextHandlerCollection.java:211)
        at
org.mortbay.jetty.handler.HandlerWrapper.handle(HandlerWrapper.java:139)
        at org.mortbay.jetty.Server.handle(Server.java:313)
        at
org.mortbay.jetty.HttpConnection.handleRequest(HttpConnection.java:506)
        at
org.mortbay.jetty.HttpConnection$RequestHandler.content(HttpConnection.java:844)
        at org.mortbay.jetty.HttpParser.parseNext(HttpParser.java:644)
        at org.mortbay.jetty.HttpParser.parseAvailable(HttpParser.java:211)
        at org.mortbay.jetty.HttpConnection.handle(HttpConnection.java:381)
        at
org.mortbay.io.nio.SelectChannelEndPoint.run(SelectChannelEndPoint.java:396)
        at
org.mortbay.thread.BoundedThreadPool$PoolThread.run(BoundedThreadPool.java:442)



===end exception






gnodet wrote:
> 
> So I suppose your cxf-se bean is sending a JBI exchange to a JMS endpoint,
> right ?
> This CNFE looks really weird and I've never seen that one before.  These
> classes should be in the container classpath.
> What kind of deployment do you use ?
> 
> On Thu, Apr 10, 2008 at 7:01 AM, mayurd <ma...@yahoo.com> wrote:
> 
>>
>> I have a SOAP Client sending InOut messages to cxf bc and getting
>> response
>> back (cxf se has implemented the business logic).
>>
>> Now I need to modify this to forward the request to a jms provider end
>> point. A bean is listening on the queue (implementing
>> MessageExchangeListener, onMessageExchange) and send the response back to
>> soap client.
>>
>> Currently I am receiving following exception on sending the soap message
>>
>> ERROR - SedaQueue                      -
>> org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue$1@1c07f3a got error
>> processin
>> g InOut[
>>  id: ID:10.1.1.107-11936a57ccc-4:0
>>  status: Active
>>  role: provider
>>  interface:
>> {http://www.abcenergy.com/ABCWorkHandler/}ABCWorkHandlerInt<http://www.abcenergy.com/ABCWorkHandler/%7DABCWorkHandlerInt>
>>  service:
>> {http://www.abcenergy.com/ABCWorkHandler/}jms<http://www.abcenergy.com/ABCWorkHandler/%7Djms>
>>  endpoint: myProvider
>>  operation:
>> {http://www.abcenergy.com/ABCWorkHandler/}GetRegister<http://www.abcenergy.com/ABCWorkHandler/%7DGetRegister>
>>  in: <?xml version="1.0" encoding="UTF-8" standalone="no"?><jbi:message
>> xmlns:jbi="http://java.sun.com/xml/ns/jbi/wsdl-
>> 11-wrapper <http://java.sun.com/xml/ns/jbi/wsdl-11-wrapper>" xmlns:msg="
>> http://www.abcenergy.com/ABCWorkHandler/"
>> name="GetRegisterRequest" type="msg:GetRegisterRequest"
>>  version="1.0"><jbi:part><abc:GetRegister
>> xmlns:abc="http://www.abcenergy.com/ABCWorkHandler/">
>>         <name>mayur</name>
>>         <address>address</address>
>>         <license>license</license>
>>         <workAreas>workarea</workAreas>
>>      </abc:GetRegister></jbi:part></jbi:message>
>> ]
>> java.lang.NoClassDefFoundError:
>> org/apache/servicemix/soap/marshalers/SoapWriter
>>        at
>>
>> org.apache.servicemix.soap.marshalers.SoapMarshaler.createWriter(SoapMarshaler.java:167)
>>        at
>>
>> org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:78)
>>        at
>>
>> org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:106)
>>        at
>>
>> org.apache.servicemix.jms.AbstractJmsProcessor.fromNMS(AbstractJmsProcessor.java:164)
>>        at
>>
>> org.apache.servicemix.jms.multiplexing.MultiplexingProviderProcessor.process(MultiplexingProviderProcessor.ja
>> va:136)
>>        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:170)
>>        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:885)
>>        at
>>
>> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
>>        at java.lang.Thread.run(Thread.java:619)
>> Caused by: java.lang.ClassNotFoundException:
>> org.apache.servicemix.soap.marshalers.SoapWriter in classloader
>> org.apache.
>> servicemix.soap.marshalers.SoapWriter
>>        at
>>
>> org.apache.xbean.classloader.MultiParentClassLoader.loadClass(MultiParentClassLoader.java:206)
>>        at java.lang.ClassLoader.loadClass(ClassLoader.java:251)
>>        at java.lang.ClassLoader.loadClassInternal(ClassLoader.java:319)
>>        ... 15 more
>> Apr 9, 2008 9:47:42 PM org.apache.cxf.phase.PhaseInterceptorChain
>> doIntercept
>> INFO: Interceptor has thrown exception, unwinding now
>> org.apache.cxf.interceptor.Fault
>>        at
>>
>> org.apache.servicemix.cxfbc.CxfBcConsumer$JbiPostInvokerInterceptor.handleMessage(CxfBcConsumer.java:454)
>>        at
>>
>> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
>>        at
>>
>> org.apache.cxf.phase.PhaseInterceptorChain.resume(PhaseInterceptorChain.java:184)
>>        at
>> org.apache.servicemix.cxfbc.CxfBcConsumer.process(CxfBcConsumer.java:183)
>>        at
>>
>> org.apache.servicemix.cxfbc.CxfBcConsumer$JbiInvokerInterceptor.handleMessage(CxfBcConsumer.java:430)
>>        at
>>
>> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
>>        at
>>
>> org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:73)
>>        at
>>
>> org.apache.cxf.transport.http_jetty.JettyHTTPDestination.serviceRequest(JettyHTTPDestination.java:268)
>>        at
>>
>> org.apache.cxf.transport.http_jetty.JettyHTTPDestination.doService(JettyHTTPDestination.java:224)
>>        at
>>
>> org.apache.cxf.transport.http_jetty.JettyHTTPHandler.handle(JettyHTTPHandler.java:54)
>>        at
>> org.mortbay.jetty.handler.ContextHandler.handle(ContextHandler.java:712)
>>        at
>>
>> org.mortbay.jetty.handler.ContextHandlerCollection.handle(ContextHandlerCollection.java:211)
>>        at
>> org.mortbay.jetty.handler.HandlerWrapper.handle(HandlerWrapper.java:139)
>>        at org.mortbay.jetty.Server.handle(Server.java:313)
>>        at
>> org.mortbay.jetty.HttpConnection.handleRequest(HttpConnection.java:506)
>>        at
>>
>> org.mortbay.jetty.HttpConnection$RequestHandler.content(HttpConnection.java:844)
>>        at org.mortbay.jetty.HttpParser.parseNext(HttpParser.java:644)
>>        at
>> org.mortbay.jetty.HttpParser.parseAvailable(HttpParser.java:211)
>>        at
>> org.mortbay.jetty.HttpConnection.handle(HttpConnection.java:381)
>>        at
>>
>> org.mortbay.io.nio.SelectChannelEndPoint.run(SelectChannelEndPoint.java:396)
>>        at
>>
>> org.mortbay.thread.BoundedThreadPool$PoolThread.run(BoundedThreadPool.java:442)
>>
>> Any help would be highly apprecaited.
>>
>>
>>
>> --
>> View this message in context:
>> http://www.nabble.com/Soap-Client%2C-CXF-BC-and-JMS-tp16602162p16602162.html
>> Sent from the ServiceMix - User mailing list archive at Nabble.com.
>>
>>
> 
> 
> -- 
> Cheers,
> Guillaume Nodet
> ------------------------
> Blog: http://gnodet.blogspot.com/
> 
> 

-- 
View this message in context: http://www.nabble.com/Soap-Client%2C-CXF-BC-and-JMS-tp16602162p16615449.html
Sent from the ServiceMix - User mailing list archive at Nabble.com.


Re: Soap Client, CXF BC and JMS

Posted by Guillaume Nodet <gn...@gmail.com>.
So I suppose your cxf-se bean is sending a JBI exchange to a JMS endpoint,
right ?
This CNFE looks really weird and I've never seen that one before.  These
classes should be in the container classpath.
What kind of deployment do you use ?

On Thu, Apr 10, 2008 at 7:01 AM, mayurd <ma...@yahoo.com> wrote:

>
> I have a SOAP Client sending InOut messages to cxf bc and getting response
> back (cxf se has implemented the business logic).
>
> Now I need to modify this to forward the request to a jms provider end
> point. A bean is listening on the queue (implementing
> MessageExchangeListener, onMessageExchange) and send the response back to
> soap client.
>
> Currently I am receiving following exception on sending the soap message
>
> ERROR - SedaQueue                      -
> org.apache.servicemix.jbi.nmr.flow.seda.SedaQueue$1@1c07f3a got error
> processin
> g InOut[
>  id: ID:10.1.1.107-11936a57ccc-4:0
>  status: Active
>  role: provider
>  interface: {http://www.abcenergy.com/ABCWorkHandler/}ABCWorkHandlerInt<http://www.abcenergy.com/ABCWorkHandler/%7DABCWorkHandlerInt>
>  service: {http://www.abcenergy.com/ABCWorkHandler/}jms<http://www.abcenergy.com/ABCWorkHandler/%7Djms>
>  endpoint: myProvider
>  operation: {http://www.abcenergy.com/ABCWorkHandler/}GetRegister<http://www.abcenergy.com/ABCWorkHandler/%7DGetRegister>
>  in: <?xml version="1.0" encoding="UTF-8" standalone="no"?><jbi:message
> xmlns:jbi="http://java.sun.com/xml/ns/jbi/wsdl-
> 11-wrapper <http://java.sun.com/xml/ns/jbi/wsdl-11-wrapper>" xmlns:msg="
> http://www.abcenergy.com/ABCWorkHandler/"
> name="GetRegisterRequest" type="msg:GetRegisterRequest"
>  version="1.0"><jbi:part><abc:GetRegister
> xmlns:abc="http://www.abcenergy.com/ABCWorkHandler/">
>         <name>mayur</name>
>         <address>address</address>
>         <license>license</license>
>         <workAreas>workarea</workAreas>
>      </abc:GetRegister></jbi:part></jbi:message>
> ]
> java.lang.NoClassDefFoundError:
> org/apache/servicemix/soap/marshalers/SoapWriter
>        at
>
> org.apache.servicemix.soap.marshalers.SoapMarshaler.createWriter(SoapMarshaler.java:167)
>        at
>
> org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:78)
>        at
>
> org.apache.servicemix.jms.DefaultJmsMarshaler.toJMS(DefaultJmsMarshaler.java:106)
>        at
>
> org.apache.servicemix.jms.AbstractJmsProcessor.fromNMS(AbstractJmsProcessor.java:164)
>        at
>
> org.apache.servicemix.jms.multiplexing.MultiplexingProviderProcessor.process(MultiplexingProviderProcessor.ja
> va:136)
>        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:170)
>        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:885)
>        at
>
> java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:907)
>        at java.lang.Thread.run(Thread.java:619)
> Caused by: java.lang.ClassNotFoundException:
> org.apache.servicemix.soap.marshalers.SoapWriter in classloader
> org.apache.
> servicemix.soap.marshalers.SoapWriter
>        at
>
> org.apache.xbean.classloader.MultiParentClassLoader.loadClass(MultiParentClassLoader.java:206)
>        at java.lang.ClassLoader.loadClass(ClassLoader.java:251)
>        at java.lang.ClassLoader.loadClassInternal(ClassLoader.java:319)
>        ... 15 more
> Apr 9, 2008 9:47:42 PM org.apache.cxf.phase.PhaseInterceptorChain
> doIntercept
> INFO: Interceptor has thrown exception, unwinding now
> org.apache.cxf.interceptor.Fault
>        at
>
> org.apache.servicemix.cxfbc.CxfBcConsumer$JbiPostInvokerInterceptor.handleMessage(CxfBcConsumer.java:454)
>        at
>
> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
>        at
>
> org.apache.cxf.phase.PhaseInterceptorChain.resume(PhaseInterceptorChain.java:184)
>        at
> org.apache.servicemix.cxfbc.CxfBcConsumer.process(CxfBcConsumer.java:183)
>        at
>
> org.apache.servicemix.cxfbc.CxfBcConsumer$JbiInvokerInterceptor.handleMessage(CxfBcConsumer.java:430)
>        at
>
> org.apache.cxf.phase.PhaseInterceptorChain.doIntercept(PhaseInterceptorChain.java:207)
>        at
>
> org.apache.cxf.transport.ChainInitiationObserver.onMessage(ChainInitiationObserver.java:73)
>        at
>
> org.apache.cxf.transport.http_jetty.JettyHTTPDestination.serviceRequest(JettyHTTPDestination.java:268)
>        at
>
> org.apache.cxf.transport.http_jetty.JettyHTTPDestination.doService(JettyHTTPDestination.java:224)
>        at
>
> org.apache.cxf.transport.http_jetty.JettyHTTPHandler.handle(JettyHTTPHandler.java:54)
>        at
> org.mortbay.jetty.handler.ContextHandler.handle(ContextHandler.java:712)
>        at
>
> org.mortbay.jetty.handler.ContextHandlerCollection.handle(ContextHandlerCollection.java:211)
>        at
> org.mortbay.jetty.handler.HandlerWrapper.handle(HandlerWrapper.java:139)
>        at org.mortbay.jetty.Server.handle(Server.java:313)
>        at
> org.mortbay.jetty.HttpConnection.handleRequest(HttpConnection.java:506)
>        at
>
> org.mortbay.jetty.HttpConnection$RequestHandler.content(HttpConnection.java:844)
>        at org.mortbay.jetty.HttpParser.parseNext(HttpParser.java:644)
>        at org.mortbay.jetty.HttpParser.parseAvailable(HttpParser.java:211)
>        at org.mortbay.jetty.HttpConnection.handle(HttpConnection.java:381)
>        at
>
> org.mortbay.io.nio.SelectChannelEndPoint.run(SelectChannelEndPoint.java:396)
>        at
>
> org.mortbay.thread.BoundedThreadPool$PoolThread.run(BoundedThreadPool.java:442)
>
> Any help would be highly apprecaited.
>
>
>
> --
> View this message in context:
> http://www.nabble.com/Soap-Client%2C-CXF-BC-and-JMS-tp16602162p16602162.html
> Sent from the ServiceMix - User mailing list archive at Nabble.com.
>
>


-- 
Cheers,
Guillaume Nodet
------------------------
Blog: http://gnodet.blogspot.com/