You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by ja...@apache.org on 2009/01/28 21:20:32 UTC

svn commit: r738604 [2/3] - in /camel/trunk: 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/component/browse...

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorType.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorType.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorType.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/ProcessorType.java Wed Jan 28 20:20:28 2009
@@ -246,7 +246,7 @@
 
 
     /**
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">ExchangePattern:</a>
+     * <a href="http://camel.apache.org/exchange-pattern.html">ExchangePattern:</a>
      * set the ExchangePattern {@link ExchangePattern} into the exchange
      *
      * @param exchangePattern  instance of {@link ExchangePattern}
@@ -258,7 +258,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">ExchangePattern:</a>
+     * <a href="http://camel.apache.org/exchange-pattern.html">ExchangePattern:</a>
      * set the exchange's ExchangePattern {@link ExchangePattern} to be InOnly
      *
      *
@@ -270,8 +270,8 @@
 
     /**
      * Sends the message to the given endpoint using an
-     * <a href="http://activemq.apache.org/camel/event-message.html">Event Message</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOnly exchange pattern</a>
+     * <a href="http://camel.apache.org/event-message.html">Event Message</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOnly exchange pattern</a>
      *
      * @param uri The endpoint uri which is used for sending the exchange
      * @return the builder
@@ -282,8 +282,8 @@
 
     /**
      * Sends the message to the given endpoint using an
-     * <a href="http://activemq.apache.org/camel/event-message.html">Event Message</a> or 
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOnly exchange pattern</a>
+     * <a href="http://camel.apache.org/event-message.html">Event Message</a> or 
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOnly exchange pattern</a>
      *
      * @param endpoint The endpoint which is used for sending the exchange
      * @return the builder
@@ -295,8 +295,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/event-message.html">Event Message</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOnly exchange pattern</a>
+     * <a href="http://camel.apache.org/event-message.html">Event Message</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOnly exchange pattern</a>
      *
      * @param uris  list of endpoints to send to
      * @return the builder
@@ -308,8 +308,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/event-message.html">Event Message</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOnly exchange pattern</a>
+     * <a href="http://camel.apache.org/event-message.html">Event Message</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOnly exchange pattern</a>
      *
      * @param endpoints  list of endpoints to send to
      * @return the builder
@@ -320,8 +320,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/event-message.html">Event Message</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOnly exchange pattern</a>
+     * <a href="http://camel.apache.org/event-message.html">Event Message</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOnly exchange pattern</a>
      *
      * @param endpoints  list of endpoints to send to
      * @return the builder
@@ -332,7 +332,7 @@
 
 
     /**
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">ExchangePattern:</a>
+     * <a href="http://camel.apache.org/exchange-pattern.html">ExchangePattern:</a>
      * set the exchange's ExchangePattern {@link ExchangePattern} to be InOut
      *
      *
@@ -344,8 +344,8 @@
 
     /**
      * Sends the message to the given endpoint using an
-     * <a href="http://activemq.apache.org/camel/request-reply.html">Request Reply</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOut exchange pattern</a>
+     * <a href="http://camel.apache.org/request-reply.html">Request Reply</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOut exchange pattern</a>
      *
      * @param uri The endpoint uri which is used for sending the exchange
      * @return the builder
@@ -357,8 +357,8 @@
 
     /**
      * Sends the message to the given endpoint using an
-     * <a href="http://activemq.apache.org/camel/request-reply.html">Request Reply</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOut exchange pattern</a>
+     * <a href="http://camel.apache.org/request-reply.html">Request Reply</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOut exchange pattern</a>
      *
      * @param endpoint The endpoint which is used for sending the exchange
      * @return the builder
@@ -369,8 +369,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/request-reply.html">Request Reply</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOut exchange pattern</a>
+     * <a href="http://camel.apache.org/request-reply.html">Request Reply</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOut exchange pattern</a>
      *
      * @param uris  list of endpoints to send to
      * @return the builder
@@ -382,8 +382,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/request-reply.html">Request Reply</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOut exchange pattern</a>
+     * <a href="http://camel.apache.org/request-reply.html">Request Reply</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOut exchange pattern</a>
      *
      * @param endpoints  list of endpoints to send to
      * @return the builder
@@ -394,8 +394,8 @@
 
     /**
      * Sends the message to the given endpoints using an
-     * <a href="http://activemq.apache.org/camel/request-reply.html">Request Reply</a> or
-     * <a href="http://activemq.apache.org/camel/exchange-pattern.html">InOut exchange pattern</a>
+     * <a href="http://camel.apache.org/request-reply.html">Request Reply</a> or
+     * <a href="http://camel.apache.org/exchange-pattern.html">InOut exchange pattern</a>
      *
      * @param endpoints  list of endpoints to send to
      * @return the builder
@@ -406,7 +406,7 @@
 
 
     /**
-     * <a href="http://activemq.apache.org/camel/multicast.html">Multicast EIP:</a>
+     * <a href="http://camel.apache.org/multicast.html">Multicast EIP:</a>
      * Multicasts messages to all its child outputs; so that each processor and
      * destination gets a copy of the original message to avoid the processors
      * interfering with each other.
@@ -420,7 +420,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/multicast.html">Multicast EIP:</a>
+     * <a href="http://camel.apache.org/multicast.html">Multicast EIP:</a>
      * Multicasts messages to all its child outputs; so that each processor and
      * destination gets a copy of the original message to avoid the processors
      * interfering with each other.
@@ -439,7 +439,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/multicast.html">Multicast EIP:</a>
+     * <a href="http://camel.apache.org/multicast.html">Multicast EIP:</a>
      * Multicasts messages to all its child outputs; so that each processor and
      * destination gets a copy of the original message to avoid the processors
      * interfering with each other.
@@ -456,7 +456,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/pipes-nd-filters.html">Pipes and Filters EIP:</a>
+     * <a href="http://camel.apache.org/pipes-nd-filters.html">Pipes and Filters EIP:</a>
      * Creates a {@link Pipeline} of the list of endpoints so that the message
      * will get processed by each endpoint in turn and for request/response the
      * output of one endpoint will be the input of the next endpoint
@@ -469,7 +469,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/pipes-nd-filters.html">Pipes and Filters EIP:</a>
+     * <a href="http://camel.apache.org/pipes-nd-filters.html">Pipes and Filters EIP:</a>
      * Creates a {@link Pipeline} of the list of endpoints so that the message
      * will get processed by each endpoint in turn and for request/response the
      * output of one endpoint will be the input of the next endpoint
@@ -482,7 +482,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/pipes-nd-filters.html">Pipes and Filters EIP:</a>
+     * <a href="http://camel.apache.org/pipes-nd-filters.html">Pipes and Filters EIP:</a>
      * Creates a {@link Pipeline} of the list of endpoints so that the message
      * will get processed by each endpoint in turn and for request/response the
      * output of one endpoint will be the input of the next endpoint
@@ -539,7 +539,7 @@
     }
     
     /**
-     * <a href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent consumer EIP:</a>
+     * <a href="http://camel.apache.org/idempotent-consumer.html">Idempotent consumer EIP:</a>
      * Creates an {@link org.apache.camel.processor.idempotent.IdempotentConsumer IdempotentConsumer}
      * to avoid duplicate messages
      *      
@@ -552,7 +552,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent consumer EIP:</a>
+     * <a href="http://camel.apache.org/idempotent-consumer.html">Idempotent consumer EIP:</a>
      * Creates an {@link org.apache.camel.processor.idempotent.IdempotentConsumer IdempotentConsumer}
      * to avoid duplicate messages
      *
@@ -568,7 +568,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent consumer EIP:</a>
+     * <a href="http://camel.apache.org/idempotent-consumer.html">Idempotent consumer EIP:</a>
      * Creates an {@link org.apache.camel.processor.idempotent.IdempotentConsumer IdempotentConsumer}
      * to avoid duplicate messages
      *
@@ -583,7 +583,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-filter.html">Message Filter EIP:</a>
+     * <a href="http://camel.apache.org/message-filter.html">Message Filter EIP:</a>
      * Creates a predicate expression which only if it is <tt>true</tt> then the
      * exchange is forwarded to the destination
      *
@@ -596,7 +596,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-filter.html">Message Filter EIP:</a>
+     * <a href="http://camel.apache.org/message-filter.html">Message Filter EIP:</a>
      * Creates a predicate which is applied and only if it is <tt>true</tt> then the
      * exchange is forwarded to the destination
      *
@@ -610,7 +610,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-filter.html">Message Filter EIP:</a>
+     * <a href="http://camel.apache.org/message-filter.html">Message Filter EIP:</a>
      * Creates a predicate expression which only if it is <tt>true</tt> then the
      * exchange is forwarded to the destination
      *
@@ -625,7 +625,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-filter.html">Message Filter EIP:</a>
+     * <a href="http://camel.apache.org/message-filter.html">Message Filter EIP:</a>
      * Creates a predicate language expression which only if it is <tt>true</tt> then the
      * exchange is forwarded to the destination
      *
@@ -638,7 +638,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/load-balancer.html">Load Balancer EIP:</a>
+     * <a href="http://camel.apache.org/load-balancer.html">Load Balancer EIP:</a>
      * Creates a loadbalance
      *
      * @return  the builder
@@ -651,7 +651,7 @@
 
 
     /**
-     * <a href="http://activemq.apache.org/camel/content-based-router.html">Content Based Router EIP:</a>
+     * <a href="http://camel.apache.org/content-based-router.html">Content Based Router EIP:</a>
      * Creates a choice of one or more predicates with an otherwise clause
      *
      * @return the builder for a choice expression
@@ -674,7 +674,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/recipient-list.html">Recipient List EIP:</a>
+     * <a href="http://camel.apache.org/recipient-list.html">Recipient List EIP:</a>
      * Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
      *
      * @param recipients expression to decide the destinations
@@ -687,7 +687,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/recipient-list.html">Recipient List EIP:</a>
+     * <a href="http://camel.apache.org/recipient-list.html">Recipient List EIP:</a>
      * Creates a dynamic recipient list allowing you to route messages to a number of dynamically specified recipients
      *
      * @return the expression clause to configure the expression to decide the destinations
@@ -701,7 +701,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/routing-slip.html">Routing Slip EIP:</a>
+     * <a href="http://camel.apache.org/routing-slip.html">Routing Slip EIP:</a>
      * Creates a routing slip allowing you to route a message consecutively through a series of processing
      * steps where the sequence of steps is not known at design time and can vary for each message.
      *
@@ -718,7 +718,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/routing-slip.html">Routing Slip EIP:</a>
+     * <a href="http://camel.apache.org/routing-slip.html">Routing Slip EIP:</a>
      * Creates a routing slip allowing you to route a message consecutively through a series of processing
      * steps where the sequence of steps is not known at design time and can vary for each message.
      * <p>
@@ -735,7 +735,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * This splitter responds with the latest message returned from destination
@@ -750,7 +750,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * This splitter responds with the latest message returned from destination
@@ -766,7 +766,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -783,7 +783,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -800,7 +800,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -818,7 +818,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -839,7 +839,7 @@
     }    
     
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -857,7 +857,7 @@
 
     /**
      /**
-      * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+      * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
       * Creates a splitter allowing you split a message into a number of pieces and process them individually.
       * <p>
       * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -876,7 +876,7 @@
     }    
     
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -897,7 +897,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -920,7 +920,7 @@
     }    
     
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -939,7 +939,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/splitter.html">Splitter EIP:</a>
+     * <a href="http://camel.apache.org/splitter.html">Splitter EIP:</a>
      * Creates a splitter allowing you split a message into a number of pieces and process them individually.
      * <p>
      * The splitter responds with the answer produced by the given {@link AggregationStrategy}.
@@ -961,7 +961,7 @@
     }   
     
     /**
-     * <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer EIP:</a>
+     * <a href="http://camel.apache.org/resequencer.html">Resequencer EIP:</a>
      * Creates a resequencer allowing you to reorganize messages based on some comparator.
      *
      * @return the expression clause for the expressions on which to compare messages in order
@@ -975,7 +975,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer EIP:</a>
+     * <a href="http://camel.apache.org/resequencer.html">Resequencer EIP:</a>
      * Creates a resequencer allowing you to reorganize messages based on some comparator.
      *
      * @param expression the expression on which to compare messages in order
@@ -986,7 +986,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer EIP:</a>
+     * <a href="http://camel.apache.org/resequencer.html">Resequencer EIP:</a>
      * Creates a resequencer allowing you to reorganize messages based on some comparator.
      *
      * @param expressions the list of expressions on which to compare messages in order
@@ -999,7 +999,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer EIP:</a>
+     * <a href="http://camel.apache.org/resequencer.html">Resequencer EIP:</a>
      * Creates a splitter allowing you to reorganise messages based on some comparator.
      *
      * @param expressions the list of expressions on which to compare messages in order
@@ -1012,7 +1012,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/aggregator.html">Aggregator EIP:</a>
+     * <a href="http://camel.apache.org/aggregator.html">Aggregator EIP:</a>
      * Creates an aggregator allowing you to combine a number of messages together into a single message.
      *
      * @return the expression clause to be used as builder to configure the correlation expression
@@ -1024,7 +1024,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/aggregator.html">Aggregator EIP:</a>
+     * <a href="http://camel.apache.org/aggregator.html">Aggregator EIP:</a>
      * Creates an aggregator allowing you to combine a number of messages together into a single message.
      *
      * @param aggregationStrategy the strategy used for the aggregation
@@ -1038,7 +1038,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/aggregator.html">Aggregator EIP:</a>
+     * <a href="http://camel.apache.org/aggregator.html">Aggregator EIP:</a>
      * Creates an aggregator allowing you to combine a number of messages together into a single message.
      *
      * @param aggregationCollection the collection used to perform the aggregation
@@ -1052,7 +1052,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/aggregator.html">Aggregator EIP:</a>
+     * <a href="http://camel.apache.org/aggregator.html">Aggregator EIP:</a>
      * Creates an aggregator allowing you to combine a number of messages together into a single message.
      *
      * @param correlationExpression the expression used to calculate the
@@ -1068,7 +1068,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/aggregator.html">Aggregator EIP:</a>
+     * <a href="http://camel.apache.org/aggregator.html">Aggregator EIP:</a>
      * Creates an aggregator allowing you to combine a number of messages together into a single message.
      *
      * @param correlationExpression the expression used to calculate the
@@ -1085,7 +1085,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/delayer.html">Delayer EIP:</a>
+     * <a href="http://camel.apache.org/delayer.html">Delayer EIP:</a>
      * Creates a delayer allowing you to delay the delivery of messages to some destination.
      *
      * @param processAtExpression  an expression to calculate the time at which the messages should be processed,
@@ -1097,7 +1097,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/delayer.html">Delayer EIP:</a>
+     * <a href="http://camel.apache.org/delayer.html">Delayer EIP:</a>
      * Creates a delayer allowing you to delay the delivery of messages to some destination.
      *
      * @param processAtExpression  an expression to calculate the time at which the messages should be processed,
@@ -1112,7 +1112,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/delayer.html">Delayer EIP:</a>
+     * <a href="http://camel.apache.org/delayer.html">Delayer EIP:</a>
      * Creates a delayer allowing you to delay the delivery of messages to some destination.
      *
      * @return the expression clause to create the expression
@@ -1124,7 +1124,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/delayer.html">Delayer EIP:</a>
+     * <a href="http://camel.apache.org/delayer.html">Delayer EIP:</a>
      * Creates a delayer allowing you to delay the delivery of messages to some destination.
      *
      * @param delay  the default delay in millis
@@ -1135,7 +1135,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/throttler.html">Throttler EIP:</a>
+     * <a href="http://camel.apache.org/throttler.html">Throttler EIP:</a>
      * Creates a throttler allowing you to ensure that a specific endpoint does not get overloaded,
      * or that we don't exceed an agreed SLA with some external service.
      * <p/>
@@ -1152,7 +1152,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/loop.html">Loop EIP:</a>
+     * <a href="http://camel.apache.org/loop.html">Loop EIP:</a>
      * Creates a loop allowing to process the a message a number of times and possibly process them
      * in a different way. Useful mostly for testing.
      *
@@ -1165,7 +1165,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/loop.html">Loop EIP:</a>
+     * <a href="http://camel.apache.org/loop.html">Loop EIP:</a>
      * Creates a loop allowing to process the a message a number of times and possibly process them
      * in a different way. Useful mostly for testing.
      *
@@ -1180,7 +1180,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/loop.html">Loop EIP:</a>
+     * <a href="http://camel.apache.org/loop.html">Loop EIP:</a>
      * Creates a loop allowing to process the a message a number of times and possibly process them
      * in a different way. Useful mostly for testing.
      *
@@ -1377,7 +1377,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/exception-clause.html">Exception clause</a>
+     * <a href="http://camel.apache.org/exception-clause.html">Exception clause</a>
      * for cathing certain exceptions and handling them.
      *
      * @param exceptionType  the exception to catch
@@ -1439,7 +1439,7 @@
     }
 
     /**
-     * Installs the given <a href="http://activemq.apache.org/camel/error-handler.html">error handler</a> builder.
+     * Installs the given <a href="http://camel.apache.org/error-handler.html">error handler</a> builder.
      *
      * @param errorHandlerBuilder the error handler to be used by default for all child routes
      * @return the current builder with the error handler configured
@@ -1450,7 +1450,7 @@
     }
 
     /**
-     * Configures whether or not the <a href="http://activemq.apache.org/camel/error-handler.html">error handler</a>
+     * Configures whether or not the <a href="http://camel.apache.org/error-handler.html">error handler</a>
      * is inherited by every processing node (or just the top most one)
      *
      * @param condition the flag as to whether error handlers should be inherited or not
@@ -1465,7 +1465,7 @@
     // -------------------------------------------------------------------------
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds the custom processor to this destination which could be a final
      * destination, or could be a transformation in a pipeline
      *
@@ -1479,7 +1479,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds the custom processor reference to this destination which could be a final
      * destination, or could be a transformation in a pipeline
      *
@@ -1494,7 +1494,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param bean  the bean to invoke
@@ -1508,7 +1508,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param bean  the bean to invoke
@@ -1524,7 +1524,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param  beanType  the bean class, Camel will instantiate an object at runtime
@@ -1538,7 +1538,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param  beanType  the bean class, Camel will instantiate an object at runtime
@@ -1554,7 +1554,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param ref  reference to a bean to lookup in the registry
@@ -1567,7 +1567,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a bean which is invoked which could be a final destination, or could be a transformation in a pipeline
      *
      * @param ref  reference to a bean to lookup in the registry
@@ -1581,7 +1581,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a processor which sets the body on the IN message
      *
      * @return a expression builder clause to set the body
@@ -1594,7 +1594,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a processor which sets the body on the IN message
      *
      * @param expression   the expression used to set the body
@@ -1607,7 +1607,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a processor which sets the body on the OUT message
      *
      * @param expression   the expression used to set the body
@@ -1620,7 +1620,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/message-translator.html">Message Translator EIP:</a>
+     * <a href="http://camel.apache.org/message-translator.html">Message Translator EIP:</a>
      * Adds a processor which sets the body on the OUT message
      *
      * @return a expression builder clause to set the body
@@ -1792,7 +1792,7 @@
     // -------------------------------------------------------------------------
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Unmarshals the in body using a {@link DataFormat} expression to define
      * the format of the input message and the output will be set on the out message body.
      *
@@ -1803,7 +1803,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Unmarshals the in body using the specified {@link DataFormat}
      * and sets the output on the out message body.
      *
@@ -1816,7 +1816,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Unmarshals the in body using the specified {@link DataFormat}
      * and sets the output on the out message body.
      *
@@ -1828,7 +1828,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Unmarshals the in body using the specified {@link DataFormat}
      * reference in the {@link org.apache.camel.spi.Registry} and sets
      * the output on the out message body.
@@ -1842,7 +1842,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Marshals the in body using a {@link DataFormat} expression to define
      * the format of the output which will be added to the out body.
      *
@@ -1853,7 +1853,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Marshals the in body using the specified {@link DataFormat}
      * and sets the output on the out message body.
      *
@@ -1866,7 +1866,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Marshals the in body using the specified {@link DataFormat}
      * and sets the output on the out message body.
      *
@@ -1878,7 +1878,7 @@
     }
 
     /**
-     * <a href="http://activemq.apache.org/camel/data-format.html">DataFormat:</a>
+     * <a href="http://camel.apache.org/data-format.html">DataFormat:</a>
      * Marshals the in body the specified {@link DataFormat}
      * reference in the {@link org.apache.camel.spi.Registry} and sets
      * the output on the out message body.

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/ArtixDSDataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/ArtixDSDataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/ArtixDSDataFormat.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/ArtixDSDataFormat.java Wed Jan 28 20:20:28 2009
@@ -27,7 +27,7 @@
 import org.apache.commons.logging.LogFactory;
 
 /**
- * Represents the <a href="http://activemq.apache.org/camel/artix-data-services.html">Artix Data Services</a>
+ * Represents the <a href="http://camel.apache.org/artix-data-services.html">Artix Data Services</a>
  * {@link DataFormat}
  *
  * @version $Revision$

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/FlatpackDataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/FlatpackDataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/FlatpackDataFormat.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/FlatpackDataFormat.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 import org.apache.camel.spi.DataFormat;
 
 /**
- * Represents a <a href="http://activemq.apache.org/camel/flatpack.html">Flatpack</a> {@link org.apache.camel.spi.DataFormat}.
+ * Represents a <a href="http://camel.apache.org/flatpack.html">Flatpack</a> {@link org.apache.camel.spi.DataFormat}.
  * 
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/HL7DataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/HL7DataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/HL7DataFormat.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/HL7DataFormat.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 import org.apache.camel.spi.DataFormat;
 
 /**
- * Represents a <a href="http://activemq.apache.org/camel/hl7.html">HL7</a> {@link org.apache.camel.spi.DataFormat}.
+ * Represents a <a href="http://camel.apache.org/hl7.html">HL7</a> {@link org.apache.camel.spi.DataFormat}.
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/RssDataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/RssDataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/RssDataFormat.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/RssDataFormat.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 import org.apache.camel.spi.DataFormat;
 
 /**
- * Represents a <a href="http://activemq.apache.org/camel/rss.html">RSS</a> {@link org.apache.camel.spi.DataFormat}.
+ * Represents a <a href="http://camel.apache.org/rss.html">RSS</a> {@link org.apache.camel.spi.DataFormat}.
  *
  */
 @XmlRootElement(name = "rss")

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/package-info.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/package-info.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/package-info.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/dataformat/package-info.java Wed Jan 28 20:20:28 2009
@@ -17,8 +17,8 @@
 
 /**
  * The JAXB POJOs for the
- * <a href="http://activemq.apache.org/camel/data-format.html">Data Formats</a> used to marshal and unmarshal objects to
- * and from streams inside <a href="http://activemq.apache.org/camel/components.html">components</a>
+ * <a href="http://camel.apache.org/data-format.html">Data Formats</a> used to marshal and unmarshal objects to
+ * and from streams inside <a href="http://camel.apache.org/components.html">components</a>
  */
 @javax.xml.bind.annotation.XmlSchema(namespace = "http://activemq.apache.org/camel/schema/spring", elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED)
 package org.apache.camel.model.dataformat;

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/MethodCallExpression.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/MethodCallExpression.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/MethodCallExpression.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/MethodCallExpression.java Wed Jan 28 20:20:28 2009
@@ -29,7 +29,7 @@
 
 /**
  * For expressions and predicates using the
- * <a href="http://activemq.apache.org/camel/bean-language.html">bean language</a>
+ * <a href="http://camel.apache.org/bean-language.html">bean language</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/SimpleExpression.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/SimpleExpression.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/SimpleExpression.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/SimpleExpression.java Wed Jan 28 20:20:28 2009
@@ -20,7 +20,7 @@
 
 /**
  * For expressions and predicates using the
- * <a href="http://activemq.apache.org/camel/simple.html>simple language</a>
+ * <a href="http://camel.apache.org/simple.html>simple language</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/package-info.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/package-info.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/package-info.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/language/package-info.java Wed Jan 28 20:20:28 2009
@@ -17,9 +17,9 @@
 
 /**
  * The JAXB POJOs for the
- * <a href="http://activemq.apache.org/camel/expression.html">Expression</a> and
- * <a href="http://activemq.apache.org/camel/predicate.html">Predicate</a> plugins for the
- * <a href="http://activemq.apache.org/camel/xml-configuration.html">XML Configuration</a>.
+ * <a href="http://camel.apache.org/expression.html">Expression</a> and
+ * <a href="http://camel.apache.org/predicate.html">Predicate</a> plugins for the
+ * <a href="http://camel.apache.org/xml-configuration.html">XML Configuration</a>.
  */
 @javax.xml.bind.annotation.XmlSchema(namespace = "http://activemq.apache.org/camel/schema/spring", elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED)
 package org.apache.camel.model.language;

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/model/package-info.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/model/package-info.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/model/package-info.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/model/package-info.java Wed Jan 28 20:20:28 2009
@@ -17,7 +17,7 @@
 
 /**
  * The JAXB POJOs for the
- * <a href="http://activemq.apache.org/camel/xml-configuration.html">XML Configuration</a>
+ * <a href="http://camel.apache.org/xml-configuration.html">XML Configuration</a>
  * of the routing rules.
  */
 @javax.xml.bind.annotation.XmlSchema(namespace = "http://activemq.apache.org/camel/schema/spring", elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED)

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/package-info.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/package-info.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/package-info.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/package-info.java Wed Jan 28 20:20:28 2009
@@ -17,7 +17,7 @@
 
 /**
  * The JAXB POJOs for the
- * <a href="http://activemq.apache.org/camel/xml-configuration.html">XML Configuration</a>
+ * <a href="http://camel.apache.org/xml-configuration.html">XML Configuration</a>
  * of the routing rules.
  */
 @javax.xml.bind.annotation.XmlSchema(namespace = "http://activemq.apache.org/camel/schema/spring", elementFormDefault = javax.xml.bind.annotation.XmlNsForm.QUALIFIED)

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Aggregator.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Aggregator.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Aggregator.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Aggregator.java Wed Jan 28 20:20:28 2009
@@ -26,7 +26,7 @@
 
 /**
  * An implementation of the <a
- * href="http://activemq.apache.org/camel/aggregator.html">Aggregator</a>
+ * href="http://camel.apache.org/aggregator.html">Aggregator</a>
  * pattern where a batch of messages are processed (up to a maximum amount or
  * until some timeout is reached) and messages for the same correlation key are
  * combined together using some kind of {@link AggregationStrategy}

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DeadLetterChannel.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DeadLetterChannel.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DeadLetterChannel.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DeadLetterChannel.java Wed Jan 28 20:20:28 2009
@@ -37,7 +37,7 @@
 
 /**
  * Implements a <a
- * href="http://activemq.apache.org/camel/dead-letter-channel.html">Dead Letter
+ * href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
  * Channel</a> after attempting to redeliver the message using the
  * {@link RedeliveryPolicy}
  *

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DelayPolicy.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DelayPolicy.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DelayPolicy.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/DelayPolicy.java Wed Jan 28 20:20:28 2009
@@ -22,8 +22,8 @@
  * The base policy used when a fixed delay is needed.
  * <p/>
  * This policy is used by
- * <a href="http://activemq.apache.org/camel/transactional-client.html">Transactional client</a>
- * and <a href="http://activemq.apache.org/camel/dead-letter-channel.html">Dead Letter Channel</a>.
+ * <a href="http://camel.apache.org/transactional-client.html">Transactional client</a>
+ * and <a href="http://camel.apache.org/dead-letter-channel.html">Dead Letter Channel</a>.
  *
  * The default values is:
  * <ul>

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Delayer.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Delayer.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Delayer.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Delayer.java Wed Jan 28 20:20:28 2009
@@ -22,7 +22,7 @@
 import org.apache.camel.util.ExpressionHelper;
 
 /**
- * A <a href="http://activemq.apache.org/camel/delayer.html">Delayer</a> which
+ * A <a href="http://camel.apache.org/delayer.html">Delayer</a> which
  * delays processing the exchange until the correct amount of time has elapsed
  * using an expression to determine the delivery time. <p/> For example if you
  * wish to delay JMS messages by 25 seconds from their publish time you could

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/FilterProcessor.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/FilterProcessor.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/FilterProcessor.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/FilterProcessor.java Wed Jan 28 20:20:28 2009
@@ -22,7 +22,7 @@
 
 /**
  * The processor which implements the
- * <a href="http://activemq.apache.org/camel/message-filter.html">Message Filter</a> EIP pattern.
+ * <a href="http://camel.apache.org/message-filter.html">Message Filter</a> EIP pattern.
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/MarshalProcessor.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/MarshalProcessor.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/MarshalProcessor.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/MarshalProcessor.java Wed Jan 28 20:20:28 2009
@@ -25,7 +25,7 @@
 
 /**
  * Marshals the body of the incoming message using the given
- * <a href="http://activemq.apache.org/camel/data-format.html">data format</a>
+ * <a href="http://camel.apache.org/data-format.html">data format</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RecipientList.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RecipientList.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RecipientList.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RecipientList.java Wed Jan 28 20:20:28 2009
@@ -34,7 +34,7 @@
 
 /**
  * Implements a dynamic <a
- * href="http://activemq.apache.org/camel/recipient-list.html">Recipient List</a>
+ * href="http://camel.apache.org/recipient-list.html">Recipient List</a>
  * pattern where the list of actual endpoints to send a message exchange to are
  * dependent on some dynamic expression.
  *

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RedeliveryPolicy.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RedeliveryPolicy.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RedeliveryPolicy.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RedeliveryPolicy.java Wed Jan 28 20:20:28 2009
@@ -29,7 +29,7 @@
 /**
  * The policy used to decide how many times to redeliver and the time between
  * the redeliveries before being sent to a <a
- * href="http://activemq.apache.org/camel/dead-letter-channel.html">Dead Letter
+ * href="http://camel.apache.org/dead-letter-channel.html">Dead Letter
  * Channel</a>
  * <p>
  * The default values are:

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Resequencer.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Resequencer.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Resequencer.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Resequencer.java Wed Jan 28 20:20:28 2009
@@ -28,7 +28,7 @@
 import org.apache.camel.util.ExpressionListComparator;
 
 /**
- * An implementation of the <a href="http://activemq.apache.org/camel/resequencer.html">Resequencer</a>
+ * An implementation of the <a href="http://camel.apache.org/resequencer.html">Resequencer</a>
  * which can reorder messages within a batch.
  *
  * @version $Revision$

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/RoutingSlip.java Wed Jan 28 20:20:28 2009
@@ -30,7 +30,7 @@
 import static org.apache.camel.util.ObjectHelper.notNull;
 
 /**
- * Implements a <a href="http://activemq.apache.org/camel/routing-slip.html">Routing Slip</a>
+ * Implements a <a href="http://camel.apache.org/routing-slip.html">Routing Slip</a>
  * pattern where the list of actual endpoints to send a message exchange to are
  * dependent on the value of a message header.
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Splitter.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Splitter.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Splitter.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Splitter.java Wed Jan 28 20:20:28 2009
@@ -36,7 +36,7 @@
 
 /**
  * Implements a dynamic <a
- * href="http://activemq.apache.org/camel/splitter.html">Splitter</a> pattern
+ * href="http://camel.apache.org/splitter.html">Splitter</a> pattern
  * where an expression is evaluated to iterate through each of the parts of a
  * message and then each part is then send to some endpoint.
  *

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Throttler.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Throttler.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Throttler.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/Throttler.java Wed Jan 28 20:20:28 2009
@@ -20,7 +20,7 @@
 import org.apache.camel.Processor;
 
 /**
- * A <a href="http://activemq.apache.org/camel/throttler.html">Throttler</a>
+ * A <a href="http://camel.apache.org/throttler.html">Throttler</a>
  * will set a limit on the maximum number of message exchanges which can be sent
  * to a processor within a specific time period. <p/> This pattern can be
  * extremely useful if you have some external system which meters access; such

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnmarshalProcessor.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnmarshalProcessor.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnmarshalProcessor.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/UnmarshalProcessor.java Wed Jan 28 20:20:28 2009
@@ -26,7 +26,7 @@
 
 /**
  * Unmarshals the body of the incoming message using the given
- * <a href="http://activemq.apache.org/camel/data-format.html">data format</a>
+ * <a href="http://camel.apache.org/data-format.html">data format</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/IdempotentConsumer.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/IdempotentConsumer.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/IdempotentConsumer.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/IdempotentConsumer.java Wed Jan 28 20:20:28 2009
@@ -28,7 +28,7 @@
 
 /**
  * An implementation of the <a
- * href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent
+ * href="http://camel.apache.org/idempotent-consumer.html">Idempotent
  * Consumer</a> pattern.
  * 
  * @version $Revision$

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/NoMessageIdException.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/NoMessageIdException.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/NoMessageIdException.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/processor/idempotent/NoMessageIdException.java Wed Jan 28 20:20:28 2009
@@ -22,7 +22,7 @@
 
 /**
  * An exception thrown if no message ID could be found on a message which is to be used with the
- * <a href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent Consumer</a> pattern.
+ * <a href="http://camel.apache.org/idempotent-consumer.html">Idempotent Consumer</a> pattern.
  *
  * @version $Revision$
  */

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/spi/DataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/DataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/spi/DataFormat.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/spi/DataFormat.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 
 /**
  * Represents a
- * <a href="http://activemq.apache.org/camel/data-format.html">data format</a>
+ * <a href="http://camel.apache.org/data-format.html">data format</a>
  * used to marshal objects to and from streams
  * such as Java Serialization or using JAXB2 to encode/decode objects using XML
  * or using SOAP encoding.

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/spi/IdempotentRepository.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/spi/IdempotentRepository.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/spi/IdempotentRepository.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/spi/IdempotentRepository.java Wed Jan 28 20:20:28 2009
@@ -18,7 +18,7 @@
 
 /**
  * Access to a repository of Message IDs to implement the
- * <a href="http://activemq.apache.org/camel/idempotent-consumer.html">Idempotent Consumer</a> pattern.
+ * <a href="http://camel.apache.org/idempotent-consumer.html">Idempotent Consumer</a> pattern.
  * <p/>
  * The <tt>add</tt> and <tt>contains</tt> methods is operating according to the {@link java.util.Set} contract.
  *

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/view/GraphGeneratorSupport.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/view/GraphGeneratorSupport.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/view/GraphGeneratorSupport.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/view/GraphGeneratorSupport.java Wed Jan 28 20:20:28 2009
@@ -48,7 +48,7 @@
     protected String extension;
 
     //private String imagePrefix = "http://www.enterpriseintegrationpatterns.com/img/";
-    private String imagePrefix = "http://activemq.apache.org/camel/images/eip/";
+    private String imagePrefix = "http://camel.apache.org/images/eip/";
     private Map<Object, NodeData> nodeMap = new HashMap<Object, NodeData>();
     private boolean makeParentDirs = true;
     private Map<String, List<RouteType>> routeGroupMap;

Modified: camel/trunk/camel-core/src/main/java/org/apache/camel/view/NodeData.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/main/java/org/apache/camel/view/NodeData.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/main/java/org/apache/camel/view/NodeData.java (original)
+++ camel/trunk/camel-core/src/main/java/org/apache/camel/view/NodeData.java Wed Jan 28 20:20:28 2009
@@ -67,13 +67,13 @@
             FromType fromType = (FromType)node;
             this.tooltop = fromType.getLabel();
             this.label = removeQueryString(this.tooltop);
-            this.url = "http://activemq.apache.org/camel/message-endpoint.html";
+            this.url = "http://camel.apache.org/message-endpoint.html";
         } else if (node instanceof ToType) {
             ToType toType = (ToType)node;
             this.tooltop = toType.getLabel();
             this.label = removeQueryString(this.tooltop);
             this.edgeLabel = "";
-            this.url = "http://activemq.apache.org/camel/message-endpoint.html";
+            this.url = "http://camel.apache.org/message-endpoint.html";
         } else if (node instanceof FilterType) {
             this.image = imagePrefix + "MessageFilterIcon.png";
             this.label = "Filter";
@@ -82,11 +82,11 @@
             this.image = imagePrefix + "MessageFilterIcon.png";
             this.nodeType = "When Filter";
             this.label = "When";
-            this.url = "http://activemq.apache.org/camel/content-based-router.html";
+            this.url = "http://camel.apache.org/content-based-router.html";
         } else if (node instanceof OtherwiseType) {
             this.nodeType = "Otherwise";
             this.edgeLabel = "";
-            this.url = "http://activemq.apache.org/camel/content-based-router.html";
+            this.url = "http://camel.apache.org/content-based-router.html";
             this.tooltop = "Otherwise";
         } else if (node instanceof ChoiceType) {
             this.image = imagePrefix + "ContentBasedRouterIcon.png";
@@ -106,7 +106,7 @@
         } else if (node instanceof RoutingSlipType) {
             this.image = imagePrefix + "RoutingTableIcon.png";
             this.nodeType = "Routing Slip";
-            this.url = "http://activemq.apache.org/camel/routing-slip.html";
+            this.url = "http://camel.apache.org/routing-slip.html";
             this.tooltop = ((RoutingSlipType) node).getHeaderName();
         } else if (node instanceof SplitterType) {
             this.image = imagePrefix + "SplitterIcon.png";
@@ -159,7 +159,7 @@
             }
         }
         if (isEmpty(this.url) && isNotEmpty(this.nodeType)) {
-            this.url = "http://activemq.apache.org/camel/" + this.nodeType.toLowerCase().replace(' ', '-')
+            this.url = "http://camel.apache.org/" + this.nodeType.toLowerCase().replace(' ', '-')
                        + ".html";
         }
         if (node instanceof ProcessorType && this.outputs == null) {

Modified: camel/trunk/camel-core/src/test/java/org/apache/camel/BodyAndHeaderConvertTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/test/java/org/apache/camel/BodyAndHeaderConvertTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/test/java/org/apache/camel/BodyAndHeaderConvertTest.java (original)
+++ camel/trunk/camel-core/src/test/java/org/apache/camel/BodyAndHeaderConvertTest.java Wed Jan 28 20:20:28 2009
@@ -71,6 +71,6 @@
         Message message = exchange.getIn();
         message.setBody("<hello>world!</hello>");
         message.setHeader("bar", 567);
-        message.addAttachment("att", new DataHandler(new URLDataSource(new URL("http://activemq.apache.org/camel/message.html"))));
+        message.addAttachment("att", new DataHandler(new URLDataSource(new URL("http://camel.apache.org/message.html"))));
     }
 }

Modified: camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorLogTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorLogTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorLogTest.java (original)
+++ camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorLogTest.java Wed Jan 28 20:20:28 2009
@@ -21,7 +21,7 @@
 import org.apache.camel.component.mock.MockEndpoint;
 
 /**
- * Testing http://activemq.apache.org/camel/dsl.html
+ * Testing http://camel.apache.org/dsl.html
  */
 public class InterceptorLogTest extends ContextTestSupport {
 

Modified: camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorPredicateProceedAndStopTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorPredicateProceedAndStopTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorPredicateProceedAndStopTest.java (original)
+++ camel/trunk/camel-core/src/test/java/org/apache/camel/issues/InterceptorPredicateProceedAndStopTest.java Wed Jan 28 20:20:28 2009
@@ -21,7 +21,7 @@
 import org.apache.camel.component.mock.MockEndpoint;
 
 /**
- * Testing http://activemq.apache.org/camel/dsl.html
+ * Testing http://camel.apache.org/dsl.html
  */
 public class InterceptorPredicateProceedAndStopTest extends ContextTestSupport {
 

Modified: camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomComponent.java (original)
+++ camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomComponent.java Wed Jan 28 20:20:28 2009
@@ -24,7 +24,7 @@
 import org.apache.camel.impl.DefaultComponent;
 
 /**
- * An <a href="http://activemq.apache.org/camel/atom.html">Atom Component</a>.
+ * An <a href="http://camel.apache.org/atom.html">Atom Component</a>.
  * <p/>
  * Camel uses Apache Abdera as the Atom implementation. 
  *

Modified: camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomEndpoint.java (original)
+++ camel/trunk/components/camel-atom/src/main/java/org/apache/camel/component/atom/AtomEndpoint.java Wed Jan 28 20:20:28 2009
@@ -31,7 +31,7 @@
 import org.apache.camel.util.ObjectHelper;
 
 /**
- * An <a href="http://activemq.apache.org/camel/atom.html">Atom Endpoint</a>.
+ * An <a href="http://camel.apache.org/atom.html">Atom Endpoint</a>.
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java (original)
+++ camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/BamProcessorSupport.java Wed Jan 28 20:20:28 2009
@@ -33,7 +33,7 @@
 
 /**
  * A base {@link Processor} for working on <a
- * href="http://activemq.apache.org/camel/bam.html">BAM</a> which a derived
+ * href="http://camel.apache.org/bam.html">BAM</a> which a derived
  * class would do the actual persistence such as the {@link JpaBamProcessor}
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/JpaBamProcessor.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/JpaBamProcessor.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/JpaBamProcessor.java (original)
+++ camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/JpaBamProcessor.java Wed Jan 28 20:20:28 2009
@@ -29,7 +29,7 @@
 
 /**
  * A concrete {@link Processor} for working on <a
- * href="http://activemq.apache.org/camel/bam.html">BAM</a> which uses JPA as
+ * href="http://camel.apache.org/bam.html">BAM</a> which uses JPA as
  * the persistence and uses the {@link ProcessInstance} entity to store the
  * process information.
  * 

Modified: camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/NoCorrelationKeyException.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/NoCorrelationKeyException.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/NoCorrelationKeyException.java (original)
+++ camel/trunk/components/camel-bam/src/main/java/org/apache/camel/bam/processor/NoCorrelationKeyException.java Wed Jan 28 20:20:28 2009
@@ -22,7 +22,7 @@
 /**
  * An exception thrown if no correlation key could be found for a message
  * exchange preventing any particular orchestration or
- * <a href="http://activemq.apache.org/camel/bam.html">BAM</a>
+ * <a href="http://camel.apache.org/bam.html">BAM</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfComponent.java (original)
+++ camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfComponent.java Wed Jan 28 20:20:28 2009
@@ -25,7 +25,7 @@
 import org.apache.camel.util.CamelContextHelper;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/cxf.html">CXF Component</a> 
+ * Defines the <a href="http://camel.apache.org/cxf.html">CXF Component</a> 
  * 
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfEndpoint.java (original)
+++ camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfEndpoint.java Wed Jan 28 20:20:28 2009
@@ -56,7 +56,7 @@
 import org.apache.cxf.message.Message;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/cxf.html">CXF Endpoint</a>.
+ * Defines the <a href="http://camel.apache.org/cxf.html">CXF Endpoint</a>.
  * It contains a list of properties for CXF endpoint including {@link DataFormat}, 
  * {@link CxfBinding}, and {@link HeaderFilterStrategy}.  The default DataFormat 
  * mode is {@link DataFormat#POJO}.  

Modified: camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSoapComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSoapComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSoapComponent.java (original)
+++ camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSoapComponent.java Wed Jan 28 20:20:28 2009
@@ -28,7 +28,7 @@
 
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/cxf.html">SOAP Component</a>
+ * Defines the <a href="http://camel.apache.org/cxf.html">SOAP Component</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSpringEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSpringEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSpringEndpoint.java (original)
+++ camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/CxfSpringEndpoint.java Wed Jan 28 20:20:28 2009
@@ -38,7 +38,7 @@
 import org.apache.cxf.jaxws.JaxWsServerFactoryBean;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/cxf.html">CXF Endpoint</a>
+ * Defines the <a href="http://camel.apache.org/cxf.html">CXF Endpoint</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/converter/CxfConverter.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/converter/CxfConverter.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/converter/CxfConverter.java (original)
+++ camel/trunk/components/camel-cxf/src/main/java/org/apache/camel/component/cxf/converter/CxfConverter.java Wed Jan 28 20:20:28 2009
@@ -31,7 +31,7 @@
 import org.apache.cxf.message.MessageContentsList;
 
 /**
- * The <a href="http://activemq.apache.org/camel/type-converter.html">Type Converters</a>
+ * The <a href="http://camel.apache.org/type-converter.html">Type Converters</a>
  * for CXF related types' converting .
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java (original)
+++ camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpComponent.java Wed Jan 28 20:20:28 2009
@@ -32,7 +32,7 @@
 import org.apache.commons.httpclient.params.HttpClientParams;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/http.html">HTTP
+ * Defines the <a href="http://camel.apache.org/http.html">HTTP
  * Component</a>
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpEndpoint.java (original)
+++ camel/trunk/components/camel-http/src/main/java/org/apache/camel/component/http/HttpEndpoint.java Wed Jan 28 20:20:28 2009
@@ -33,7 +33,7 @@
 import org.apache.commons.httpclient.params.HttpClientParams;
 
 /**
- * Represents a <a href="http://activemq.apache.org/camel/http.html">HTTP
+ * Represents a <a href="http://camel.apache.org/http.html">HTTP
  * endpoint</a>
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisComponent.java (original)
+++ camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisComponent.java Wed Jan 28 20:20:28 2009
@@ -32,7 +32,7 @@
 import org.springframework.core.io.Resource;
 
 /**
- * An <a href="http://activemq.apache.org/camel/ibatis.html>iBatis Component</a>
+ * An <a href="http://camel.apache.org/ibatis.html>iBatis Component</a>
  * for performing SQL operations using an XML mapping file to abstract away the SQL
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisEndpoint.java (original)
+++ camel/trunk/components/camel-ibatis/src/main/java/org/apache/camel/component/ibatis/IBatisEndpoint.java Wed Jan 28 20:20:28 2009
@@ -36,7 +36,7 @@
 import org.apache.commons.logging.LogFactory;
 
 /**
- * An <a href="http://activemq.apache.org/camel/ibatis.html>iBatis Endpoint</a>
+ * An <a href="http://camel.apache.org/ibatis.html>iBatis Endpoint</a>
  * for performing SQL operations using an XML mapping file to abstract away the SQL
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcComponent.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcComponent.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcComponent.java (original)
+++ camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcComponent.java Wed Jan 28 20:20:28 2009
@@ -28,7 +28,7 @@
 import org.schwering.irc.lib.IRCConnection;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/irc.html">IRC Component</a>
+ * Defines the <a href="http://camel.apache.org/irc.html">IRC Component</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcEndpoint.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcEndpoint.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcEndpoint.java (original)
+++ camel/trunk/components/camel-irc/src/main/java/org/apache/camel/component/irc/IrcEndpoint.java Wed Jan 28 20:20:28 2009
@@ -24,7 +24,7 @@
 import org.schwering.irc.lib.IRCUser;
 
 /**
- * Defines the <a href="http://activemq.apache.org/camel/irc.html">IRC Endpoint</a>
+ * Defines the <a href="http://camel.apache.org/irc.html">IRC Endpoint</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-jaxb/src/main/java/org/apache/camel/converter/jaxb/JaxbDataFormat.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jaxb/src/main/java/org/apache/camel/converter/jaxb/JaxbDataFormat.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jaxb/src/main/java/org/apache/camel/converter/jaxb/JaxbDataFormat.java (original)
+++ camel/trunk/components/camel-jaxb/src/main/java/org/apache/camel/converter/jaxb/JaxbDataFormat.java Wed Jan 28 20:20:28 2009
@@ -31,7 +31,7 @@
 import org.apache.camel.util.IOHelper;
 
 /**
- * A <a href="http://activemq.apache.org/camel/data-format.html">data format</a> ({@link DataFormat})
+ * A <a href="http://camel.apache.org/data-format.html">data format</a> ({@link DataFormat})
  * using JAXB2 to marshal to and from XML
  *
  * @version $Revision$

Modified: camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsIOConverter.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsIOConverter.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsIOConverter.java (original)
+++ camel/trunk/components/camel-jms/src/main/java/org/apache/camel/component/jms/JmsIOConverter.java Wed Jan 28 20:20:28 2009
@@ -36,7 +36,7 @@
 
 /**
  * Some simple payload conversions to I/O <a
- * href="http://activemq.apache.org/camel/type-converter.html">Type Converters</a>
+ * href="http://camel.apache.org/type-converter.html">Type Converters</a>
  *
  * @version $Revision$
  */

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/AbstractTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/AbstractTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/AbstractTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/AbstractTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -32,7 +32,7 @@
 
 /**
  * Test case derived from:
- * http://activemq.apache.org/camel/transactional-client.html and Martin
+ * http://camel.apache.org/transactional-client.html and Martin
  * Krasser's sample:
  * http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  *

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToProcessorTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToProcessorTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToProcessorTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToProcessorTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 
 /**
  * Test case derived from:
- *      http://activemq.apache.org/camel/transactional-client.html
+ *      http://camel.apache.org/transactional-client.html
  *  and
  *      Martin Krasser's sample: http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  *

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueRequestReplyTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueRequestReplyTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueRequestReplyTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueRequestReplyTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -27,7 +27,7 @@
 
 /**
  * Test case derived from:
- * http://activemq.apache.org/camel/transactional-client.html and Martin
+ * http://camel.apache.org/transactional-client.html and Martin
  * Krasser's sample:
  * http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  * <p/>

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/QueueToQueueTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 
 /**
  * Test case derived from:
- * http://activemq.apache.org/camel/transactional-client.html and Martin
+ * http://camel.apache.org/transactional-client.html and Martin
  * Krasser's sample:
  * http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  * NOTE: had to split into separate test classes as I was unable to fully tear

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToProcessorTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToProcessorTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToProcessorTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToProcessorTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -24,7 +24,7 @@
 
 /**
  * Test case derived from:
- * http://activemq.apache.org/camel/transactional-client.html and Martin
+ * http://camel.apache.org/transactional-client.html and Martin
  * Krasser's sample:
  * http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  * NOTE: had to split into separate test classes as I was unable to fully tear

Modified: camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToQueueTransactionTest.java
URL: http://svn.apache.org/viewvc/camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToQueueTransactionTest.java?rev=738604&r1=738603&r2=738604&view=diff
==============================================================================
--- camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToQueueTransactionTest.java (original)
+++ camel/trunk/components/camel-jms/src/test/java/org/apache/camel/component/jms/tx/XMLQueueToQueueTransactionTest.java Wed Jan 28 20:20:28 2009
@@ -23,7 +23,7 @@
 
 /**
  * Test case derived from:
- * http://activemq.apache.org/camel/transactional-client.html and Martin
+ * http://camel.apache.org/transactional-client.html and Martin
  * Krasser's sample:
  * http://www.nabble.com/JMS-Transactions---How-To-td15168958s22882.html#a15198803
  * NOTE: had to split into separate test classes as I was unable to fully tear