You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by dk...@apache.org on 2011/12/22 22:08:37 UTC

svn commit: r1222454 [2/4] - in /camel/branches/camel-2.8.x: camel-core/src/main/java/org/apache/camel/ camel-core/src/main/java/org/apache/camel/builder/ camel-core/src/main/java/org/apache/camel/builder/xml/ camel-core/src/main/java/org/apache/camel/...

Modified: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/processor/interceptor/DefaultTraceEventHandler.java
URL: http://svn.apache.org/viewvc/camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/processor/interceptor/DefaultTraceEventHandler.java?rev=1222454&r1=1222453&r2=1222454&view=diff
==============================================================================
--- camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/processor/interceptor/DefaultTraceEventHandler.java (original)
+++ camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/processor/interceptor/DefaultTraceEventHandler.java Thu Dec 22 21:08:26 2011
@@ -1,148 +1,148 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.processor.interceptor;
-
-import java.util.Date;
-import java.util.HashMap;
-import java.util.Map;
-
-import org.apache.camel.Endpoint;
-import org.apache.camel.Exchange;
-import org.apache.camel.Processor;
-import org.apache.camel.Producer;
-import org.apache.camel.Service;
-import org.apache.camel.impl.DefaultExchange;
-import org.apache.camel.model.ProcessorDefinition;
-import org.apache.camel.util.IntrospectionSupport;
-import org.apache.camel.util.ObjectHelper;
-import org.apache.camel.util.ServiceHelper;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public class DefaultTraceEventHandler implements TraceEventHandler, Service {
-    private static final transient Logger LOG = LoggerFactory.getLogger(DefaultTraceEventHandler.class);
-    
-    private Producer traceEventProducer;
-    private Class<?> jpaTraceEventMessageClass;
-    private String jpaTraceEventMessageClassName;
-
-    private final Tracer tracer;
-    
-    public DefaultTraceEventHandler(Tracer tracer) {
-        this.tracer = tracer;
-    }
-
-    private synchronized void loadJpaTraceEventMessageClass(Exchange exchange) {
-        if (jpaTraceEventMessageClass == null) {
-            jpaTraceEventMessageClassName = tracer.getJpaTraceEventMessageClassName();
-        }
-        if (jpaTraceEventMessageClass == null) {
-            jpaTraceEventMessageClass = exchange.getContext().getClassResolver().resolveClass(jpaTraceEventMessageClassName);
-            if (jpaTraceEventMessageClass == null) {
-                throw new IllegalArgumentException("Cannot find class: " + jpaTraceEventMessageClassName
-                        + ". Make sure camel-jpa.jar is in the classpath.");
-            }
-        }
-    }
-
-    private synchronized Producer getTraceEventProducer(Exchange exchange) throws Exception {
-        if (traceEventProducer == null) {
-            // create producer when we have access the the camel context (we dont in doStart)
-            Endpoint endpoint = tracer.getDestination() != null ? tracer.getDestination() : exchange.getContext().getEndpoint(tracer.getDestinationUri());
-            traceEventProducer = endpoint.createProducer();
-            ServiceHelper.startService(traceEventProducer);
-        }
-        return traceEventProducer;
-    }
-
-    @Override
-    public void traceExchange(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange) throws Exception {
-        if (tracer.getDestination() != null || tracer.getDestinationUri() != null) {
-
-            // create event exchange and add event information
-            Date timestamp = new Date();
-            Exchange event = new DefaultExchange(exchange);
-            event.setProperty(Exchange.TRACE_EVENT_NODE_ID, node.getId());
-            event.setProperty(Exchange.TRACE_EVENT_TIMESTAMP, timestamp);
-            // keep a reference to the original exchange in case its needed
-            event.setProperty(Exchange.TRACE_EVENT_EXCHANGE, exchange);
-
-            // create event message to sent as in body containing event information such as
-            // from node, to node, etc.
-            TraceEventMessage msg = new DefaultTraceEventMessage(timestamp, node, exchange);
-
-            // should we use ordinary or jpa objects
-            if (tracer.isUseJpa()) {
-                if (LOG.isTraceEnabled()) {
-                    LOG.trace("Using class: " + this.jpaTraceEventMessageClassName + " for tracing event messages");
-                }
-
-                // load the jpa event message class
-                loadJpaTraceEventMessageClass(exchange);
-                // create a new instance of the event message class
-                Object jpa = ObjectHelper.newInstance(jpaTraceEventMessageClass);
-
-                // copy options from event to jpa
-                Map<String, Object> options = new HashMap<String, Object>();
-                IntrospectionSupport.getProperties(msg, options, null);
-                IntrospectionSupport.setProperties(jpa, options);
-                // and set the timestamp as its not a String type
-                IntrospectionSupport.setProperty(jpa, "timestamp", msg.getTimestamp());
-
-                event.getIn().setBody(jpa);
-            } else {
-                event.getIn().setBody(msg);
-            }
-
-            // marker property to indicate its a tracing event being routed in case
-            // new Exchange instances is created during trace routing so we can check
-            // for this marker when interceptor also kick in during routing of trace events
-            event.setProperty(Exchange.TRACE_EVENT, Boolean.TRUE);
-            try {
-                // process the trace route
-                getTraceEventProducer(exchange).process(event);
-            } catch (Exception e) {
-                // log and ignore this as the original Exchange should be allowed to continue
-                LOG.error("Error processing trace event (original Exchange will continue): " + event, e);
-            }
-        }
-    }
-
-    @Override
-    public Object traceExchangeIn(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange) throws Exception {
-        traceExchange(node, target, traceInterceptor, exchange);
-        return null;
-    }
-
-    @Override
-    public void traceExchangeOut(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange, Object traceState) throws Exception {
-        traceExchange(node, target, traceInterceptor, exchange);
-    }
-
-    @Override
-    public void start() throws Exception {
-        traceEventProducer = null;
-    }
-
-    @Override
-    public void stop() throws Exception {
-        if (traceEventProducer != null) {
-            ServiceHelper.stopService(traceEventProducer);
-        }
-    }
-
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.processor.interceptor;
+
+import java.util.Date;
+import java.util.HashMap;
+import java.util.Map;
+
+import org.apache.camel.Endpoint;
+import org.apache.camel.Exchange;
+import org.apache.camel.Processor;
+import org.apache.camel.Producer;
+import org.apache.camel.Service;
+import org.apache.camel.impl.DefaultExchange;
+import org.apache.camel.model.ProcessorDefinition;
+import org.apache.camel.util.IntrospectionSupport;
+import org.apache.camel.util.ObjectHelper;
+import org.apache.camel.util.ServiceHelper;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class DefaultTraceEventHandler implements TraceEventHandler, Service {
+    private static final transient Logger LOG = LoggerFactory.getLogger(DefaultTraceEventHandler.class);
+    
+    private Producer traceEventProducer;
+    private Class<?> jpaTraceEventMessageClass;
+    private String jpaTraceEventMessageClassName;
+
+    private final Tracer tracer;
+    
+    public DefaultTraceEventHandler(Tracer tracer) {
+        this.tracer = tracer;
+    }
+
+    private synchronized void loadJpaTraceEventMessageClass(Exchange exchange) {
+        if (jpaTraceEventMessageClass == null) {
+            jpaTraceEventMessageClassName = tracer.getJpaTraceEventMessageClassName();
+        }
+        if (jpaTraceEventMessageClass == null) {
+            jpaTraceEventMessageClass = exchange.getContext().getClassResolver().resolveClass(jpaTraceEventMessageClassName);
+            if (jpaTraceEventMessageClass == null) {
+                throw new IllegalArgumentException("Cannot find class: " + jpaTraceEventMessageClassName
+                        + ". Make sure camel-jpa.jar is in the classpath.");
+            }
+        }
+    }
+
+    private synchronized Producer getTraceEventProducer(Exchange exchange) throws Exception {
+        if (traceEventProducer == null) {
+            // create producer when we have access the the camel context (we dont in doStart)
+            Endpoint endpoint = tracer.getDestination() != null ? tracer.getDestination() : exchange.getContext().getEndpoint(tracer.getDestinationUri());
+            traceEventProducer = endpoint.createProducer();
+            ServiceHelper.startService(traceEventProducer);
+        }
+        return traceEventProducer;
+    }
+
+    @Override
+    public void traceExchange(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange) throws Exception {
+        if (tracer.getDestination() != null || tracer.getDestinationUri() != null) {
+
+            // create event exchange and add event information
+            Date timestamp = new Date();
+            Exchange event = new DefaultExchange(exchange);
+            event.setProperty(Exchange.TRACE_EVENT_NODE_ID, node.getId());
+            event.setProperty(Exchange.TRACE_EVENT_TIMESTAMP, timestamp);
+            // keep a reference to the original exchange in case its needed
+            event.setProperty(Exchange.TRACE_EVENT_EXCHANGE, exchange);
+
+            // create event message to sent as in body containing event information such as
+            // from node, to node, etc.
+            TraceEventMessage msg = new DefaultTraceEventMessage(timestamp, node, exchange);
+
+            // should we use ordinary or jpa objects
+            if (tracer.isUseJpa()) {
+                if (LOG.isTraceEnabled()) {
+                    LOG.trace("Using class: " + this.jpaTraceEventMessageClassName + " for tracing event messages");
+                }
+
+                // load the jpa event message class
+                loadJpaTraceEventMessageClass(exchange);
+                // create a new instance of the event message class
+                Object jpa = ObjectHelper.newInstance(jpaTraceEventMessageClass);
+
+                // copy options from event to jpa
+                Map<String, Object> options = new HashMap<String, Object>();
+                IntrospectionSupport.getProperties(msg, options, null);
+                IntrospectionSupport.setProperties(jpa, options);
+                // and set the timestamp as its not a String type
+                IntrospectionSupport.setProperty(jpa, "timestamp", msg.getTimestamp());
+
+                event.getIn().setBody(jpa);
+            } else {
+                event.getIn().setBody(msg);
+            }
+
+            // marker property to indicate its a tracing event being routed in case
+            // new Exchange instances is created during trace routing so we can check
+            // for this marker when interceptor also kick in during routing of trace events
+            event.setProperty(Exchange.TRACE_EVENT, Boolean.TRUE);
+            try {
+                // process the trace route
+                getTraceEventProducer(exchange).process(event);
+            } catch (Exception e) {
+                // log and ignore this as the original Exchange should be allowed to continue
+                LOG.error("Error processing trace event (original Exchange will continue): " + event, e);
+            }
+        }
+    }
+
+    @Override
+    public Object traceExchangeIn(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange) throws Exception {
+        traceExchange(node, target, traceInterceptor, exchange);
+        return null;
+    }
+
+    @Override
+    public void traceExchangeOut(ProcessorDefinition node, Processor target, TraceInterceptor traceInterceptor, Exchange exchange, Object traceState) throws Exception {
+        traceExchange(node, target, traceInterceptor, exchange);
+    }
+
+    @Override
+    public void start() throws Exception {
+        traceEventProducer = null;
+    }
+
+    @Override
+    public void stop() throws Exception {
+        if (traceEventProducer != null) {
+            ServiceHelper.stopService(traceEventProducer);
+        }
+    }
+
+}

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/processor/interceptor/DefaultTraceEventHandler.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/spi/CamelContextNameStrategy.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/spi/HasId.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/spi/ManagementObjectStrategy.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/spi/SubUnitOfWork.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/spi/SubUnitOfWorkCallback.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/CastUtils.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/InetAddressUtil.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/ModelHelper.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/UnitOfWorkHelper.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/concurrent/SizedScheduledExecutorService.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/main/java/org/apache/camel/util/concurrent/SynchronousExecutorService.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/MainTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/UnitOfWorkSyncProcessTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/ProxyBuilderTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/xml/XPathMockTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/xml/XPathNestedNamespaceTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTransformRouteTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/xml/XPathTransformTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/builder/xml/XsltTestErrorListenerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/converter/DateTimeConverterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/BeanAnnotationParameterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/BeanAnnotationParameterTwoTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/SimpleOgnlMapIssueTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/XPathFromFileExceptionTest.java
URL: http://svn.apache.org/viewvc/camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/XPathFromFileExceptionTest.java?rev=1222454&r1=1222453&r2=1222454&view=diff
==============================================================================
--- camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/XPathFromFileExceptionTest.java (original)
+++ camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/XPathFromFileExceptionTest.java Thu Dec 22 21:08:26 2011
@@ -1,86 +1,86 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.language;
-
-import java.io.File;
-
-import org.apache.camel.ContextTestSupport;
-import org.apache.camel.Exchange;
-import org.apache.camel.builder.RouteBuilder;
-
-/**
- *
- */
-public class XPathFromFileExceptionTest extends ContextTestSupport {
-
-    @Override
-    protected void setUp() throws Exception {
-        deleteDirectory("target/xpath");
-        super.setUp();
-    }
-
-    public void testXPathFromFileExceptionOk() throws Exception {
-        getMockEndpoint("mock:result").expectedMessageCount(1);
-        getMockEndpoint("mock:error").expectedMessageCount(0);
-
-        template.sendBodyAndHeader("file:target/xpath", "<hello>world!</hello>", Exchange.FILE_NAME, "hello.xml");
-
-        assertMockEndpointsSatisfied();
-
-        oneExchangeDone.matchesMockWaitTime();
-
-        File file = new File("target/xpath/hello.xml");
-        assertFalse("File should not exists " + file, file.exists());
-
-        file = new File("target/xpath/ok/hello.xml");
-        assertTrue("File should exists " + file, file.exists());
-    }
-
-    public void testXPathFromFileExceptionFail() throws Exception {
-        getMockEndpoint("mock:result").expectedMessageCount(0);
-        getMockEndpoint("mock:error").expectedMessageCount(1);
-
-        // the last tag is not ended properly
-        template.sendBodyAndHeader("file:target/xpath", "<hello>world!</hello", Exchange.FILE_NAME, "hello2.xml");
-
-        assertMockEndpointsSatisfied();
-
-        oneExchangeDone.matchesMockWaitTime();
-        
-        File file = new File("target/xpath/hello2.xml");
-        assertFalse("File should not exists " + file, file.exists());
-
-        file = new File("target/xpath/error/hello2.xml");
-        assertTrue("File should exists " + file, file.exists());
-    }
-
-    @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
-        return new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                from("file:target/xpath?moveFailed=error&move=ok")
-                    .onException(Exception.class)
-                        .to("mock:error")
-                    .end()
-                    .choice()
-                        .when().xpath("/hello").to("mock:result")
-                    .end();
-            }
-        };
-    }
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.language;
+
+import java.io.File;
+
+import org.apache.camel.ContextTestSupport;
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+
+/**
+ *
+ */
+public class XPathFromFileExceptionTest extends ContextTestSupport {
+
+    @Override
+    protected void setUp() throws Exception {
+        deleteDirectory("target/xpath");
+        super.setUp();
+    }
+
+    public void testXPathFromFileExceptionOk() throws Exception {
+        getMockEndpoint("mock:result").expectedMessageCount(1);
+        getMockEndpoint("mock:error").expectedMessageCount(0);
+
+        template.sendBodyAndHeader("file:target/xpath", "<hello>world!</hello>", Exchange.FILE_NAME, "hello.xml");
+
+        assertMockEndpointsSatisfied();
+
+        oneExchangeDone.matchesMockWaitTime();
+
+        File file = new File("target/xpath/hello.xml");
+        assertFalse("File should not exists " + file, file.exists());
+
+        file = new File("target/xpath/ok/hello.xml");
+        assertTrue("File should exists " + file, file.exists());
+    }
+
+    public void testXPathFromFileExceptionFail() throws Exception {
+        getMockEndpoint("mock:result").expectedMessageCount(0);
+        getMockEndpoint("mock:error").expectedMessageCount(1);
+
+        // the last tag is not ended properly
+        template.sendBodyAndHeader("file:target/xpath", "<hello>world!</hello", Exchange.FILE_NAME, "hello2.xml");
+
+        assertMockEndpointsSatisfied();
+
+        oneExchangeDone.matchesMockWaitTime();
+        
+        File file = new File("target/xpath/hello2.xml");
+        assertFalse("File should not exists " + file, file.exists());
+
+        file = new File("target/xpath/error/hello2.xml");
+        assertTrue("File should exists " + file, file.exists());
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                from("file:target/xpath?moveFailed=error&move=ok")
+                    .onException(Exception.class)
+                        .to("mock:error")
+                    .end()
+                    .choice()
+                        .when().xpath("/hello").to("mock:result")
+                    .end();
+            }
+        };
+    }
 }
\ No newline at end of file

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/language/XPathFromFileExceptionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/AddEventNotifierTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/DualManagedThreadPoolProfileTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/DualManagedThreadPoolWithIdTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCBRTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCamelContextDumpRoutesAsXmlTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCamelContextSuspendResumeTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCamelContextSuspendStartTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCamelContextUpdateRoutesFromXmlTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCustomBeanTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedCustomProcessorTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedMemoryIdempotentConsumerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRedeliverRouteOnlyTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRedeliverTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRouteAddSecondRouteNotRegisterNewRoutesTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRouteAddSecondRouteTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRouteNoAutoStartupTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRouteStopWithAbortAfterTimeoutTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedRouteUpdateRouteFromXmlTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagedStatisticsWithSplitterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/ManagementTestSupport.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/RecipientListProducerCacheLimitTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/TwoManagedCamelContextAutoAssignedNameClashTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/TwoManagedCamelContextClashTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/management/TwoManagedCamelContextTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/ChoiceDefinitionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/LoadRouteFromXmlTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/LoadRouteFromXmlWithInterceptTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/LoadRouteFromXmlWithOnExceptionTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/LoadRouteFromXmlWithPolicyTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/camel-core/src/test/java/org/apache/camel/model/ModelSanityCheckerTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1 +1,16 @@
+.pmd
+.checkstyle
+.ruleset
 target
+.settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-ahc/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,9 +1,16 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-amqp/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,8 +1,16 @@
-.project
 .pmd
 .checkstyle
-.classpath
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-apns/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,9 +1,16 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-atom/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,8 +1,16 @@
-.checkstyle
 .pmd
+.checkstyle
+.ruleset
 target
-eclipse-classes
+.settings
 .classpath
 .project
-.settings
-*.i??
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-aws/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,9 +1,16 @@
-eclipse-classes
 .pmd
 .checkstyle
-.project
-.classpath
+.ruleset
 target
 .settings
-activemq-data
-*.i??
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-bam/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,9 +1,16 @@
-.checkstyle
 .pmd
+.checkstyle
+.ruleset
 target
-eclipse-classes
+.settings
 .classpath
 .project
-.settings
-derby.log
-*.i??
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
+eclipse-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-bean-validator/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,9 +1,16 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
-classes
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Thu Dec 22 21:08:26 2011
@@ -1,8 +1,16 @@
-.project
-.checkstyle
 .pmd
-.classpath
+.checkstyle
+.ruleset
 target
 .settings
+.classpath
+.project
+.wtpmodules
+prj.el
+.jdee_classpath
+.jdee_sources
+velocity.log
 eclipse-classes
-*.i??
+*.ipr
+*.iml
+*.iws

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/BindyAbstractDataFormat.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/BindyFixedLengthFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/annotation/FixedLengthRecord.java
URL: http://svn.apache.org/viewvc/camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/annotation/FixedLengthRecord.java?rev=1222454&r1=1222453&r2=1222454&view=diff
==============================================================================
--- camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/annotation/FixedLengthRecord.java (original)
+++ camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/annotation/FixedLengthRecord.java Thu Dec 22 21:08:26 2011
@@ -1,63 +1,63 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.dataformat.bindy.annotation;
-
-import java.lang.annotation.Documented;
-import java.lang.annotation.Retention;
-import java.lang.annotation.RetentionPolicy;
-
-/**
- * This annotation represents the root class of the model. When a 
- * fixed-length record must be described in the model we will use this
- * annotation to split the data during the unmarshal process.
- */
-@Documented
-@Retention(RetentionPolicy.RUNTIME)
-public @interface FixedLengthRecord {
-
-    /**
-     * Name describing the record (optional)
-     * 
-     * @return String
-     */
-    String name() default "";
-
-    /**
-     * Character to be used to add a carriage return after each record
-     * (optional) Three values can be used : WINDOWS, UNIX or MAC
-     * 
-     * @return String
-     */
-    String crlf() default "WINDOWS";
-    
-    /**
-     * The char to pad with.
-     * @return the char to pad with if the record is set to a fixed length;
-     */
-    char paddingChar() default ' ';
-    
-    /**
-     * The fixed length of the record. It means that the record will always be that long padded with {#paddingChar()}'s
-     * @return the length of the record.
-     */
-    int length() default 0;
-
-    boolean hasHeader() default false;
-    
-    boolean hasFooter() default false;
-
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.dataformat.bindy.annotation;
+
+import java.lang.annotation.Documented;
+import java.lang.annotation.Retention;
+import java.lang.annotation.RetentionPolicy;
+
+/**
+ * This annotation represents the root class of the model. When a 
+ * fixed-length record must be described in the model we will use this
+ * annotation to split the data during the unmarshal process.
+ */
+@Documented
+@Retention(RetentionPolicy.RUNTIME)
+public @interface FixedLengthRecord {
+
+    /**
+     * Name describing the record (optional)
+     * 
+     * @return String
+     */
+    String name() default "";
+
+    /**
+     * Character to be used to add a carriage return after each record
+     * (optional) Three values can be used : WINDOWS, UNIX or MAC
+     * 
+     * @return String
+     */
+    String crlf() default "WINDOWS";
+    
+    /**
+     * The char to pad with.
+     * @return the char to pad with if the record is set to a fixed length;
+     */
+    char paddingChar() default ' ';
+    
+    /**
+     * The fixed length of the record. It means that the record will always be that long padded with {#paddingChar()}'s
+     * @return the length of the record.
+     */
+    int length() default 0;
+
+    boolean hasHeader() default false;
+    
+    boolean hasFooter() default false;
+
+}

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/annotation/FixedLengthRecord.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/main/java/org/apache/camel/dataformat/bindy/fixed/BindyFixedLengthDataFormat.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindyDoubleQuotesCsvUnmarshallTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindyInlinedQuotesCsvUnmarshallTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindyPipeDelimiterTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySimpleCsvRemoveWhitespaceUnmarshallTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySingleQuotesCsvUnmarshallTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindyTabSeparatorTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv2/BindyMarshalWithQuoteTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv2/BindyUnmarshalCommaIssueTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv2/WeatherModel.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fix/BindySimpleKeyValuePairWithoutSectionMarshallDslTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallTest.java
URL: http://svn.apache.org/viewvc/camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallTest.java?rev=1222454&r1=1222453&r2=1222454&view=diff
==============================================================================
--- camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallTest.java (original)
+++ camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallTest.java Thu Dec 22 21:08:26 2011
@@ -1,256 +1,256 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.dataformat.bindy.fixed.marshall.simple;
-
-import java.math.BigDecimal;
-import java.util.ArrayList;
-import java.util.Calendar;
-import java.util.Date;
-import java.util.GregorianCalendar;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-import org.apache.camel.EndpointInject;
-import org.apache.camel.LoggingLevel;
-import org.apache.camel.Produce;
-import org.apache.camel.ProducerTemplate;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.dataformat.bindy.annotation.DataField;
-import org.apache.camel.dataformat.bindy.annotation.FixedLengthRecord;
-import org.apache.camel.dataformat.bindy.fixed.BindyFixedLengthDataFormat;
-import org.apache.camel.dataformat.bindy.model.simple.oneclass.Order;
-import org.apache.camel.model.dataformat.BindyType;
-import org.apache.camel.processor.interceptor.Tracer;
-import org.junit.Test;
-import org.springframework.test.annotation.DirtiesContext;
-import org.springframework.test.context.ContextConfiguration;
-import org.springframework.test.context.junit4.AbstractJUnit4SpringContextTests;
-
-@ContextConfiguration
-public class BindySimpleFixedLengthMarshallTest extends AbstractJUnit4SpringContextTests {
-    
-    private static final String URI_MOCK_RESULT = "mock:result";
-    private static final String URI_MOCK_ERROR = "mock:error";
-    private static final String URI_DIRECT_START = "direct:start";
-
-    private List<Map<String, Object>> models = new ArrayList<Map<String, Object>>();
-    private String expected;
-
-    @Produce(uri = URI_DIRECT_START)
-    private ProducerTemplate template;
-
-    @EndpointInject(uri = URI_MOCK_RESULT)
-    private MockEndpoint result;
-
-    @EndpointInject(uri = URI_MOCK_ERROR)
-    private MockEndpoint error;
-
-    @Test
-    @DirtiesContext
-    public void testMarshallMessage() throws Exception {
-
-        expected = "10A9  PaulineM    ISINXD12345678BUYShare000002500.45USD01-08-2009\r\n";
-        result.expectedBodiesReceived(expected);
-
-        template.sendBody(generateModel());
-        result.assertIsSatisfied();
-    }
-
-    public List<Map<String, Object>> generateModel() {
-        Map<String, Object> modelObjects = new HashMap<String, Object>();
-
-        Order order = new Order();
-        order.setOrderNr(10);
-        order.setOrderType("BUY");
-        order.setClientNr("A9");
-        order.setFirstName("Pauline");
-        order.setLastName("M");
-        order.setAmount(new BigDecimal("2500.45"));
-        order.setInstrumentCode("ISIN");
-        order.setInstrumentNumber("XD12345678");
-        order.setInstrumentType("Share");
-        order.setCurrency("USD");
-
-        Calendar calendar = new GregorianCalendar();
-        calendar.set(2009, 7, 1);
-        order.setOrderDate(calendar.getTime());
-
-        modelObjects.put(order.getClass().getName(), order);
-
-        models.add(modelObjects);
-
-        return models;
-    }
-
-    public static class ContextConfig extends RouteBuilder {
-        public void configure() {
-
-            Tracer tracer = new Tracer();
-            tracer.setLogLevel(LoggingLevel.ERROR);
-            tracer.setLogName("org.apache.camel.bindy");
-
-            getContext().addInterceptStrategy(tracer);
-
-            // default should errors go to mock:error
-            errorHandler(deadLetterChannel(URI_MOCK_ERROR).redeliveryDelay(0));
-
-            onException(Exception.class).maximumRedeliveries(0).handled(true);
-
-            from(URI_DIRECT_START)
-                    .marshal().bindy(BindyType.Fixed, "org.apache.camel.dataformat.bindy.fixed.marshall.simple")
-                    .to(URI_MOCK_RESULT);
-        }
-
-    }
-
-    @FixedLengthRecord(length = 65, paddingChar = ' ')
-    public static class Order {
-
-        @DataField(pos = 1, length = 2)
-        private int orderNr;
-
-        @DataField(pos = 3, length = 2)
-        private String clientNr;
-
-        @DataField(pos = 5, length = 9)
-        private String firstName;
-
-        @DataField(pos = 14, length = 5, align = "L")
-        private String lastName;
-
-        @DataField(pos = 19, length = 4)
-        private String instrumentCode;
-
-        @DataField(pos = 23, length = 10)
-        private String instrumentNumber;
-
-        @DataField(pos = 33, length = 3)
-        private String orderType;
-
-        @DataField(pos = 36, length = 5)
-        private String instrumentType;
-
-        @DataField(pos = 41, precision = 2, length = 12, paddingChar = '0')
-        private BigDecimal amount;
-
-        @DataField(pos = 53, length = 3)
-        private String currency;
-
-        @DataField(pos = 56, length = 10, pattern = "dd-MM-yyyy")
-        private Date orderDate;
-
-
-        public int getOrderNr() {
-            return orderNr;
-        }
-
-        public void setOrderNr(int orderNr) {
-            this.orderNr = orderNr;
-        }
-
-        public String getClientNr() {
-            return clientNr;
-        }
-
-        public void setClientNr(String clientNr) {
-            this.clientNr = clientNr;
-        }
-
-        public String getFirstName() {
-            return firstName;
-        }
-
-        public void setFirstName(String firstName) {
-            this.firstName = firstName;
-        }
-
-        public String getLastName() {
-            return lastName;
-        }
-
-        public void setLastName(String lastName) {
-            this.lastName = lastName;
-        }
-
-        public String getInstrumentCode() {
-            return instrumentCode;
-        }
-
-        public void setInstrumentCode(String instrumentCode) {
-            this.instrumentCode = instrumentCode;
-        }
-
-        public String getInstrumentNumber() {
-            return instrumentNumber;
-        }
-
-        public void setInstrumentNumber(String instrumentNumber) {
-            this.instrumentNumber = instrumentNumber;
-        }
-
-        public String getOrderType() {
-            return orderType;
-        }
-
-        public void setOrderType(String orderType) {
-            this.orderType = orderType;
-        }
-
-        public String getInstrumentType() {
-            return instrumentType;
-        }
-
-        public void setInstrumentType(String instrumentType) {
-            this.instrumentType = instrumentType;
-        }
-
-        public BigDecimal getAmount() {
-            return amount;
-        }
-
-        public void setAmount(BigDecimal amount) {
-            this.amount = amount;
-        }
-
-        public String getCurrency() {
-            return currency;
-        }
-
-        public void setCurrency(String currency) {
-            this.currency = currency;
-        }
-
-        public Date getOrderDate() {
-            return orderDate;
-        }
-
-        public void setOrderDate(Date orderDate) {
-            this.orderDate = orderDate;
-        }
-
-        @Override
-        public String toString() {
-            return "Model : " + Order.class.getName() + " : " + this.orderNr + ", " + this.orderType + ", " + String.valueOf(this.amount) + ", " + this.instrumentCode + ", "
-                   + this.instrumentNumber + ", " + this.instrumentType + ", " + this.currency + ", " + this.clientNr + ", " + this.firstName + ", " + this.lastName + ", "
-                   + String.valueOf(this.orderDate);
-        }
-    }
-
-
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.dataformat.bindy.fixed.marshall.simple;
+
+import java.math.BigDecimal;
+import java.util.ArrayList;
+import java.util.Calendar;
+import java.util.Date;
+import java.util.GregorianCalendar;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+import org.apache.camel.EndpointInject;
+import org.apache.camel.LoggingLevel;
+import org.apache.camel.Produce;
+import org.apache.camel.ProducerTemplate;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.dataformat.bindy.annotation.DataField;
+import org.apache.camel.dataformat.bindy.annotation.FixedLengthRecord;
+import org.apache.camel.dataformat.bindy.fixed.BindyFixedLengthDataFormat;
+import org.apache.camel.dataformat.bindy.model.simple.oneclass.Order;
+import org.apache.camel.model.dataformat.BindyType;
+import org.apache.camel.processor.interceptor.Tracer;
+import org.junit.Test;
+import org.springframework.test.annotation.DirtiesContext;
+import org.springframework.test.context.ContextConfiguration;
+import org.springframework.test.context.junit4.AbstractJUnit4SpringContextTests;
+
+@ContextConfiguration
+public class BindySimpleFixedLengthMarshallTest extends AbstractJUnit4SpringContextTests {
+    
+    private static final String URI_MOCK_RESULT = "mock:result";
+    private static final String URI_MOCK_ERROR = "mock:error";
+    private static final String URI_DIRECT_START = "direct:start";
+
+    private List<Map<String, Object>> models = new ArrayList<Map<String, Object>>();
+    private String expected;
+
+    @Produce(uri = URI_DIRECT_START)
+    private ProducerTemplate template;
+
+    @EndpointInject(uri = URI_MOCK_RESULT)
+    private MockEndpoint result;
+
+    @EndpointInject(uri = URI_MOCK_ERROR)
+    private MockEndpoint error;
+
+    @Test
+    @DirtiesContext
+    public void testMarshallMessage() throws Exception {
+
+        expected = "10A9  PaulineM    ISINXD12345678BUYShare000002500.45USD01-08-2009\r\n";
+        result.expectedBodiesReceived(expected);
+
+        template.sendBody(generateModel());
+        result.assertIsSatisfied();
+    }
+
+    public List<Map<String, Object>> generateModel() {
+        Map<String, Object> modelObjects = new HashMap<String, Object>();
+
+        Order order = new Order();
+        order.setOrderNr(10);
+        order.setOrderType("BUY");
+        order.setClientNr("A9");
+        order.setFirstName("Pauline");
+        order.setLastName("M");
+        order.setAmount(new BigDecimal("2500.45"));
+        order.setInstrumentCode("ISIN");
+        order.setInstrumentNumber("XD12345678");
+        order.setInstrumentType("Share");
+        order.setCurrency("USD");
+
+        Calendar calendar = new GregorianCalendar();
+        calendar.set(2009, 7, 1);
+        order.setOrderDate(calendar.getTime());
+
+        modelObjects.put(order.getClass().getName(), order);
+
+        models.add(modelObjects);
+
+        return models;
+    }
+
+    public static class ContextConfig extends RouteBuilder {
+        public void configure() {
+
+            Tracer tracer = new Tracer();
+            tracer.setLogLevel(LoggingLevel.ERROR);
+            tracer.setLogName("org.apache.camel.bindy");
+
+            getContext().addInterceptStrategy(tracer);
+
+            // default should errors go to mock:error
+            errorHandler(deadLetterChannel(URI_MOCK_ERROR).redeliveryDelay(0));
+
+            onException(Exception.class).maximumRedeliveries(0).handled(true);
+
+            from(URI_DIRECT_START)
+                    .marshal().bindy(BindyType.Fixed, "org.apache.camel.dataformat.bindy.fixed.marshall.simple")
+                    .to(URI_MOCK_RESULT);
+        }
+
+    }
+
+    @FixedLengthRecord(length = 65, paddingChar = ' ')
+    public static class Order {
+
+        @DataField(pos = 1, length = 2)
+        private int orderNr;
+
+        @DataField(pos = 3, length = 2)
+        private String clientNr;
+
+        @DataField(pos = 5, length = 9)
+        private String firstName;
+
+        @DataField(pos = 14, length = 5, align = "L")
+        private String lastName;
+
+        @DataField(pos = 19, length = 4)
+        private String instrumentCode;
+
+        @DataField(pos = 23, length = 10)
+        private String instrumentNumber;
+
+        @DataField(pos = 33, length = 3)
+        private String orderType;
+
+        @DataField(pos = 36, length = 5)
+        private String instrumentType;
+
+        @DataField(pos = 41, precision = 2, length = 12, paddingChar = '0')
+        private BigDecimal amount;
+
+        @DataField(pos = 53, length = 3)
+        private String currency;
+
+        @DataField(pos = 56, length = 10, pattern = "dd-MM-yyyy")
+        private Date orderDate;
+
+
+        public int getOrderNr() {
+            return orderNr;
+        }
+
+        public void setOrderNr(int orderNr) {
+            this.orderNr = orderNr;
+        }
+
+        public String getClientNr() {
+            return clientNr;
+        }
+
+        public void setClientNr(String clientNr) {
+            this.clientNr = clientNr;
+        }
+
+        public String getFirstName() {
+            return firstName;
+        }
+
+        public void setFirstName(String firstName) {
+            this.firstName = firstName;
+        }
+
+        public String getLastName() {
+            return lastName;
+        }
+
+        public void setLastName(String lastName) {
+            this.lastName = lastName;
+        }
+
+        public String getInstrumentCode() {
+            return instrumentCode;
+        }
+
+        public void setInstrumentCode(String instrumentCode) {
+            this.instrumentCode = instrumentCode;
+        }
+
+        public String getInstrumentNumber() {
+            return instrumentNumber;
+        }
+
+        public void setInstrumentNumber(String instrumentNumber) {
+            this.instrumentNumber = instrumentNumber;
+        }
+
+        public String getOrderType() {
+            return orderType;
+        }
+
+        public void setOrderType(String orderType) {
+            this.orderType = orderType;
+        }
+
+        public String getInstrumentType() {
+            return instrumentType;
+        }
+
+        public void setInstrumentType(String instrumentType) {
+            this.instrumentType = instrumentType;
+        }
+
+        public BigDecimal getAmount() {
+            return amount;
+        }
+
+        public void setAmount(BigDecimal amount) {
+            this.amount = amount;
+        }
+
+        public String getCurrency() {
+            return currency;
+        }
+
+        public void setCurrency(String currency) {
+            this.currency = currency;
+        }
+
+        public Date getOrderDate() {
+            return orderDate;
+        }
+
+        public void setOrderDate(Date orderDate) {
+            this.orderDate = orderDate;
+        }
+
+        @Override
+        public String toString() {
+            return "Model : " + Order.class.getName() + " : " + this.orderNr + ", " + this.orderType + ", " + String.valueOf(this.amount) + ", " + this.instrumentCode + ", "
+                   + this.instrumentNumber + ", " + this.instrumentType + ", " + this.currency + ", " + this.clientNr + ", " + this.firstName + ", " + this.lastName + ", "
+                   + String.valueOf(this.orderDate);
+        }
+    }
+
+
+}

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallTest.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallWithClipAndTrimTest.java
URL: http://svn.apache.org/viewvc/camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallWithClipAndTrimTest.java?rev=1222454&r1=1222453&r2=1222454&view=diff
==============================================================================
--- camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallWithClipAndTrimTest.java (original)
+++ camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallWithClipAndTrimTest.java Thu Dec 22 21:08:26 2011
@@ -1,223 +1,223 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.camel.dataformat.bindy.fixed.marshall.simple;
-
-import java.math.BigDecimal;
-import java.util.ArrayList;
-import java.util.Calendar;
-import java.util.Date;
-import java.util.GregorianCalendar;
-import java.util.HashMap;
-import java.util.List;
-import java.util.Map;
-
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.dataformat.bindy.annotation.DataField;
-import org.apache.camel.dataformat.bindy.annotation.FixedLengthRecord;
-import org.apache.camel.dataformat.bindy.fixed.BindyFixedLengthDataFormat;
-import org.apache.camel.test.CamelTestSupport;
-import org.junit.Test;
-
-public class BindySimpleFixedLengthMarshallWithClipAndTrimTest extends CamelTestSupport {
-
-    private List<Map<String, Object>> models = new ArrayList<Map<String, Object>>();
-
-    @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
-        return new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                BindyFixedLengthDataFormat bindy = new BindyFixedLengthDataFormat("org.apache.camel.dataformat.bindy.fixed.marshall.simple");
-
-                from("direct:start")
-                    .marshal(bindy)
-                    .to("mock:result");
-            }
-        };
-    }
-
-    @Test
-    public void testMarshallMessage() throws Exception {
-        String expected = "10A9Madame deM    ISINXD12345678BUYShare000002500.45USD01-08-2009\r\n";
-        getMockEndpoint("mock:result").expectedBodiesReceived(expected);
-
-        template.sendBody("direct:start", generateModel());
-
-        assertMockEndpointsSatisfied();
-    }
-
-    public List<Map<String, Object>> generateModel() {
-        Map<String, Object> modelObjects = new HashMap<String, Object>();
-
-        Order order = new Order();
-        order.setOrderNr(10);
-        order.setOrderType("BUY");
-        order.setClientNr("A9  ");
-        order.setFirstName("Madame de Sol");
-        order.setLastName("M");
-        order.setAmount(new BigDecimal("2500.45"));
-        order.setInstrumentCode("ISIN");
-        order.setInstrumentNumber("XD12345678");
-        order.setInstrumentType("Share");
-        order.setCurrency("USD");
-
-        Calendar calendar = new GregorianCalendar();
-        calendar.set(2009, 7, 1);
-        order.setOrderDate(calendar.getTime());
-
-        modelObjects.put(order.getClass().getName(), order);
-
-        models.add(modelObjects);
-
-        return models;
-    }
-
-    @FixedLengthRecord(length = 65, paddingChar = ' ')
-    public static class Order {
-
-        @DataField(pos = 1, length = 2)
-        private int orderNr;
-
-        @DataField(pos = 3, length = 2, trim = true)
-        private String clientNr;
-
-        @DataField(pos = 5, length = 9, clip = true)
-        private String firstName;
-
-        @DataField(pos = 14, length = 5, align = "L")
-        private String lastName;
-
-        @DataField(pos = 19, length = 4)
-        private String instrumentCode;
-
-        @DataField(pos = 23, length = 10)
-        private String instrumentNumber;
-
-        @DataField(pos = 33, length = 3)
-        private String orderType;
-
-        @DataField(pos = 36, length = 5)
-        private String instrumentType;
-
-        @DataField(pos = 41, precision = 2, length = 12, paddingChar = '0')
-        private BigDecimal amount;
-
-        @DataField(pos = 53, length = 3)
-        private String currency;
-
-        @DataField(pos = 56, length = 10, pattern = "dd-MM-yyyy")
-        private Date orderDate;
-
-
-        public int getOrderNr() {
-            return orderNr;
-        }
-
-        public void setOrderNr(int orderNr) {
-            this.orderNr = orderNr;
-        }
-
-        public String getClientNr() {
-            return clientNr;
-        }
-
-        public void setClientNr(String clientNr) {
-            this.clientNr = clientNr;
-        }
-
-        public String getFirstName() {
-            return firstName;
-        }
-
-        public void setFirstName(String firstName) {
-            this.firstName = firstName;
-        }
-
-        public String getLastName() {
-            return lastName;
-        }
-
-        public void setLastName(String lastName) {
-            this.lastName = lastName;
-        }
-
-        public String getInstrumentCode() {
-            return instrumentCode;
-        }
-
-        public void setInstrumentCode(String instrumentCode) {
-            this.instrumentCode = instrumentCode;
-        }
-
-        public String getInstrumentNumber() {
-            return instrumentNumber;
-        }
-
-        public void setInstrumentNumber(String instrumentNumber) {
-            this.instrumentNumber = instrumentNumber;
-        }
-
-        public String getOrderType() {
-            return orderType;
-        }
-
-        public void setOrderType(String orderType) {
-            this.orderType = orderType;
-        }
-
-        public String getInstrumentType() {
-            return instrumentType;
-        }
-
-        public void setInstrumentType(String instrumentType) {
-            this.instrumentType = instrumentType;
-        }
-
-        public BigDecimal getAmount() {
-            return amount;
-        }
-
-        public void setAmount(BigDecimal amount) {
-            this.amount = amount;
-        }
-
-        public String getCurrency() {
-            return currency;
-        }
-
-        public void setCurrency(String currency) {
-            this.currency = currency;
-        }
-
-        public Date getOrderDate() {
-            return orderDate;
-        }
-
-        public void setOrderDate(Date orderDate) {
-            this.orderDate = orderDate;
-        }
-
-        @Override
-        public String toString() {
-            return "Model : " + Order.class.getName() + " : " + this.orderNr + ", " + this.orderType + ", " + String.valueOf(this.amount) + ", " + this.instrumentCode + ", "
-                    + this.instrumentNumber + ", " + this.instrumentType + ", " + this.currency + ", " + this.clientNr + ", " + this.firstName + ", " + this.lastName + ", "
-                    + String.valueOf(this.orderDate);
-        }
-    }
-
-
-}
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *      http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.camel.dataformat.bindy.fixed.marshall.simple;
+
+import java.math.BigDecimal;
+import java.util.ArrayList;
+import java.util.Calendar;
+import java.util.Date;
+import java.util.GregorianCalendar;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Map;
+
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.dataformat.bindy.annotation.DataField;
+import org.apache.camel.dataformat.bindy.annotation.FixedLengthRecord;
+import org.apache.camel.dataformat.bindy.fixed.BindyFixedLengthDataFormat;
+import org.apache.camel.test.CamelTestSupport;
+import org.junit.Test;
+
+public class BindySimpleFixedLengthMarshallWithClipAndTrimTest extends CamelTestSupport {
+
+    private List<Map<String, Object>> models = new ArrayList<Map<String, Object>>();
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                BindyFixedLengthDataFormat bindy = new BindyFixedLengthDataFormat("org.apache.camel.dataformat.bindy.fixed.marshall.simple");
+
+                from("direct:start")
+                    .marshal(bindy)
+                    .to("mock:result");
+            }
+        };
+    }
+
+    @Test
+    public void testMarshallMessage() throws Exception {
+        String expected = "10A9Madame deM    ISINXD12345678BUYShare000002500.45USD01-08-2009\r\n";
+        getMockEndpoint("mock:result").expectedBodiesReceived(expected);
+
+        template.sendBody("direct:start", generateModel());
+
+        assertMockEndpointsSatisfied();
+    }
+
+    public List<Map<String, Object>> generateModel() {
+        Map<String, Object> modelObjects = new HashMap<String, Object>();
+
+        Order order = new Order();
+        order.setOrderNr(10);
+        order.setOrderType("BUY");
+        order.setClientNr("A9  ");
+        order.setFirstName("Madame de Sol");
+        order.setLastName("M");
+        order.setAmount(new BigDecimal("2500.45"));
+        order.setInstrumentCode("ISIN");
+        order.setInstrumentNumber("XD12345678");
+        order.setInstrumentType("Share");
+        order.setCurrency("USD");
+
+        Calendar calendar = new GregorianCalendar();
+        calendar.set(2009, 7, 1);
+        order.setOrderDate(calendar.getTime());
+
+        modelObjects.put(order.getClass().getName(), order);
+
+        models.add(modelObjects);
+
+        return models;
+    }
+
+    @FixedLengthRecord(length = 65, paddingChar = ' ')
+    public static class Order {
+
+        @DataField(pos = 1, length = 2)
+        private int orderNr;
+
+        @DataField(pos = 3, length = 2, trim = true)
+        private String clientNr;
+
+        @DataField(pos = 5, length = 9, clip = true)
+        private String firstName;
+
+        @DataField(pos = 14, length = 5, align = "L")
+        private String lastName;
+
+        @DataField(pos = 19, length = 4)
+        private String instrumentCode;
+
+        @DataField(pos = 23, length = 10)
+        private String instrumentNumber;
+
+        @DataField(pos = 33, length = 3)
+        private String orderType;
+
+        @DataField(pos = 36, length = 5)
+        private String instrumentType;
+
+        @DataField(pos = 41, precision = 2, length = 12, paddingChar = '0')
+        private BigDecimal amount;
+
+        @DataField(pos = 53, length = 3)
+        private String currency;
+
+        @DataField(pos = 56, length = 10, pattern = "dd-MM-yyyy")
+        private Date orderDate;
+
+
+        public int getOrderNr() {
+            return orderNr;
+        }
+
+        public void setOrderNr(int orderNr) {
+            this.orderNr = orderNr;
+        }
+
+        public String getClientNr() {
+            return clientNr;
+        }
+
+        public void setClientNr(String clientNr) {
+            this.clientNr = clientNr;
+        }
+
+        public String getFirstName() {
+            return firstName;
+        }
+
+        public void setFirstName(String firstName) {
+            this.firstName = firstName;
+        }
+
+        public String getLastName() {
+            return lastName;
+        }
+
+        public void setLastName(String lastName) {
+            this.lastName = lastName;
+        }
+
+        public String getInstrumentCode() {
+            return instrumentCode;
+        }
+
+        public void setInstrumentCode(String instrumentCode) {
+            this.instrumentCode = instrumentCode;
+        }
+
+        public String getInstrumentNumber() {
+            return instrumentNumber;
+        }
+
+        public void setInstrumentNumber(String instrumentNumber) {
+            this.instrumentNumber = instrumentNumber;
+        }
+
+        public String getOrderType() {
+            return orderType;
+        }
+
+        public void setOrderType(String orderType) {
+            this.orderType = orderType;
+        }
+
+        public String getInstrumentType() {
+            return instrumentType;
+        }
+
+        public void setInstrumentType(String instrumentType) {
+            this.instrumentType = instrumentType;
+        }
+
+        public BigDecimal getAmount() {
+            return amount;
+        }
+
+        public void setAmount(BigDecimal amount) {
+            this.amount = amount;
+        }
+
+        public String getCurrency() {
+            return currency;
+        }
+
+        public void setCurrency(String currency) {
+            this.currency = currency;
+        }
+
+        public Date getOrderDate() {
+            return orderDate;
+        }
+
+        public void setOrderDate(Date orderDate) {
+            this.orderDate = orderDate;
+        }
+
+        @Override
+        public String toString() {
+            return "Model : " + Order.class.getName() + " : " + this.orderNr + ", " + this.orderType + ", " + String.valueOf(this.amount) + ", " + this.instrumentCode + ", "
+                    + this.instrumentNumber + ", " + this.instrumentType + ", " + this.currency + ", " + this.clientNr + ", " + this.firstName + ", " + this.lastName + ", "
+                    + String.valueOf(this.orderDate);
+        }
+    }
+
+
+}

Propchange: camel/branches/camel-2.8.x/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fixed/marshall/simple/BindySimpleFixedLengthMarshallWithClipAndTrimTest.java
------------------------------------------------------------------------------
    svn:eol-style = native