Author: ningjiang
Date: Thu Jan 17 00:03:38 2008
New Revision: 612747
URL: http://svn.apache.org/viewvc?rev=612747&view=rev
Log:
Added the missing files
Added:
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
(with props)
activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
(with props)
Modified:
activemq/camel/trunk/components/camel-stream/pom.xml
activemq/camel/trunk/pom.xml
Modified: activemq/camel/trunk/components/camel-stream/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/pom.xml?rev=612747&r1=612746&r2=612747&view=diff
==============================================================================
--- activemq/camel/trunk/components/camel-stream/pom.xml (original)
+++ activemq/camel/trunk/components/camel-stream/pom.xml Thu Jan 17 00:03:38 2008
@@ -21,19 +21,22 @@
xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/maven-v4_0_0.xsd">
<modelVersion>4.0.0</modelVersion>
+
+ <parent>
+ <groupId>org.apache.camel</groupId>
+ <artifactId>camel-parent</artifactId>
+ <version>1.3-SNAPSHOT</version>
+ </parent>
+
<groupId>org.apache.camel</groupId>
<artifactId>camel-stream</artifactId>
- <packaging>jar</packaging>
- <version>1.0-SNAPSHOT</version>
+ <packaging>bundle</packaging>
<name>Camel :: Stream</name>
<description>Camel Stream (System.in, System.out, System.err) support</description>
- <parent>
- <groupId>org.apache.camel</groupId>
- <artifactId>camel-parent</artifactId>
- <version>1.3-SNAPSHOT</version>
- </parent>
-
+ <properties>
+ <camel.osgi.export.pkg>org.apache.camel.component*</camel.osgi.export.pkg>
+ </properties>
<dependencies>
<dependency>
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,72 @@
+/**
+ *
+ * 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.component.stream;
+
+
+import java.io.BufferedReader;
+
+import java.io.IOException;
+
+import java.io.InputStreamReader;
+
+
+public class StdInHandler implements InputStreamHandler {
+
+ StreamReceiver sr;
+
+
+ public StdInHandler(StreamReceiver sr) {
+
+ this.sr = sr;
+
+ }
+
+
+ public void consume() throws ConsumingException {
+
+ BufferedReader br = new BufferedReader(new InputStreamReader(System.in));
+
+ String line = null;
+
+ try {
+
+ while ((line = br.readLine()) != null) {
+
+ sr.pass(line);
+
+ }
+
+ br.close();
+
+ } catch (IOException e) {
+
+ e.printStackTrace();
+
+ throw new ConsumingException(e);
+
+ } catch (Exception e) {
+
+ e.printStackTrace();
+
+ throw new ConsumingException(e);
+
+ }
+
+ }
+
+}
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StdInHandler.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,38 @@
+/**
+ *
+ * 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.component.stream;
+
+import java.util.Map;
+import org.apache.camel.Endpoint;
+import org.apache.camel.impl.DefaultComponent;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+public class StreamComponent extends DefaultComponent<StreamExchange> {
+
+ private static final Log log = LogFactory.getLog(StreamComponent.class);
+
+ @Override
+ protected Endpoint<StreamExchange> createEndpoint(String uri,
+ String remaining, Map parameters) throws Exception {
+
+ return new StreamEndpoint(this, uri, remaining, parameters);
+
+ }
+
+}
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamComponent.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,108 @@
+/**
+ *
+ * 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.component.stream;
+
+import java.util.Arrays;
+import java.util.List;
+import java.util.Map;
+import org.apache.camel.Endpoint;
+import org.apache.camel.Exchange;
+import org.apache.camel.Processor;
+import org.apache.camel.impl.DefaultConsumer;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+public class StreamConsumer extends DefaultConsumer<StreamExchange> implements StreamReceiver
{
+
+ private static final String TYPES = "in";
+
+ private static final String INVALID_URI = "Invalid uri, valid form: 'stream:{"
+ + TYPES + "}'";
+
+ private static final List<String> TYPES_LIST = Arrays.asList(TYPES.split(","));
+ private static final Log log = LogFactory.getLog(StreamConsumer.class);
+ Endpoint<StreamExchange> endpoint;
+ private Map<String, String> parameters;
+ private String uri;
+ public StreamConsumer(Endpoint<StreamExchange> endpoint,
+ Processor processor, String uri, Map<String, String> parameters)
+ throws Exception {
+
+ super(endpoint, processor);
+ this.endpoint = endpoint;
+ this.parameters = parameters;
+ validateUri(uri);
+ log.debug("### stream consumer created");
+
+ }
+
+ @Override
+ protected void doStart() throws Exception {
+
+ super.doStart();
+ InputStreamHandler sh = new StdInHandler(this);
+
+ try {
+
+ if (parameters.get("prompt") != null) {
+ pass(parameters.get("prompt"));
+ }
+ sh.consume();
+
+ } catch (ConsumingException e) {
+ log.error(e);
+ e.printStackTrace();
+ }
+
+ }
+
+ public int pass(String s) throws Exception {
+
+ Exchange ex = endpoint.createExchange();
+
+ ex.setIn(new StreamMessage(s));
+
+ getProcessor().process(ex);
+
+ return 0;
+
+ }
+
+ private void validateUri(String uri) throws Exception {
+
+ String[] s = uri.split(":");
+ if (s.length < 2) {
+ throw new Exception(INVALID_URI);
+
+ }
+ String[] t = s[1].split("\\?");
+
+ if (t.length < 1) {
+ throw new Exception(INVALID_URI);
+ }
+
+ this.uri = t[0].trim();
+
+ if (!TYPES_LIST.contains(this.uri)) {
+
+ throw new Exception(INVALID_URI);
+
+ }
+ }
+
+}
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamConsumer.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,73 @@
+/**
+ *
+ * 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.component.stream;
+
+
+import java.util.Map;
+import org.apache.camel.Consumer;
+import org.apache.camel.Processor;
+import org.apache.camel.Producer;
+import org.apache.camel.impl.DefaultEndpoint;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+
+
+public class StreamEndpoint extends DefaultEndpoint<StreamExchange> {
+
+ String file;
+ Producer<StreamExchange> producer;
+ private Map parameters;
+ private String uri;
+
+ private static final Log log = LogFactory.getLog(StreamConsumer.class);
+
+
+ public StreamEndpoint(StreamComponent component, String uri,
+ String remaining, Map parameters) throws Exception {
+
+ super(uri, component);
+ this.parameters = parameters;
+ this.uri=uri;
+ log.debug(uri + " / " + remaining + " / " + parameters);
+ this.producer = new StreamProducer(this, uri, parameters);
+
+ }
+
+
+ public Consumer<StreamExchange> createConsumer(Processor p)
+ throws Exception {
+
+ return new StreamConsumer(this, p, uri, parameters);
+
+ }
+
+
+
+ public Producer<StreamExchange> createProducer() throws Exception {
+
+ return producer;
+
+ }
+
+
+ public boolean isSingleton() {
+
+ return true;
+ }
+}
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamEndpoint.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,34 @@
+/**
+ *
+ * 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.component.stream;
+
+import org.apache.camel.CamelContext;
+import org.apache.camel.impl.DefaultExchange;
+
+
+public class StreamExchange extends DefaultExchange {
+
+ public StreamExchange(CamelContext context) {
+ super(context);
+ }
+
+ public StreamExchange(DefaultExchange parent) {
+ super(parent);
+ // TODO Auto-generated constructor stub
+ }
+}
\ No newline at end of file
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamExchange.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,48 @@
+/**
+ *
+ * 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.component.stream;
+
+import org.apache.camel.impl.DefaultMessage;
+
+public class StreamMessage extends DefaultMessage {
+ String s;
+ public StreamMessage(String s) {
+
+ this.s = s;
+
+ }
+
+
+ @Override
+ public String toString() {
+ return s;
+ }
+
+
+ @Override
+ protected Object createBody() {
+ return s;
+ }
+
+
+ @Override
+ public Object getBody() {
+ return s;
+ }
+
+}
\ No newline at end of file
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamMessage.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,90 @@
+/**
+ *
+ * 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.component.stream;
+
+
+import java.util.Arrays;
+import java.util.List;
+import java.util.Map;
+
+import org.apache.camel.Endpoint;
+import org.apache.camel.Exchange;
+import org.apache.camel.impl.DefaultProducer;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+
+public class StreamProducer extends DefaultProducer<StreamExchange> {
+
+ private static final Log log = LogFactory.getLog(StreamProducer.class);
+
+ private static final String TYPES = "in,out,err";
+
+ private static final String INVALID_URI = "Invalid uri, valid form: 'stream:{"
+ + TYPES + "}'";
+
+ private static final List<String> TYPES_LIST = Arrays.asList(TYPES.split(","));
+
+ private String uri;
+
+ private Map<String, String> parameters;
+
+
+ public StreamProducer(Endpoint<StreamExchange> endpoint, String uri,
+ Map parameters) throws Exception {
+ super(endpoint);
+ this.parameters = parameters;
+ validateUri(uri);
+ log.debug("### stream producer created");
+
+ }
+
+
+ public void process(Exchange ex) throws Exception {
+
+ if (parameters.get("delay") != null) {
+ Thread.sleep(Integer.valueOf(parameters.get("delay")));
+ }
+
+ if ("out".equals(uri)) {
+ System.out.println(ex.getIn().getBody(String.class));
+ } else {
+ System.err.println(ex.getIn().getBody(String.class));
+ }
+
+ }
+
+
+ private void validateUri(String uri) throws Exception {
+ String[] s = uri.split(":");
+ if (s.length < 2) {
+ throw new Exception(INVALID_URI);
+ }
+ String[] t = s[1].split("\\?");
+
+ if (t.length < 1){
+ throw new Exception(INVALID_URI);
+ }
+ this.uri = t[0].trim();
+
+ if (!TYPES_LIST.contains(this.uri)) {
+ throw new Exception(INVALID_URI);
+ }
+ }
+
+}
\ No newline at end of file
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamProducer.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Added: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java?rev=612747&view=auto
==============================================================================
--- activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
(added)
+++ activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
Thu Jan 17 00:03:38 2008
@@ -0,0 +1,25 @@
+/**
+ *
+ * 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.component.stream;
+
+
+public interface StreamReceiver {
+
+ public int pass(String s) throws Exception;
+
+}
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
------------------------------------------------------------------------------
svn:eol-style = native
Propchange: activemq/camel/trunk/components/camel-stream/src/main/java/org/apache/camel/component/stream/StreamReceiver.java
------------------------------------------------------------------------------
svn:keywords = Rev Date
Modified: activemq/camel/trunk/pom.xml
URL: http://svn.apache.org/viewvc/activemq/camel/trunk/pom.xml?rev=612747&r1=612746&r2=612747&view=diff
==============================================================================
--- activemq/camel/trunk/pom.xml (original)
+++ activemq/camel/trunk/pom.xml Thu Jan 17 00:03:38 2008
@@ -361,6 +361,11 @@
</dependency>
<dependency>
<groupId>org.apache.camel</groupId>
+ <artifactId>camel-stream</artifactId>
+ <version>${camel-version}</version>
+ </dependency>
+ <dependency>
+ <groupId>org.apache.camel</groupId>
<artifactId>camel-supercsv</artifactId>
<version>${camel-version}</version>
</dependency>
|