You are viewing a plain text version of this content. The canonical link for it is here.
Posted to users@camel.apache.org by Frankiboy <ma...@gmail.com> on 2014/07/01 15:48:57 UTC

Im trying to write "Frank was here" into my websphere MQ from camel with Topic and Subscribtions.

Im trying to write "Frank was here" into my websphere MQ from camel with
Topic and Subscribtions.

The MQ is defined as Topic: HUB_TOP01

With 3 subscribtions "HUB_SUB01" and "HUB_SUB01" and "HUB_SUB03" here im
trying to write to HUB_SUB01

This bean fails with a exception bean(LogMq.class,
"logStart").to("activemq:topic:HUB_TOP01") and the logMq only returns a
string with "Frank was here"



 My Bean definition in camel.xml

	
  <bean id="activemq" class="org.apache.camel.component.jms.JmsComponent">  
     <property name="connectionFactory">
        <bean class="com.ibm.mq.jms.MQConnectionFactory">  
			 <property name="hostName" value="bdaix416.bdunet.dk"/>     
		   	 <property name="port" value="1414"/>
		   	 <property name="clientId" value="HUB_SUB01"/>  
	    </bean> 
     </property>
 </bean>
	



My route.

  from("cxf:bean:hubws?dataFormat=MESSAGE").streamCaching()
        .onException(Exception.class).process(new LogError()).end()
        .bean(LogMq.class, "logStart").to("activemq:topic:HUB_TOP01")
        .bean(AddIpBean.class).bean(SetRoutingKey.class).choice()
        .when(header(ROUTING_KEY).contains(ROUTING_BD)).to("bdws")
        .when(header(ROUTING_KEY).contains(ROUTING_BEC)).to("becws")
       
.when(header(ROUTING_KEY).contains(ROUTING_SDC)).to("sdcws").otherwise().to("file:/fja/")
    ;   


	

Is the cleintId, i thougt i schould set the durableSubscriptionName , but
this is not in the MQConnectionFactory, is this the right way to set 
the subScriobtions, and can any one tell me if im on the right track ? 


Some of the stack Trace from camel:

Exception occurred during execution on the exchange: Exchange[Message: Frank
was here]
org.apache.camel.util.ObjectHelper.wrapCamelExecutionException(ObjectHelper.java:1368)org.apache.camel.impl.DefaultExchange.setException(DefaultExchange.java:283)

org.apache.camel.component.jms.JmsProducer.process(JmsProducer.java:158)org.apache.camel.processor.SendProcessor.process(SendProcessor.java:110)

org.apache.camel.management.InstrumentationProcessor.process(InstrumentationProcessor.java:72)org.apache.camel.processor.RedeliveryErrorHandler.process(RedeliveryErrorHandler.java:398)

org.apache.camel.processor.CamelInternalProcessor.process(CamelInternalProcessor.java:191)org.apache.camel.processor.Pipeline.process(Pipeline.java:118)

org.apache.camel.processor.Pipeline.process(Pipeline.java:80)org.apache.camel.processor.CamelInternalProcessor.process(CamelInternalProcessor.java:191)

org.apache.camel.util.AsyncProcessorHelper.process(AsyncProcessorHelper.java:105)org.apache.camel.processor.DelegateAsyncProcessor.process(DelegateAsyncProcessor.java:87)

org.apache.camel.component.cxf.CxfConsumer$1.syncInvoke(CxfConsumer.java:134)org.apache.camel.component.cxf.CxfConsumer$1.invoke(CxfC



--
View this message in context: http://camel.465427.n5.nabble.com/Im-trying-to-write-Frank-was-here-into-my-websphere-MQ-from-camel-with-Topic-and-Subscribtions-tp5753148.html
Sent from the Camel - Users mailing list archive at Nabble.com.