You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by da...@apache.org on 2016/01/09 11:44:44 UTC

[1/9] camel git commit: CAMEL-4725 camel-sql - Add support for Callable statements

Repository: camel
Updated Branches:
  refs/heads/master dbb552c9e -> e9f3f60d2


CAMEL-4725 camel-sql - Add support for Callable statements


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/6dac645b
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/6dac645b
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/6dac645b

Branch: refs/heads/master
Commit: 6dac645b89ac4c3e115137b08a079c822c935d1f
Parents: dbb552c
Author: Sami Nurminen <sn...@gmail.com>
Authored: Sun Dec 20 23:34:33 2015 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 10:59:45 2016 +0100

----------------------------------------------------------------------
 .../apache/camel/component/sql/SqlEndpoint.java |   5 +-
 .../apache/camel/component/sql/SqlProducer.java |  17 +-
 .../component/sql/sspt/ProducerSSPTHelper.java  |  36 ++
 .../sql/sspt/SimpleStoredProcedure.java         |  56 +++
 .../sql/sspt/SimpleStoredProcedureFactory.java  |  33 ++
 .../component/sql/sspt/ast/InputParameter.java  |  47 ++
 .../component/sql/sspt/ast/OutParameter.java    |  33 ++
 .../component/sql/sspt/ast/ParseException.java  | 189 ++++++++
 .../component/sql/sspt/ast/ParseHelper.java     |  58 +++
 .../camel/component/sql/sspt/ast/Template.java  |  43 ++
 .../component/sql/sspt/parser/SSPTParser.java   | 282 +++++++++++
 .../sql/sspt/parser/SSPTParserConstants.java    |  39 ++
 .../sql/sspt/parser/SSPTParserTokenManager.java | 366 ++++++++++++++
 .../sql/sspt/parser/SimpleCharStream.java       | 471 +++++++++++++++++++
 .../camel/component/sql/sspt/parser/Token.java  | 131 ++++++
 .../sql/sspt/parser/TokenMgrError.java          | 147 ++++++
 .../sql/sspt/parser/generate_sptp_classes.sh    |   4 +
 .../camel/component/sql/sspt/parser/sspt.jj     | 136 ++++++
 .../camel/component/sql/sspt/ParserTest.java    |  81 ++++
 .../camel/component/sql/sspt/ProducerTest.java  |  72 +++
 .../sql/sspt/SimpleStoredProcedureTest.java     |  57 +++
 .../sql/sspt/SimpleStoredProcedureUdf.java      |  15 +
 .../test/resources/sql/storedProcedureTest.sql  |  22 +
 23 files changed, 2338 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
index b16147d..247952d 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
@@ -20,6 +20,7 @@ import org.apache.camel.Component;
 import org.apache.camel.Consumer;
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
+import org.apache.camel.component.sql.sspt.ProducerSSPTHelper;
 import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriPath;
@@ -61,7 +62,9 @@ public class SqlEndpoint extends DefaultSqlEndpoint {
 
     public Producer createProducer() throws Exception {
         SqlPrepareStatementStrategy prepareStrategy = getPrepareStatementStrategy() != null ? getPrepareStatementStrategy() : new DefaultSqlPrepareStatementStrategy(getSeparator());
-        SqlProducer result = new SqlProducer(this, query, getJdbcTemplate(), prepareStrategy, isBatch(), isAlwaysPopulateStatement(), isUseMessageBodyForSql());
+        ProducerSSPTHelper producerSSPTHelper = new ProducerSSPTHelper(getJdbcTemplate().getDataSource());
+        SqlProducer result = new SqlProducer(this, query, getJdbcTemplate(), prepareStrategy, isBatch(),
+                isAlwaysPopulateStatement(), isUseMessageBodyForSql(),producerSSPTHelper);
         result.setParametersCount(getParametersCount());
         return result;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
index 483bd72..a8a85ac 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
@@ -27,6 +27,8 @@ import java.util.List;
 import java.util.Map;
 
 import org.apache.camel.Exchange;
+
+import org.apache.camel.component.sql.sspt.ProducerSSPTHelper;
 import org.apache.camel.impl.DefaultProducer;
 import org.springframework.jdbc.core.JdbcTemplate;
 import org.springframework.jdbc.core.PreparedStatementCallback;
@@ -42,9 +44,11 @@ public class SqlProducer extends DefaultProducer {
     private final SqlPrepareStatementStrategy sqlPrepareStatementStrategy;
     private final boolean useMessageBodyForSql;
     private int parametersCount;
+    private final ProducerSSPTHelper producerSSPTHelper;
 
     public SqlProducer(SqlEndpoint endpoint, String query, JdbcTemplate jdbcTemplate, SqlPrepareStatementStrategy sqlPrepareStatementStrategy,
-                       boolean batch, boolean alwaysPopulateStatement, boolean useMessageBodyForSql) {
+                       boolean batch, boolean alwaysPopulateStatement, boolean useMessageBodyForSql,
+                       ProducerSSPTHelper producerSSPTHelper) {
         super(endpoint);
         this.jdbcTemplate = jdbcTemplate;
         this.sqlPrepareStatementStrategy = sqlPrepareStatementStrategy;
@@ -52,6 +56,7 @@ public class SqlProducer extends DefaultProducer {
         this.batch = batch;
         this.alwaysPopulateStatement = alwaysPopulateStatement;
         this.useMessageBodyForSql = useMessageBodyForSql;
+        this.producerSSPTHelper = producerSSPTHelper;
     }
 
     @Override
@@ -61,12 +66,20 @@ public class SqlProducer extends DefaultProducer {
 
     public void process(final Exchange exchange) throws Exception {
         final String sql;
+
         if (useMessageBodyForSql) {
             sql = exchange.getIn().getBody(String.class);
         } else {
             String queryHeader = exchange.getIn().getHeader(SqlConstants.SQL_QUERY, String.class);
             sql = queryHeader != null ? queryHeader : query;
         }
+
+        if(producerSSPTHelper.isSSPTQuery(sql)) {
+            producerSSPTHelper.handleSstpQuery(sql,exchange);
+            return;
+        }
+
+
         final String preparedQuery = sqlPrepareStatementStrategy.prepareQuery(sql, getEndpoint().isAllowNamedParameters());
 
         // CAMEL-7313 - check whether to return generated keys
@@ -208,6 +221,8 @@ public class SqlProducer extends DefaultProducer {
         });
     }
 
+
+
     public void setParametersCount(int parametersCount) {
         this.parametersCount = parametersCount;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
new file mode 100644
index 0000000..75e7a71
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
@@ -0,0 +1,36 @@
+package org.apache.camel.component.sql.sspt;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.RuntimeCamelException;
+import org.apache.camel.component.sql.sspt.ast.ParseException;
+
+import javax.sql.DataSource;
+
+/**
+ * Created by snurmine on 1/1/16.
+ */
+public class ProducerSSPTHelper {
+
+    public static final String SSPT_QUERY_PREFIX = "sspt:";
+    final DataSource dataSource;
+    SimpleStoredProcedureFactory simpleStoredProcedureFactory = new SimpleStoredProcedureFactory();
+
+    public ProducerSSPTHelper(DataSource dataSource) {
+        this.dataSource = dataSource;
+    }
+
+    public void handleSstpQuery(String sql, Exchange exchange) {
+        try {
+            String sstp = sql.substring(SSPT_QUERY_PREFIX.length());
+            //TODO: cache parsed SimpleStoredProcedure to LRU-cache.
+            SimpleStoredProcedure storedProcedure = simpleStoredProcedureFactory.createFromString(sstp, dataSource);
+            storedProcedure.execute(exchange);
+        } catch (ParseException parseException) {
+            throw new RuntimeCamelException(parseException);
+        }
+    }
+
+    public boolean isSSPTQuery(String sql) {
+        return sql.startsWith(SSPT_QUERY_PREFIX);
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
new file mode 100644
index 0000000..55da509
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
@@ -0,0 +1,56 @@
+package org.apache.camel.component.sql.sspt;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.sspt.ast.InputParameter;
+import org.apache.camel.component.sql.sspt.ast.OutParameter;
+import org.apache.camel.component.sql.sspt.ast.Template;
+import org.springframework.jdbc.core.SqlOutParameter;
+import org.springframework.jdbc.core.SqlParameter;
+import org.springframework.jdbc.object.StoredProcedure;
+
+import javax.sql.DataSource;
+import java.util.HashMap;
+import java.util.Map;
+
+
+public class SimpleStoredProcedure extends StoredProcedure {
+
+    Template template;
+
+    public SimpleStoredProcedure(DataSource dataSource, Template template) {
+        this.template = template;
+        setDataSource(dataSource);
+
+        setSql(template.getProcedureName());
+
+        for (InputParameter inputParameter : template.getInputParameterList()) {
+            declareParameter(new SqlParameter(inputParameter.getName(), inputParameter.getSqlType()));
+        }
+
+        for (OutParameter outParameter : template.getOutParameterList()) {
+            declareParameter(new SqlOutParameter(outParameter.getName(), outParameter.getSqlType()));
+            setFunction(false);
+        }
+
+        compile();
+    }
+
+
+    public void execute(Exchange exchange) {
+
+        Map<String, Object> params = new HashMap<>();
+
+        for (InputParameter inputParameter : template.getInputParameterList()) {
+            params.put(inputParameter.getName(), inputParameter.getValueExpression().evaluate(exchange, inputParameter.getJavaType()));
+        }
+
+        Map<String, Object> ret = super.execute(params);
+
+        for (OutParameter out : template.getOutParameterList()) {
+            exchange.getOut().setHeader(out.getOutHeader(), ret.get(out.getName()));
+        }
+
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
new file mode 100644
index 0000000..43765b2
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
@@ -0,0 +1,33 @@
+package org.apache.camel.component.sql.sspt;
+
+import org.apache.camel.component.sql.sspt.ast.ParseException;
+import org.apache.camel.component.sql.sspt.ast.Template;
+import org.apache.camel.component.sql.sspt.parser.SSPTParser;
+
+import javax.sql.DataSource;
+import java.io.StringReader;
+
+public class SimpleStoredProcedureFactory {
+
+
+    public SimpleStoredProcedure createFromString(String string, DataSource dataSource) throws ParseException {
+        Template sptpRootNode = parseTemplate(string);
+        return new SimpleStoredProcedure(dataSource, sptpRootNode);
+
+    }
+
+    public Template parseTemplate(String template) throws ParseException {
+        SSPTParser parser = new SSPTParser(new StringReader(template));
+
+        return validate(parser.parse());
+    }
+
+    private Template validate(Template input) throws ParseException {
+        if (input.getOutParameterList().isEmpty()) {
+            throw new ParseException("At least one OUT parameter must be given.");
+        }
+        return input;
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
new file mode 100644
index 0000000..2dfd62b
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
@@ -0,0 +1,47 @@
+package org.apache.camel.component.sql.sspt.ast;
+
+import org.apache.camel.Expression;
+import org.apache.camel.builder.ExpressionBuilder;
+
+
+public class InputParameter {
+
+    String name;
+
+    int sqlType;
+
+    Expression valueExpression;
+
+    Class javaType;
+
+
+    public InputParameter(String name, int sqlType, String valueSrcAsStr, Class javaType) {
+        this.name = name;
+        this.sqlType = sqlType;
+        this.javaType = javaType;
+        this.valueExpression = parseValueExpression(valueSrcAsStr);
+    }
+
+
+    private Expression parseValueExpression(String str) {
+        return ExpressionBuilder.simpleExpression(str);
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public int getSqlType() {
+        return sqlType;
+    }
+
+    public Expression getValueExpression() {
+        return valueExpression;
+    }
+
+    public Class getJavaType() {
+        return javaType;
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
new file mode 100644
index 0000000..b7914e4
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
@@ -0,0 +1,33 @@
+package org.apache.camel.component.sql.sspt.ast;
+
+/**
+ * Created by snurmine on 12/20/15.
+ */
+public class OutParameter {
+
+
+    String name;
+
+    int sqlType;
+
+    String outHeader;
+
+
+    public OutParameter(String name, int sqlType, String outHeader) {
+        this.name = name;
+        this.sqlType = sqlType;
+        this.outHeader = outHeader;
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public int getSqlType() {
+        return sqlType;
+    }
+
+    public String getOutHeader() {
+        return outHeader;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
new file mode 100644
index 0000000..f6b5878
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
@@ -0,0 +1,189 @@
+/* Generated By:JavaCC: Do not edit this line. ParseException.java Version 5.0 */
+/* JavaCCOptions:KEEP_LINE_COL=null */
+package org.apache.camel.component.sql.sspt.ast;
+
+import org.apache.camel.component.sql.sspt.parser.Token;
+
+/**
+ * This exception is thrown when parse errors are encountered.
+ * You can explicitly create objects of this exception type by
+ * calling the method generateParseException in the generated
+ * parser.
+ * <p>
+ * You can modify this class to customize your error reporting
+ * mechanisms so long as you retain the public fields.
+ */
+public class ParseException extends RuntimeException {
+
+    /**
+     * The version identifier for this Serializable class.
+     * Increment only if the <i>serialized</i> form of the
+     * class changes.
+     */
+    private static final long serialVersionUID = 1L;
+    /**
+     * This is the last token that has been consumed successfully.  If
+     * this object has been created due to a parse error, the token
+     * followng this token will (therefore) be the first error token.
+     */
+    public Token currentToken;
+    /**
+     * Each entry in this array is an array of integers.  Each array
+     * of integers represents a sequence of tokens (by their ordinal
+     * values) that is expected at this point of the parse.
+     */
+    public int[][] expectedTokenSequences;
+    /**
+     * This is a reference to the "tokenImage" array of the generated
+     * parser within which the parse error occurred.  This array is
+     * defined in the generated ...Constants interface.
+     */
+    public String[] tokenImage;
+    /**
+     * The end of line string for this machine.
+     */
+    protected String eol = System.getProperty("line.separator", "\n");
+
+
+    /**
+     * This constructor is used by the method "generateParseException"
+     * in the generated parser.  Calling this constructor generates
+     * a new object of this type with the fields "currentToken",
+     * "expectedTokenSequences", and "tokenImage" set.
+     */
+    public ParseException(Token currentTokenVal,
+                          int[][] expectedTokenSequencesVal,
+                          String[] tokenImageVal
+    ) {
+        super(initialise(currentTokenVal, expectedTokenSequencesVal, tokenImageVal));
+        currentToken = currentTokenVal;
+        expectedTokenSequences = expectedTokenSequencesVal;
+        tokenImage = tokenImageVal;
+    }
+
+    /**
+     * The following constructors are for use by you for whatever
+     * purpose you can think of.  Constructing the exception in this
+     * manner makes the exception behave in the normal way - i.e., as
+     * documented in the class "Throwable".  The fields "errorToken",
+     * "expectedTokenSequences", and "tokenImage" do not contain
+     * relevant information.  The JavaCC generated code does not use
+     * these constructors.
+     */
+
+    public ParseException() {
+        super();
+    }
+
+    /**
+     * Constructor with message.
+     */
+    public ParseException(String message) {
+        super(message);
+    }
+
+    public ParseException(Exception cause) {
+        super(cause);
+    }
+
+    /**
+     * It uses "currentToken" and "expectedTokenSequences" to generate a parse
+     * error message and returns it.  If this object has been created
+     * due to a parse error, and you do not catch it (it gets thrown
+     * from the parser) the correct error message
+     * gets displayed.
+     */
+    private static String initialise(Token currentToken,
+                                     int[][] expectedTokenSequences,
+                                     String[] tokenImage) {
+        String eol = System.getProperty("line.separator", "\n");
+        StringBuffer expected = new StringBuffer();
+        int maxSize = 0;
+        for (int i = 0; i < expectedTokenSequences.length; i++) {
+            if (maxSize < expectedTokenSequences[i].length) {
+                maxSize = expectedTokenSequences[i].length;
+            }
+            for (int j = 0; j < expectedTokenSequences[i].length; j++) {
+                expected.append(tokenImage[expectedTokenSequences[i][j]]).append(' ');
+            }
+            if (expectedTokenSequences[i][expectedTokenSequences[i].length - 1] != 0) {
+                expected.append("...");
+            }
+            expected.append(eol).append("    ");
+        }
+        String retval = "Encountered \"";
+        Token tok = currentToken.next;
+        for (int i = 0; i < maxSize; i++) {
+            if (i != 0) retval += " ";
+            if (tok.kind == 0) {
+                retval += tokenImage[0];
+                break;
+            }
+            retval += " " + tokenImage[tok.kind];
+            retval += " \"";
+            retval += add_escapes(tok.image);
+            retval += " \"";
+            tok = tok.next;
+        }
+        retval += "\" at line " + currentToken.next.beginLine + ", column " + currentToken.next.beginColumn;
+        retval += "." + eol;
+        if (expectedTokenSequences.length == 1) {
+            retval += "Was expecting:" + eol + "    ";
+        } else {
+            retval += "Was expecting one of:" + eol + "    ";
+        }
+        retval += expected.toString();
+        return retval;
+    }
+
+    /**
+     * Used to convert raw characters to their escaped version
+     * when these raw version cannot be used as part of an ASCII
+     * string literal.
+     */
+    static String add_escapes(String str) {
+        StringBuffer retval = new StringBuffer();
+        char ch;
+        for (int i = 0; i < str.length(); i++) {
+            switch (str.charAt(i)) {
+                case 0:
+                    continue;
+                case '\b':
+                    retval.append("\\b");
+                    continue;
+                case '\t':
+                    retval.append("\\t");
+                    continue;
+                case '\n':
+                    retval.append("\\n");
+                    continue;
+                case '\f':
+                    retval.append("\\f");
+                    continue;
+                case '\r':
+                    retval.append("\\r");
+                    continue;
+                case '\"':
+                    retval.append("\\\"");
+                    continue;
+                case '\'':
+                    retval.append("\\\'");
+                    continue;
+                case '\\':
+                    retval.append("\\\\");
+                    continue;
+                default:
+                    if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
+                        String s = "0000" + Integer.toString(ch, 16);
+                        retval.append("\\u" + s.substring(s.length() - 4, s.length()));
+                    } else {
+                        retval.append(ch);
+                    }
+                    continue;
+            }
+        }
+        return retval.toString();
+    }
+
+}
+/* JavaCC - OriginalChecksum=9df9fe5c4e531f41d82ff5964724c931 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
new file mode 100644
index 0000000..1b372db
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
@@ -0,0 +1,58 @@
+package org.apache.camel.component.sql.sspt.ast;
+
+import org.springframework.util.ReflectionUtils;
+
+import java.lang.reflect.Field;
+import java.math.BigInteger;
+import java.sql.Date;
+import java.sql.Types;
+
+
+public class ParseHelper {
+
+    public static int parseSqlType(String sqlType) {
+        Field field = ReflectionUtils.findField(Types.class, sqlType);
+        if (field == null) {
+            throw new ParseException("Field " + sqlType + " not found from java.procedureName.Types");
+        }
+        try {
+            return field.getInt(Types.class);
+        } catch (IllegalAccessException e) {
+            throw new ParseException(e);
+        }
+    }
+
+    public static Class sqlTypeToJavaType(int sqlType, String sqlTypeStr) {
+        //TODO: as rest of types.
+        //TODO: add test for each type.
+        Class ret = null;
+        switch (sqlType) {
+            case Types.INTEGER:
+                ret = Integer.class;
+                break;
+            case Types.VARCHAR:
+                ret = String.class;
+                break;
+            case Types.BIGINT:
+                ret = BigInteger.class;
+                break;
+            case Types.CHAR:
+                ret = String.class;
+                break;
+            case Types.BOOLEAN:
+                ret = Boolean.class;
+                break;
+            case Types.DATE:
+                ret = Date.class;
+                break;
+            case Types.TIMESTAMP:
+                ret = Date.class;
+                break;
+        }
+        if (ret == null) {
+            throw new ParseException("Unable to map SQL type " + sqlTypeStr + " to Java type");
+
+        }
+        return ret;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
new file mode 100644
index 0000000..adcb740
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
@@ -0,0 +1,43 @@
+package org.apache.camel.component.sql.sspt.ast;
+
+import java.util.ArrayList;
+import java.util.List;
+
+/**
+ * Root element of Simple Stored Procedure Template AST.
+ */
+public class Template {
+
+    String procedureName;
+
+    List<InputParameter> inputParameterList = new ArrayList<>();
+
+    List<OutParameter> outParameterList = new ArrayList<>();
+
+    public void addParameter(Object parameter) {
+
+        if (parameter instanceof OutParameter) {
+            outParameterList.add((OutParameter) parameter);
+        } else {
+            inputParameterList.add((InputParameter) parameter);
+
+        }
+    }
+
+    public String getProcedureName() {
+        return procedureName;
+    }
+
+    public void setProcedureName(String procedureName) {
+        this.procedureName = procedureName;
+    }
+
+    public List<InputParameter> getInputParameterList() {
+        return inputParameterList;
+    }
+
+    public List<OutParameter> getOutParameterList() {
+        return outParameterList;
+    }
+}
+

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
new file mode 100644
index 0000000..66b0843
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
@@ -0,0 +1,282 @@
+/* Generated By: http&JavaCC: Do not edit this line. SSPTParser.java */
+package org.apache.camel.component.sql.sspt.parser;
+
+import org.apache.camel.component.sql.sspt.ast.*;
+
+public class SSPTParser implements SSPTParserConstants {
+   int paramaterNameCounter = 0;
+
+   String createNextParameterName() {
+      return "_"+(paramaterNameCounter++);
+   }
+
+  final public Template parse() throws ParseException {
+    Token procudureName;
+    Template template = new Template();
+    Object parameter = null;
+    procudureName = jj_consume_token(IDENTIFIER);
+    jj_consume_token(1);
+    parameter = Parameter();
+                                                               template.addParameter(parameter);
+    label_1:
+    while (true) {
+      switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
+      case 2:
+        ;
+        break;
+      default:
+        jj_la1[0] = jj_gen;
+        break label_1;
+      }
+      jj_consume_token(2);
+      parameter = Parameter();
+                template.addParameter(parameter);
+    }
+    jj_consume_token(3);
+    jj_consume_token(0);
+   template.setProcedureName(procudureName.toString());
+   {if (true) return template;}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public Object Parameter() throws ParseException {
+    Object param;
+    switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
+    case IDENTIFIER:
+      param = InputParameter();
+                                {if (true) return param;}
+      break;
+    case 5:
+      param = OutParameter();
+                                                                          {if (true) return param;}
+      break;
+    default:
+      jj_la1[1] = jj_gen;
+      jj_consume_token(-1);
+      throw new ParseException();
+    }
+    throw new Error("Missing return statement in function");
+  }
+
+  final public InputParameter InputParameter() throws ParseException {
+     String sqlTypeAsStr;
+     String name;
+     String valueSrcAsStr;
+    sqlTypeAsStr = ParameterSqlType();
+    jj_consume_token(4);
+    valueSrcAsStr = InputParameterSrc();
+        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
+        {if (true) return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public OutParameter OutParameter() throws ParseException {
+     String sqlType;
+     String name;
+     String outHeader;
+    jj_consume_token(5);
+    jj_consume_token(4);
+    sqlType = ParameterSqlType();
+    jj_consume_token(4);
+    outHeader = OutHeader();
+        {if (true) return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String ParameterSqlType() throws ParseException {
+    Token t;
+    t = jj_consume_token(IDENTIFIER);
+        {if (true) return t.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String OutHeader() throws ParseException {
+ Token token;
+    token = jj_consume_token(IDENTIFIER);
+        {if (true) return token.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String InputParameterSrc() throws ParseException {
+    String ret;
+    ret = SimpleExpression();
+        {if (true) return ret;}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String SimpleExpression() throws ParseException {
+ Token t = null;
+    t = jj_consume_token(SIMPLE_EXP_TOKEN);
+    {if (true) return t.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  /** Generated Token Manager. */
+  public SSPTParserTokenManager token_source;
+  SimpleCharStream jj_input_stream;
+  /** Current token. */
+  public Token token;
+  /** Next token. */
+  public Token jj_nt;
+  private int jj_ntk;
+  private int jj_gen;
+  final private int[] jj_la1 = new int[2];
+  static private int[] jj_la1_0;
+  static {
+      jj_la1_init_0();
+   }
+   private static void jj_la1_init_0() {
+      jj_la1_0 = new int[] {0x4,0x220,};
+   }
+
+  /** Constructor with InputStream. */
+  public SSPTParser(java.io.InputStream stream) {
+     this(stream, null);
+  }
+  /** Constructor with InputStream and supplied encoding */
+  public SSPTParser(java.io.InputStream stream, String encoding) {
+    try { jj_input_stream = new SimpleCharStream(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
+    token_source = new SSPTParserTokenManager(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream stream) {
+     ReInit(stream, null);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream stream, String encoding) {
+    try { jj_input_stream.ReInit(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
+    token_source.ReInit(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  /** Constructor. */
+  public SSPTParser(java.io.Reader stream) {
+    jj_input_stream = new SimpleCharStream(stream, 1, 1);
+    token_source = new SSPTParserTokenManager(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader stream) {
+    jj_input_stream.ReInit(stream, 1, 1);
+    token_source.ReInit(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  /** Constructor with generated Token Manager. */
+  public SSPTParser(SSPTParserTokenManager tm) {
+    token_source = tm;
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(SSPTParserTokenManager tm) {
+    token_source = tm;
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
+  }
+
+  private Token jj_consume_token(int kind) throws ParseException {
+    Token oldToken;
+    if ((oldToken = token).next != null) token = token.next;
+    else token = token.next = token_source.getNextToken();
+    jj_ntk = -1;
+    if (token.kind == kind) {
+      jj_gen++;
+      return token;
+    }
+    token = oldToken;
+    jj_kind = kind;
+    throw generateParseException();
+  }
+
+
+/** Get the next Token. */
+  final public Token getNextToken() {
+    if (token.next != null) token = token.next;
+    else token = token.next = token_source.getNextToken();
+    jj_ntk = -1;
+    jj_gen++;
+    return token;
+  }
+
+/** Get the specific Token. */
+  final public Token getToken(int index) {
+    Token t = token;
+    for (int i = 0; i < index; i++) {
+      if (t.next != null) t = t.next;
+      else t = t.next = token_source.getNextToken();
+    }
+    return t;
+  }
+
+  private int jj_ntk() {
+    if ((jj_nt=token.next) == null)
+      return (jj_ntk = (token.next=token_source.getNextToken()).kind);
+    else
+      return (jj_ntk = jj_nt.kind);
+  }
+
+  private java.util.List<int[]> jj_expentries = new java.util.ArrayList<int[]>();
+  private int[] jj_expentry;
+  private int jj_kind = -1;
+
+  /** Generate ParseException. */
+  public ParseException generateParseException() {
+    jj_expentries.clear();
+    boolean[] la1tokens = new boolean[10];
+    if (jj_kind >= 0) {
+      la1tokens[jj_kind] = true;
+      jj_kind = -1;
+    }
+    for (int i = 0; i < 2; i++) {
+      if (jj_la1[i] == jj_gen) {
+        for (int j = 0; j < 32; j++) {
+          if ((jj_la1_0[i] & (1<<j)) != 0) {
+            la1tokens[j] = true;
+          }
+        }
+      }
+    }
+    for (int i = 0; i < 10; i++) {
+      if (la1tokens[i]) {
+        jj_expentry = new int[1];
+        jj_expentry[0] = i;
+        jj_expentries.add(jj_expentry);
+      }
+    }
+    int[][] exptokseq = new int[jj_expentries.size()][];
+    for (int i = 0; i < jj_expentries.size(); i++) {
+      exptokseq[i] = jj_expentries.get(i);
+    }
+    return new ParseException(token, exptokseq, tokenImage);
+  }
+
+  /** Enable tracing. */
+  final public void enable_tracing() {
+  }
+
+  /** Disable tracing. */
+  final public void disable_tracing() {
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
new file mode 100644
index 0000000..54e57d3
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
@@ -0,0 +1,39 @@
+/* Generated By: http&JavaCC: Do not edit this line. SSPTParserConstants.java */
+package org.apache.camel.component.sql.sspt.parser;
+
+
+/**
+ * Token literal values and constants.
+ * Generated by org.javacc.parser.OtherFilesGen#start()
+ */
+public interface SSPTParserConstants {
+
+  /** End of File. */
+  int EOF = 0;
+  /** RegularExpression Id. */
+  int DIGIT = 6;
+  /** RegularExpression Id. */
+  int LETTER = 7;
+  /** RegularExpression Id. */
+  int SIMPLE_EXP_TOKEN = 8;
+  /** RegularExpression Id. */
+  int IDENTIFIER = 9;
+
+  /** Lexical state. */
+  int DEFAULT = 0;
+
+  /** Literal token values. */
+  String[] tokenImage = {
+    "<EOF>",
+    "\"(\"",
+    "\",\"",
+    "\")\"",
+    "\" \"",
+    "\"OUT\"",
+    "<DIGIT>",
+    "<LETTER>",
+    "<SIMPLE_EXP_TOKEN>",
+    "<IDENTIFIER>",
+  };
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
new file mode 100644
index 0000000..4daa202
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
@@ -0,0 +1,366 @@
+/* Generated By: http&JavaCC: Do not edit this line. SSPTParserTokenManager.java */
+package org.apache.camel.component.sql.sspt.parser;
+import org.apache.camel.component.sql.sspt.ast.*;
+
+/** Token Manager. */
+public class SSPTParserTokenManager implements SSPTParserConstants
+{
+
+  /** Debug output. */
+  public  java.io.PrintStream debugStream = System.out;
+  /** Set debug output. */
+  public  void setDebugStream(java.io.PrintStream ds) { debugStream = ds; }
+private final int jjStopStringLiteralDfa_0(int pos, long active0)
+{
+   switch (pos)
+   {
+      case 0:
+         if ((active0 & 0x20L) != 0L)
+         {
+            jjmatchedKind = 9;
+            return 5;
+         }
+         return -1;
+      case 1:
+         if ((active0 & 0x20L) != 0L)
+         {
+            jjmatchedKind = 9;
+            jjmatchedPos = 1;
+            return 5;
+         }
+         return -1;
+      default :
+         return -1;
+   }
+}
+private final int jjStartNfa_0(int pos, long active0)
+{
+   return jjMoveNfa_0(jjStopStringLiteralDfa_0(pos, active0), pos + 1);
+}
+private int jjStopAtPos(int pos, int kind)
+{
+   jjmatchedKind = kind;
+   jjmatchedPos = pos;
+   return pos + 1;
+}
+private int jjMoveStringLiteralDfa0_0()
+{
+   switch(curChar)
+   {
+      case 32:
+         return jjStopAtPos(0, 4);
+      case 40:
+         return jjStopAtPos(0, 1);
+      case 41:
+         return jjStopAtPos(0, 3);
+      case 44:
+         return jjStopAtPos(0, 2);
+      case 79:
+         return jjMoveStringLiteralDfa1_0(0x20L);
+      default :
+         return jjMoveNfa_0(3, 0);
+   }
+}
+private int jjMoveStringLiteralDfa1_0(long active0)
+{
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) {
+      jjStopStringLiteralDfa_0(0, active0);
+      return 1;
+   }
+   switch(curChar)
+   {
+      case 85:
+         return jjMoveStringLiteralDfa2_0(active0, 0x20L);
+      default :
+         break;
+   }
+   return jjStartNfa_0(0, active0);
+}
+private int jjMoveStringLiteralDfa2_0(long old0, long active0)
+{
+   if (((active0 &= old0)) == 0L)
+      return jjStartNfa_0(0, old0);
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) {
+      jjStopStringLiteralDfa_0(1, active0);
+      return 2;
+   }
+   switch(curChar)
+   {
+      case 84:
+         if ((active0 & 0x20L) != 0L)
+            return jjStartNfaWithStates_0(2, 5, 5);
+         break;
+      default :
+         break;
+   }
+   return jjStartNfa_0(1, active0);
+}
+private int jjStartNfaWithStates_0(int pos, int kind, int state)
+{
+   jjmatchedKind = kind;
+   jjmatchedPos = pos;
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) { return pos + 1; }
+   return jjMoveNfa_0(state, pos + 1);
+}
+private int jjMoveNfa_0(int startState, int curPos)
+{
+   int startsAt = 0;
+   jjnewStateCnt = 6;
+   int i = 1;
+   jjstateSet[0] = startState;
+   int kind = 0x7fffffff;
+   for (;;)
+   {
+      if (++jjround == 0x7fffffff)
+         ReInitRounds();
+      if (curChar < 64)
+      {
+         long l = 1L << curChar;
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               case 3:
+                  if (curChar == 36)
+                     jjstateSet[jjnewStateCnt++] = 0;
+                  break;
+               case 1:
+                  if ((0x3ff408100000000L & l) != 0L)
+                     jjAddStates(0, 1);
+                  break;
+               case 5:
+                  if ((0x3ff400000000000L & l) == 0L)
+                     break;
+                  if (kind > 9)
+                     kind = 9;
+                  jjstateSet[jjnewStateCnt++] = 5;
+                  break;
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      else if (curChar < 128)
+      {
+         long l = 1L << (curChar & 077);
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               case 3:
+               case 5:
+                  if ((0x7fffffe07fffffeL & l) == 0L)
+                     break;
+                  if (kind > 9)
+                     kind = 9;
+                  jjCheckNAdd(5);
+                  break;
+               case 0:
+                  if (curChar == 123)
+                     jjCheckNAddTwoStates(1, 2);
+                  break;
+               case 1:
+                  if ((0x7fffffe07fffffeL & l) != 0L)
+                     jjCheckNAddTwoStates(1, 2);
+                  break;
+               case 2:
+                  if (curChar == 125)
+                     kind = 8;
+                  break;
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      else
+      {
+         int i2 = (curChar & 0xff) >> 6;
+         long l2 = 1L << (curChar & 077);
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      if (kind != 0x7fffffff)
+      {
+         jjmatchedKind = kind;
+         jjmatchedPos = curPos;
+         kind = 0x7fffffff;
+      }
+      ++curPos;
+      if ((i = jjnewStateCnt) == (startsAt = 6 - (jjnewStateCnt = startsAt)))
+         return curPos;
+      try { curChar = input_stream.readChar(); }
+      catch(java.io.IOException e) { return curPos; }
+   }
+}
+static final int[] jjnextStates = {
+   1, 2, 
+};
+
+/** Token literal values. */
+public static final String[] jjstrLiteralImages = {
+"", "\50", "\54", "\51", "\40", "\117\125\124", null, null, null, null, };
+
+/** Lexer state names. */
+public static final String[] lexStateNames = {
+   "DEFAULT",
+};
+protected SimpleCharStream input_stream;
+private final int[] jjrounds = new int[6];
+private final int[] jjstateSet = new int[12];
+protected char curChar;
+/** Constructor. */
+public SSPTParserTokenManager(SimpleCharStream stream){
+   if (SimpleCharStream.staticFlag)
+      throw new Error("ERROR: Cannot use a static CharStream class with a non-static lexical analyzer.");
+   input_stream = stream;
+}
+
+/** Constructor. */
+public SSPTParserTokenManager(SimpleCharStream stream, int lexState){
+   this(stream);
+   SwitchTo(lexState);
+}
+
+/** Reinitialise parser. */
+public void ReInit(SimpleCharStream stream)
+{
+   jjmatchedPos = jjnewStateCnt = 0;
+   curLexState = defaultLexState;
+   input_stream = stream;
+   ReInitRounds();
+}
+private void ReInitRounds()
+{
+   int i;
+   jjround = 0x80000001;
+   for (i = 6; i-- > 0;)
+      jjrounds[i] = 0x80000000;
+}
+
+/** Reinitialise parser. */
+public void ReInit(SimpleCharStream stream, int lexState)
+{
+   ReInit(stream);
+   SwitchTo(lexState);
+}
+
+/** Switch to specified lex state. */
+public void SwitchTo(int lexState)
+{
+   if (lexState >= 1 || lexState < 0)
+      throw new TokenMgrError("Error: Ignoring invalid lexical state : " + lexState + ". State unchanged.", TokenMgrError.INVALID_LEXICAL_STATE);
+   else
+      curLexState = lexState;
+}
+
+protected Token jjFillToken()
+{
+   final Token t;
+   final String curTokenImage;
+   final int beginLine;
+   final int endLine;
+   final int beginColumn;
+   final int endColumn;
+   String im = jjstrLiteralImages[jjmatchedKind];
+   curTokenImage = (im == null) ? input_stream.GetImage() : im;
+   beginLine = input_stream.getBeginLine();
+   beginColumn = input_stream.getBeginColumn();
+   endLine = input_stream.getEndLine();
+   endColumn = input_stream.getEndColumn();
+   t = Token.newToken(jjmatchedKind, curTokenImage);
+
+   t.beginLine = beginLine;
+   t.endLine = endLine;
+   t.beginColumn = beginColumn;
+   t.endColumn = endColumn;
+
+   return t;
+}
+
+int curLexState = 0;
+int defaultLexState = 0;
+int jjnewStateCnt;
+int jjround;
+int jjmatchedPos;
+int jjmatchedKind;
+
+/** Get the next Token. */
+public Token getNextToken() 
+{
+  Token matchedToken;
+  int curPos = 0;
+
+  EOFLoop :
+  for (;;)
+  {
+   try
+   {
+      curChar = input_stream.BeginToken();
+   }
+   catch(java.io.IOException e)
+   {
+      jjmatchedKind = 0;
+      matchedToken = jjFillToken();
+      return matchedToken;
+   }
+
+   jjmatchedKind = 0x7fffffff;
+   jjmatchedPos = 0;
+   curPos = jjMoveStringLiteralDfa0_0();
+   if (jjmatchedKind != 0x7fffffff)
+   {
+      if (jjmatchedPos + 1 < curPos)
+         input_stream.backup(curPos - jjmatchedPos - 1);
+         matchedToken = jjFillToken();
+         return matchedToken;
+   }
+   int error_line = input_stream.getEndLine();
+   int error_column = input_stream.getEndColumn();
+   String error_after = null;
+   boolean EOFSeen = false;
+   try { input_stream.readChar(); input_stream.backup(1); }
+   catch (java.io.IOException e1) {
+      EOFSeen = true;
+      error_after = curPos <= 1 ? "" : input_stream.GetImage();
+      if (curChar == '\n' || curChar == '\r') {
+         error_line++;
+         error_column = 0;
+      }
+      else
+         error_column++;
+   }
+   if (!EOFSeen) {
+      input_stream.backup(1);
+      error_after = curPos <= 1 ? "" : input_stream.GetImage();
+   }
+   throw new TokenMgrError(EOFSeen, curLexState, error_line, error_column, error_after, curChar, TokenMgrError.LEXICAL_ERROR);
+  }
+}
+
+private void jjCheckNAdd(int state)
+{
+   if (jjrounds[state] != jjround)
+   {
+      jjstateSet[jjnewStateCnt++] = state;
+      jjrounds[state] = jjround;
+   }
+}
+private void jjAddStates(int start, int end)
+{
+   do {
+      jjstateSet[jjnewStateCnt++] = jjnextStates[start];
+   } while (start++ != end);
+}
+private void jjCheckNAddTwoStates(int state1, int state2)
+{
+   jjCheckNAdd(state1);
+   jjCheckNAdd(state2);
+}
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
new file mode 100644
index 0000000..58a03ae
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
@@ -0,0 +1,471 @@
+/* Generated By:JavaCC: Do not edit this line. SimpleCharStream.java Version 5.0 */
+/* JavaCCOptions:STATIC=false,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
+package org.apache.camel.component.sql.sspt.parser;
+
+/**
+ * An implementation of interface CharStream, where the stream is assumed to
+ * contain only ASCII characters (without unicode processing).
+ */
+
+public class SimpleCharStream
+{
+/** Whether parser is static. */
+  public static final boolean staticFlag = false;
+  int bufsize;
+  int available;
+  int tokenBegin;
+/** Position in buffer. */
+  public int bufpos = -1;
+  protected int bufline[];
+  protected int bufcolumn[];
+
+  protected int column = 0;
+  protected int line = 1;
+
+  protected boolean prevCharIsCR = false;
+  protected boolean prevCharIsLF = false;
+
+  protected java.io.Reader inputStream;
+
+  protected char[] buffer;
+  protected int maxNextCharInd = 0;
+  protected int inBuf = 0;
+  protected int tabSize = 8;
+
+  protected void setTabSize(int i) { tabSize = i; }
+  protected int getTabSize(int i) { return tabSize; }
+
+
+  protected void ExpandBuff(boolean wrapAround)
+  {
+    char[] newbuffer = new char[bufsize + 2048];
+    int newbufline[] = new int[bufsize + 2048];
+    int newbufcolumn[] = new int[bufsize + 2048];
+
+    try
+    {
+      if (wrapAround)
+      {
+        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
+        System.arraycopy(buffer, 0, newbuffer, bufsize - tokenBegin, bufpos);
+        buffer = newbuffer;
+
+        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
+        System.arraycopy(bufline, 0, newbufline, bufsize - tokenBegin, bufpos);
+        bufline = newbufline;
+
+        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
+        System.arraycopy(bufcolumn, 0, newbufcolumn, bufsize - tokenBegin, bufpos);
+        bufcolumn = newbufcolumn;
+
+        maxNextCharInd = (bufpos += (bufsize - tokenBegin));
+      }
+      else
+      {
+        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
+        buffer = newbuffer;
+
+        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
+        bufline = newbufline;
+
+        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
+        bufcolumn = newbufcolumn;
+
+        maxNextCharInd = (bufpos -= tokenBegin);
+      }
+    }
+    catch (Throwable t)
+    {
+      throw new Error(t.getMessage());
+    }
+
+
+    bufsize += 2048;
+    available = bufsize;
+    tokenBegin = 0;
+  }
+
+  protected void FillBuff() throws java.io.IOException
+  {
+    if (maxNextCharInd == available)
+    {
+      if (available == bufsize)
+      {
+        if (tokenBegin > 2048)
+        {
+          bufpos = maxNextCharInd = 0;
+          available = tokenBegin;
+        }
+        else if (tokenBegin < 0)
+          bufpos = maxNextCharInd = 0;
+        else
+          ExpandBuff(false);
+      }
+      else if (available > tokenBegin)
+        available = bufsize;
+      else if ((tokenBegin - available) < 2048)
+        ExpandBuff(true);
+      else
+        available = tokenBegin;
+    }
+
+    int i;
+    try {
+      if ((i = inputStream.read(buffer, maxNextCharInd, available - maxNextCharInd)) == -1)
+      {
+        inputStream.close();
+        throw new java.io.IOException();
+      }
+      else
+        maxNextCharInd += i;
+      return;
+    }
+    catch(java.io.IOException e) {
+      --bufpos;
+      backup(0);
+      if (tokenBegin == -1)
+        tokenBegin = bufpos;
+      throw e;
+    }
+  }
+
+/** Start. */
+  public char BeginToken() throws java.io.IOException
+  {
+    tokenBegin = -1;
+    char c = readChar();
+    tokenBegin = bufpos;
+
+    return c;
+  }
+
+  protected void UpdateLineColumn(char c)
+  {
+    column++;
+
+    if (prevCharIsLF)
+    {
+      prevCharIsLF = false;
+      line += (column = 1);
+    }
+    else if (prevCharIsCR)
+    {
+      prevCharIsCR = false;
+      if (c == '\n')
+      {
+        prevCharIsLF = true;
+      }
+      else
+        line += (column = 1);
+    }
+
+    switch (c)
+    {
+      case '\r' :
+        prevCharIsCR = true;
+        break;
+      case '\n' :
+        prevCharIsLF = true;
+        break;
+      case '\t' :
+        column--;
+        column += (tabSize - (column % tabSize));
+        break;
+      default :
+        break;
+    }
+
+    bufline[bufpos] = line;
+    bufcolumn[bufpos] = column;
+  }
+
+/** Read a character. */
+  public char readChar() throws java.io.IOException
+  {
+    if (inBuf > 0)
+    {
+      --inBuf;
+
+      if (++bufpos == bufsize)
+        bufpos = 0;
+
+      return buffer[bufpos];
+    }
+
+    if (++bufpos >= maxNextCharInd)
+      FillBuff();
+
+    char c = buffer[bufpos];
+
+    UpdateLineColumn(c);
+    return c;
+  }
+
+  @Deprecated
+  /**
+   * @deprecated
+   * @see #getEndColumn
+   */
+
+  public int getColumn() {
+    return bufcolumn[bufpos];
+  }
+
+  @Deprecated
+  /**
+   * @deprecated
+   * @see #getEndLine
+   */
+
+  public int getLine() {
+    return bufline[bufpos];
+  }
+
+  /** Get token end column number. */
+  public int getEndColumn() {
+    return bufcolumn[bufpos];
+  }
+
+  /** Get token end line number. */
+  public int getEndLine() {
+     return bufline[bufpos];
+  }
+
+  /** Get token beginning column number. */
+  public int getBeginColumn() {
+    return bufcolumn[tokenBegin];
+  }
+
+  /** Get token beginning line number. */
+  public int getBeginLine() {
+    return bufline[tokenBegin];
+  }
+
+/** Backup a number of characters. */
+  public void backup(int amount) {
+
+    inBuf += amount;
+    if ((bufpos -= amount) < 0)
+      bufpos += bufsize;
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    inputStream = dstream;
+    line = startline;
+    column = startcolumn - 1;
+
+    available = bufsize = buffersize;
+    buffer = new char[buffersize];
+    bufline = new int[buffersize];
+    bufcolumn = new int[buffersize];
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream, int startline,
+                          int startcolumn)
+  {
+    this(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream)
+  {
+    this(dstream, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    inputStream = dstream;
+    line = startline;
+    column = startcolumn - 1;
+
+    if (buffer == null || buffersize != buffer.length)
+    {
+      available = bufsize = buffersize;
+      buffer = new char[buffersize];
+      bufline = new int[buffersize];
+      bufcolumn = new int[buffersize];
+    }
+    prevCharIsLF = prevCharIsCR = false;
+    tokenBegin = inBuf = maxNextCharInd = 0;
+    bufpos = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream, int startline,
+                     int startcolumn)
+  {
+    ReInit(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream)
+  {
+    ReInit(dstream, 1, 1, 4096);
+  }
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
+  int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
+  {
+    this(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    this(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
+                          int startcolumn) throws java.io.UnsupportedEncodingException
+  {
+    this(dstream, encoding, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, int startline,
+                          int startcolumn)
+  {
+    this(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
+  {
+    this(dstream, encoding, 1, 1, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream)
+  {
+    this(dstream, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
+                          int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, int startline,
+                          int startcolumn, int buffersize)
+  {
+    ReInit(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(dstream, encoding, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream)
+  {
+    ReInit(dstream, 1, 1, 4096);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
+                     int startcolumn) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(dstream, encoding, startline, startcolumn, 4096);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, int startline,
+                     int startcolumn)
+  {
+    ReInit(dstream, startline, startcolumn, 4096);
+  }
+  /** Get token literal value. */
+  public String GetImage()
+  {
+    if (bufpos >= tokenBegin)
+      return new String(buffer, tokenBegin, bufpos - tokenBegin + 1);
+    else
+      return new String(buffer, tokenBegin, bufsize - tokenBegin) +
+                            new String(buffer, 0, bufpos + 1);
+  }
+
+  /** Get the suffix. */
+  public char[] GetSuffix(int len)
+  {
+    char[] ret = new char[len];
+
+    if ((bufpos + 1) >= len)
+      System.arraycopy(buffer, bufpos - len + 1, ret, 0, len);
+    else
+    {
+      System.arraycopy(buffer, bufsize - (len - bufpos - 1), ret, 0,
+                                                        len - bufpos - 1);
+      System.arraycopy(buffer, 0, ret, len - bufpos - 1, bufpos + 1);
+    }
+
+    return ret;
+  }
+
+  /** Reset buffer when finished. */
+  public void Done()
+  {
+    buffer = null;
+    bufline = null;
+    bufcolumn = null;
+  }
+
+  /**
+   * Method to adjust line and column numbers for the start of a token.
+   */
+  public void adjustBeginLineColumn(int newLine, int newCol)
+  {
+    int start = tokenBegin;
+    int len;
+
+    if (bufpos >= tokenBegin)
+    {
+      len = bufpos - tokenBegin + inBuf + 1;
+    }
+    else
+    {
+      len = bufsize - tokenBegin + bufpos + 1 + inBuf;
+    }
+
+    int i = 0, j = 0, k = 0;
+    int nextColDiff = 0, columnDiff = 0;
+
+    while (i < len && bufline[j = start % bufsize] == bufline[k = ++start % bufsize])
+    {
+      bufline[j] = newLine;
+      nextColDiff = columnDiff + bufcolumn[k] - bufcolumn[j];
+      bufcolumn[j] = newCol + columnDiff;
+      columnDiff = nextColDiff;
+      i++;
+    }
+
+    if (i < len)
+    {
+      bufline[j] = newLine++;
+      bufcolumn[j] = newCol + columnDiff;
+
+      while (i++ < len)
+      {
+        if (bufline[j = start % bufsize] != bufline[++start % bufsize])
+          bufline[j] = newLine++;
+        else
+          bufline[j] = newLine;
+      }
+    }
+
+    line = bufline[j];
+    column = bufcolumn[j];
+  }
+
+}
+/* JavaCC - OriginalChecksum=740c413ce2f513b4d926ea988f37e3da (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
new file mode 100644
index 0000000..a7ed978
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
@@ -0,0 +1,131 @@
+/* Generated By:JavaCC: Do not edit this line. Token.java Version 5.0 */
+/* JavaCCOptions:TOKEN_EXTENDS=,KEEP_LINE_COL=null,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
+package org.apache.camel.component.sql.sspt.parser;
+
+/**
+ * Describes the input token stream.
+ */
+
+public class Token implements java.io.Serializable {
+
+  /**
+   * The version identifier for this Serializable class.
+   * Increment only if the <i>serialized</i> form of the
+   * class changes.
+   */
+  private static final long serialVersionUID = 1L;
+
+  /**
+   * An integer that describes the kind of this token.  This numbering
+   * system is determined by JavaCCParser, and a table of these numbers is
+   * stored in the file ...Constants.java.
+   */
+  public int kind;
+
+  /** The line number of the first character of this Token. */
+  public int beginLine;
+  /** The column number of the first character of this Token. */
+  public int beginColumn;
+  /** The line number of the last character of this Token. */
+  public int endLine;
+  /** The column number of the last character of this Token. */
+  public int endColumn;
+
+  /**
+   * The string image of the token.
+   */
+  public String image;
+
+  /**
+   * A reference to the next regular (non-special) token from the input
+   * stream.  If this is the last token from the input stream, or if the
+   * token manager has not read tokens beyond this one, this field is
+   * set to null.  This is true only if this token is also a regular
+   * token.  Otherwise, see below for a description of the contents of
+   * this field.
+   */
+  public Token next;
+
+  /**
+   * This field is used to access special tokens that occur prior to this
+   * token, but after the immediately preceding regular (non-special) token.
+   * If there are no such special tokens, this field is set to null.
+   * When there are more than one such special token, this field refers
+   * to the last of these special tokens, which in turn refers to the next
+   * previous special token through its specialToken field, and so on
+   * until the first special token (whose specialToken field is null).
+   * The next fields of special tokens refer to other special tokens that
+   * immediately follow it (without an intervening regular token).  If there
+   * is no such token, this field is null.
+   */
+  public Token specialToken;
+
+  /**
+   * An optional attribute value of the Token.
+   * Tokens which are not used as syntactic sugar will often contain
+   * meaningful values that will be used later on by the compiler or
+   * interpreter. This attribute value is often different from the image.
+   * Any subclass of Token that actually wants to return a non-null value can
+   * override this method as appropriate.
+   */
+  public Object getValue() {
+    return null;
+  }
+
+  /**
+   * No-argument constructor
+   */
+  public Token() {}
+
+  /**
+   * Constructs a new token for the specified Image.
+   */
+  public Token(int kind)
+  {
+    this(kind, null);
+  }
+
+  /**
+   * Constructs a new token for the specified Image and Kind.
+   */
+  public Token(int kind, String image)
+  {
+    this.kind = kind;
+    this.image = image;
+  }
+
+  /**
+   * Returns the image.
+   */
+  public String toString()
+  {
+    return image;
+  }
+
+  /**
+   * Returns a new Token object, by default. However, if you want, you
+   * can create and return subclass objects based on the value of ofKind.
+   * Simply add the cases to the switch for all those special cases.
+   * For example, if you have a subclass of Token called IDToken that
+   * you want to create if ofKind is ID, simply add something like :
+   *
+   *    case MyParserConstants.ID : return new IDToken(ofKind, image);
+   *
+   * to the following switch statement. Then you can cast matchedToken
+   * variable to the appropriate type and use sit in your lexical actions.
+   */
+  public static Token newToken(int ofKind, String image)
+  {
+    switch(ofKind)
+    {
+      default : return new Token(ofKind, image);
+    }
+  }
+
+  public static Token newToken(int ofKind)
+  {
+    return newToken(ofKind, null);
+  }
+
+}
+/* JavaCC - OriginalChecksum=49813021262cb0b6d876cbaf57667539 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
new file mode 100644
index 0000000..b58d63b
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
@@ -0,0 +1,147 @@
+/* Generated By:JavaCC: Do not edit this line. TokenMgrError.java Version 5.0 */
+/* JavaCCOptions: */
+package org.apache.camel.component.sql.sspt.parser;
+
+/** Token Manager Error. */
+public class TokenMgrError extends Error
+{
+
+  /**
+   * The version identifier for this Serializable class.
+   * Increment only if the <i>serialized</i> form of the
+   * class changes.
+   */
+  private static final long serialVersionUID = 1L;
+
+  /*
+   * Ordinals for various reasons why an Error of this type can be thrown.
+   */
+
+  /**
+   * Lexical error occurred.
+   */
+  static final int LEXICAL_ERROR = 0;
+
+  /**
+   * An attempt was made to create a second instance of a static token manager.
+   */
+  static final int STATIC_LEXER_ERROR = 1;
+
+  /**
+   * Tried to change to an invalid lexical state.
+   */
+  static final int INVALID_LEXICAL_STATE = 2;
+
+  /**
+   * Detected (and bailed out of) an infinite loop in the token manager.
+   */
+  static final int LOOP_DETECTED = 3;
+
+  /**
+   * Indicates the reason why the exception is thrown. It will have
+   * one of the above 4 values.
+   */
+  int errorCode;
+
+  /**
+   * Replaces unprintable characters by their escaped (or unicode escaped)
+   * equivalents in the given string
+   */
+  protected static final String addEscapes(String str) {
+    StringBuffer retval = new StringBuffer();
+    char ch;
+    for (int i = 0; i < str.length(); i++) {
+      switch (str.charAt(i))
+      {
+        case 0 :
+          continue;
+        case '\b':
+          retval.append("\\b");
+          continue;
+        case '\t':
+          retval.append("\\t");
+          continue;
+        case '\n':
+          retval.append("\\n");
+          continue;
+        case '\f':
+          retval.append("\\f");
+          continue;
+        case '\r':
+          retval.append("\\r");
+          continue;
+        case '\"':
+          retval.append("\\\"");
+          continue;
+        case '\'':
+          retval.append("\\\'");
+          continue;
+        case '\\':
+          retval.append("\\\\");
+          continue;
+        default:
+          if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
+            String s = "0000" + Integer.toString(ch, 16);
+            retval.append("\\u" + s.substring(s.length() - 4, s.length()));
+          } else {
+            retval.append(ch);
+          }
+          continue;
+      }
+    }
+    return retval.toString();
+  }
+
+  /**
+   * Returns a detailed message for the Error when it is thrown by the
+   * token manager to indicate a lexical error.
+   * Parameters :
+   *    EOFSeen     : indicates if EOF caused the lexical error
+   *    curLexState : lexical state in which this error occurred
+   *    errorLine   : line number when the error occurred
+   *    errorColumn : column number when the error occurred
+   *    errorAfter  : prefix that was seen before this error occurred
+   *    curchar     : the offending character
+   * Note: You can customize the lexical error message by modifying this method.
+   */
+  protected static String LexicalError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar) {
+    return("Lexical error at line " +
+          errorLine + ", column " +
+          errorColumn + ".  Encountered: " +
+          (EOFSeen ? "<EOF> " : ("\"" + addEscapes(String.valueOf(curChar)) + "\"") + " (" + (int)curChar + "), ") +
+          "after : \"" + addEscapes(errorAfter) + "\"");
+  }
+
+  /**
+   * You can also modify the body of this method to customize your error messages.
+   * For example, cases like LOOP_DETECTED and INVALID_LEXICAL_STATE are not
+   * of end-users concern, so you can return something like :
+   *
+   *     "Internal Error : Please file a bug report .... "
+   *
+   * from this method for such cases in the release version of your parser.
+   */
+  public String getMessage() {
+    return super.getMessage();
+  }
+
+  /*
+   * Constructors of various flavors follow.
+   */
+
+  /** No arg constructor. */
+  public TokenMgrError() {
+  }
+
+  /** Constructor with message and reason. */
+  public TokenMgrError(String message, int reason) {
+    super(message);
+    errorCode = reason;
+  }
+
+  /** Full Constructor. */
+  public TokenMgrError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar, int reason) {
+    this(LexicalError(EOFSeen, lexState, errorLine, errorColumn, errorAfter, curChar), reason);
+  }
+}
+/* JavaCC - OriginalChecksum=40bf525b6801e308b2ddf5874ae68024 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
new file mode 100755
index 0000000..e80e9a5
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
@@ -0,0 +1,4 @@
+#!/usr/bin/env bash
+rm -f *.java
+javacc sspt.jj
+rm -f ParseException.java

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
new file mode 100644
index 0000000..db2f33c
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
@@ -0,0 +1,136 @@
+//Using some token definions from: http://kiwwito.com/build-a-lexical-analyzer-with-javacc/
+
+options {
+    STATIC = false;
+}
+
+
+PARSER_BEGIN(SSPTParser)
+
+package org.apache.camel.component.sql.sspt.parser;
+
+import org.apache.camel.component.sql.sspt.ast.*;
+
+public class SSPTParser {
+   int paramaterNameCounter = 0;
+
+   String createNextParameterName() {
+      return "_"+(paramaterNameCounter++);
+   }
+}
+
+PARSER_END(SSPTParser)
+
+public Template parse() :
+{   Token procudureName;
+    Template template = new Template();
+    Object parameter = null;
+}
+{
+  (procudureName = <IDENTIFIER> "(" (parameter = Parameter() { template.addParameter(parameter);}) (","
+  parameter
+  = Parameter(){template.addParameter(parameter);})*  ")" <EOF>)
+  {
+   template.setProcedureName(procudureName.toString());
+   return template;
+  }
+}
+
+Object Parameter() :
+{
+    Object param;
+}
+{
+     (param = InputParameter() {return param;}) | (param = OutParameter(){return param;})
+}
+
+InputParameter InputParameter() :
+{
+     String sqlTypeAsStr;
+     String name;
+     String valueSrcAsStr;
+}
+{
+    (sqlTypeAsStr = ParameterSqlType() " " valueSrcAsStr =
+    InputParameterSrc())
+    {
+        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
+        return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));
+    }
+}
+
+OutParameter OutParameter() :
+{
+     String sqlType;
+     String name;
+     String outHeader;
+}
+{
+    ("OUT" " " sqlType = ParameterSqlType() " " outHeader =
+    OutHeader())
+    {
+        return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);
+    }
+}
+
+String ParameterSqlType():
+{
+    Token t;
+}
+{
+    (t = <IDENTIFIER>)
+    {
+        return t.toString();
+    }
+}
+
+String OutHeader():
+{
+ Token token;
+}
+{
+    (token = <IDENTIFIER>)
+    {
+        return token.toString();
+    }
+}
+
+String InputParameterSrc():
+{
+    String ret;
+}
+{
+    (ret = SimpleExpression())
+    {
+        return ret;
+    }
+}
+
+String SimpleExpression() :
+{
+ Token t = null;
+}
+{
+    (t = <SIMPLE_EXP_TOKEN>)
+    {
+    return t.toString();
+    }
+}
+
+TOKEN: {
+    <#DIGIT: (["0"-"9"])>
+}
+
+TOKEN: {
+    <#LETTER: (["a"-"z","A"-"Z"])>
+}
+
+TOKEN : {
+    <SIMPLE_EXP_TOKEN: "${"(<LETTER>|<DIGIT> | " " | "'" | "." )* "}">
+}
+
+
+TOKEN : {
+    <IDENTIFIER: <LETTER>( <LETTER> | <DIGIT> | ".") *>
+}
+

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
new file mode 100644
index 0000000..ba36baf
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
@@ -0,0 +1,81 @@
+package org.apache.camel.component.sql.sspt;
+
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.sspt.ast.InputParameter;
+import org.apache.camel.component.sql.sspt.ast.OutParameter;
+import org.apache.camel.component.sql.sspt.ast.ParseException;
+import org.apache.camel.component.sql.sspt.ast.Template;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.Assert;
+import org.junit.Test;
+
+import java.math.BigInteger;
+import java.sql.Types;
+
+public class ParserTest extends CamelTestSupport {
+
+    SimpleStoredProcedureFactory parser = new SimpleStoredProcedureFactory();
+
+
+    @Test
+    public void shouldParseOk() {
+
+
+        Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1}," +
+                "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
+
+        Assert.assertEquals("addnumbers", template.getProcedureName());
+        Assert.assertEquals(3, template.getInputParameterList().size());
+
+        Exchange exchange = createExchangeWithBody(null);
+        exchange.getIn().setHeader("header1", 1);
+        exchange.setProperty("property1", "constant string");
+        exchange.getIn().setHeader("header2", BigInteger.valueOf(2));
+
+        InputParameter param1 = template.getInputParameterList().get(0);
+        Assert.assertEquals("_0", param1.getName());
+        Assert.assertEquals(Types.INTEGER, param1.getSqlType());
+        Assert.assertEquals(Integer.valueOf(1), param1.getValueExpression().evaluate(exchange, Integer.class));
+
+        InputParameter param2 = template.getInputParameterList().get(1);
+        Assert.assertEquals("_1", param2.getName());
+        Assert.assertEquals(Types.VARCHAR, param2.getSqlType());
+        Assert.assertEquals("constant string", param2.getValueExpression().evaluate(exchange, String.class));
+
+        InputParameter param3 = template.getInputParameterList().get(2);
+        Assert.assertEquals("_2", param3.getName());
+        Assert.assertEquals(Types.BIGINT, param3.getSqlType());
+        Assert.assertEquals(BigInteger.valueOf(2), param3.getValueExpression().evaluate(exchange, BigInteger.class));
+
+        OutParameter sptpOutputNode = template.getOutParameterList().get(0);
+        Assert.assertEquals("_3", sptpOutputNode.getName());
+        Assert.assertEquals(Types.INTEGER, sptpOutputNode.getSqlType());
+        Assert.assertEquals("header1", sptpOutputNode.getOutHeader());
+
+    }
+
+
+    @Test(expected = ParseException.class)
+    public void noOutputParameterShouldFail() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(INTEGER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+
+    }
+
+    @Test(expected = ParseException.class)
+    public void unexistingTypeShouldFail() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
+
+    }
+
+
+    @Test(expected = ParseException.class)
+    public void unmappedTypeShouldFaild() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
new file mode 100644
index 0000000..d00108c
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
@@ -0,0 +1,72 @@
+package org.apache.camel.component.sql.sspt;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.component.sql.SqlComponent;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
+
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Created by snurmine on 12/30/15.
+ */
+public class ProducerTest extends CamelTestSupport {
+
+
+    private EmbeddedDatabase db;
+
+    @Before
+    public void setUp() throws Exception {
+        db = new EmbeddedDatabaseBuilder()
+                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
+
+        super.setUp();
+    }
+
+    @After
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        db.shutdown();
+    }
+
+    @Test
+    public void shouldExecuteStoredProcedure() throws InterruptedException {
+        MockEndpoint mock = getMockEndpoint("mock:query");
+        mock.expectedMessageCount(1);
+
+
+        Map<String, Object> headers = new HashMap<>();
+        headers.put("num1", 1);
+        headers.put("num2", 2);
+        template.requestBodyAndHeaders("direct:query", null, headers);
+
+        assertMockEndpointsSatisfied();
+
+        Exchange exchange = mock.getExchanges().get(0);
+
+        assertEquals(Integer.valueOf(3), exchange.getIn().getHeader("resultofsum"));
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                // required for the sql component
+                getContext().getComponent("sql", SqlComponent.class).setDataSource(db);
+
+                from("direct:query").to("sql:sspt:ADDNUMBERS(INTEGER ${headers.num1},INTEGER ${headers"
+                        + ".num2},OUT INTEGER resultofsum)").to("mock:query");
+            }
+        };
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
new file mode 100644
index 0000000..5fc4fef
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
@@ -0,0 +1,57 @@
+package org.apache.camel.component.sql.sspt;
+
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.sspt.ast.ParseException;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.After;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+import org.springframework.jdbc.core.JdbcTemplate;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
+
+public class SimpleStoredProcedureTest extends CamelTestSupport {
+
+    SimpleStoredProcedureFactory parser = new SimpleStoredProcedureFactory();
+
+    private EmbeddedDatabase db;
+    private JdbcTemplate jdbcTemplate;
+
+    @Before
+    public void setUp() throws Exception {
+        db = new EmbeddedDatabaseBuilder()
+                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
+
+        jdbcTemplate = new JdbcTemplate(db);
+
+        super.setUp();
+    }
+
+
+    @Test
+    public void shouldExecuteStoredProcedure() throws ParseException {
+        SimpleStoredProcedure sp = new SimpleStoredProcedure(db, parser.parseTemplate("ADDNUMBERS" +
+                "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
+
+        Exchange exchange = createExchangeWithBody(null);
+        exchange.getIn().setHeader("v1", 1);
+        exchange.getIn().setHeader("v2", 2);
+
+
+        sp.execute(exchange);
+
+        Assert.assertEquals(Integer.valueOf(3), exchange.getOut().getHeader("resultofsum"));
+
+
+    }
+
+    @After
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        db.shutdown();
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
new file mode 100644
index 0000000..f88ebd4
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
@@ -0,0 +1,15 @@
+package org.apache.camel.component.sql.sspt;
+
+/**
+ * Created by snurmine on 12/20/15.
+ */
+public class SimpleStoredProcedureUdf {
+
+    public static void addnumbers(int VALUE1, int VALUE2, int[] RESULT) {
+        System.out.println("calling addnumbers:" + VALUE1 + "," + VALUE2);
+
+        RESULT[0] = VALUE1 + VALUE2;
+
+
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/6dac645b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
new file mode 100644
index 0000000..edee883
--- /dev/null
+++ b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
@@ -0,0 +1,22 @@
+-- ------------------------------------------------------------------------
+-- 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.
+-- ------------------------------------------------------------------------
+
+CREATE PROCEDURE ADDNUMBERS(VALUE1 INTEGER, VALUE2 INTEGER,OUT RESULT INTEGER)
+ PARAMETER STYLE JAVA
+ LANGUAGE JAVA
+ EXTERNAL NAME
+'org.apache.camel.component.sql.sspt.SimpleStoredProcedureUdf.addnumbers';
\ No newline at end of file


[5/9] camel git commit: Caching templates.

Posted by da...@apache.org.
Caching templates.


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/c8cbcde3
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/c8cbcde3
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/c8cbcde3

Branch: refs/heads/master
Commit: c8cbcde397dde05a9bba18fa79cd81e8aa984708
Parents: f0738bb
Author: Sami Nurminen <sn...@gmail.com>
Authored: Wed Jan 6 22:25:38 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 10:59:47 2016 +0100

----------------------------------------------------------------------
 .../sql/stored/SqlStoredComponent.java          |  6 ++--
 .../component/sql/stored/SqlStoredEndpoint.java | 13 ++++----
 .../component/sql/stored/SqlStoredProducer.java | 13 +++++---
 .../template/TemplateStoredProcedure.java       |  7 +++--
 .../TemplateStoredProcedureFactory.java         | 32 +++++++++++++++++---
 .../sql/stored/template/grammar/sspt.jj         |  2 ++
 .../camel/component/sql/stored/ParserTest.java  |  2 +-
 .../sql/stored/TemplateStoredProcedureTest.java |  9 ++++--
 8 files changed, 58 insertions(+), 26 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
index 9fdb45d..20aedf1 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -5,6 +5,7 @@ import org.apache.camel.Endpoint;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.UriEndpointComponent;
 import org.apache.camel.util.CamelContextHelper;
+import org.springframework.jdbc.core.JdbcTemplate;
 
 import javax.sql.DataSource;
 import java.util.Map;
@@ -20,9 +21,6 @@ public class SqlStoredComponent extends UriEndpointComponent {
         super(SqlStoredEndpoint.class);
     }
 
-
-    TemplateStoredProcedureFactory templateStoredProcedureFactory = new TemplateStoredProcedureFactory();
-
     public SqlStoredComponent(CamelContext context, Class<? extends Endpoint> endpointClass) {
         super(context, endpointClass);
     }
@@ -49,7 +47,7 @@ public class SqlStoredComponent extends UriEndpointComponent {
         }
 
 
-        return new SqlStoredEndpoint(templateStoredProcedureFactory, target, remaining);
+        return new SqlStoredEndpoint(new JdbcTemplate(target), remaining);
     }
 
     public DataSource getDataSource() {

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
index 844e9e5..ae7348c 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
@@ -7,8 +7,7 @@ import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriPath;
 import org.apache.camel.util.UnsafeUriCharactersEncoder;
-
-import javax.sql.DataSource;
+import org.springframework.jdbc.core.JdbcTemplate;
 
 @UriEndpoint(scheme = "sql-stored", title = "SQL stored", syntax = "sql-stored:template", label = "database,sql")
 public class SqlStoredEndpoint extends DefaultPollingEndpoint {
@@ -19,19 +18,19 @@ public class SqlStoredEndpoint extends DefaultPollingEndpoint {
 
     private final TemplateStoredProcedureFactory templateStoredProcedureFactory;
 
-    private final DataSource dataSource;
+    private final JdbcTemplate jdbcTemplate;
 
 
-    public SqlStoredEndpoint(TemplateStoredProcedureFactory templateStoredProcedureFactory, DataSource dataSource,
+    public SqlStoredEndpoint(JdbcTemplate jdbcTemplate,
                              String template) {
-        this.templateStoredProcedureFactory = templateStoredProcedureFactory;
-        this.dataSource = dataSource;
+        this.templateStoredProcedureFactory = new TemplateStoredProcedureFactory(jdbcTemplate);
+        this.jdbcTemplate = jdbcTemplate;
         this.template = template;
     }
 
     @Override
     public Producer createProducer() throws Exception {
-        return new SqlStoredProducer(this, templateStoredProcedureFactory.createFromString(template, dataSource));
+        return new SqlStoredProducer(this, template, templateStoredProcedureFactory);
     }
 
     @Override

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
index 9d2210d..f306a4c 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
@@ -3,6 +3,7 @@ package org.apache.camel.component.sql.stored;
 import org.apache.camel.Endpoint;
 import org.apache.camel.Exchange;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedure;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.DefaultProducer;
 
 /**
@@ -10,16 +11,20 @@ import org.apache.camel.impl.DefaultProducer;
  */
 public class SqlStoredProducer extends DefaultProducer {
 
-    final TemplateStoredProcedure templateStoredProcedure;
+    final TemplateStoredProcedureFactory templateStoredProcedureFactory;
 
-    public SqlStoredProducer(Endpoint endpoint, TemplateStoredProcedure templateStoredProcedure) {
+    final TemplateStoredProcedure defaultTemplateStoredProcedure;
+
+    public SqlStoredProducer(Endpoint endpoint, String template, TemplateStoredProcedureFactory
+            templateStoredProcedureFactory) {
         super(endpoint);
-        this.templateStoredProcedure = templateStoredProcedure;
+        this.defaultTemplateStoredProcedure = templateStoredProcedureFactory.createFromString(template);
+        this.templateStoredProcedureFactory = templateStoredProcedureFactory;
     }
 
     @Override
     public void process(Exchange exchange) throws Exception {
-        templateStoredProcedure.execute(exchange);
+        this.defaultTemplateStoredProcedure.execute(exchange);
     }
 
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
index 7c1f415..44103d8 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
@@ -4,6 +4,7 @@ import org.apache.camel.Exchange;
 import org.apache.camel.component.sql.stored.template.ast.InputParameter;
 import org.apache.camel.component.sql.stored.template.ast.OutParameter;
 import org.apache.camel.component.sql.stored.template.ast.Template;
+import org.springframework.jdbc.core.JdbcTemplate;
 import org.springframework.jdbc.core.SqlOutParameter;
 import org.springframework.jdbc.core.SqlParameter;
 import org.springframework.jdbc.object.StoredProcedure;
@@ -17,9 +18,9 @@ public class TemplateStoredProcedure extends StoredProcedure {
 
     Template template;
 
-    public TemplateStoredProcedure(DataSource dataSource, Template template) {
+    public TemplateStoredProcedure(JdbcTemplate jdbcTemplate, Template template) {
         this.template = template;
-        setDataSource(dataSource);
+        setDataSource(jdbcTemplate.getDataSource());
 
         setSql(template.getProcedureName());
 
@@ -33,9 +34,11 @@ public class TemplateStoredProcedure extends StoredProcedure {
         }
 
         compile();
+
     }
 
 
+
     public void execute(Exchange exchange) {
 
         Map<String, Object> params = new HashMap<>();

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
index 2229a4e..947a6a5 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -4,25 +4,47 @@ import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
 import org.apache.camel.component.sql.stored.template.ast.Template;
 import org.apache.camel.component.sql.stored.template.generated.ParseException;
 import org.apache.camel.component.sql.stored.template.generated.SSPTParser;
+import org.apache.camel.util.LRUCache;
+import org.springframework.jdbc.core.JdbcTemplate;
 
 import javax.sql.DataSource;
 import java.io.StringReader;
 
 public class TemplateStoredProcedureFactory {
 
+    final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
+
+    final JdbcTemplate jdbcTemplate;
+
+    LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(200);
+
+
+    public TemplateStoredProcedureFactory(JdbcTemplate jdbcTemplate) {
+        this.jdbcTemplate = jdbcTemplate;
+    }
+
+    public TemplateStoredProcedure createFromString(String string) {
+        TemplateStoredProcedure fromCache = templateCache.get(string);
+
+        if (fromCache != null) {
+            return fromCache;
+        }
 
-    public TemplateStoredProcedure createFromString(String string, DataSource dataSource)  {
         Template sptpRootNode = parseTemplate(string);
-        return new TemplateStoredProcedure(dataSource, sptpRootNode);
+        TemplateStoredProcedure ret = new TemplateStoredProcedure(jdbcTemplate, sptpRootNode);
+
+        templateCache.put(string, ret);
+
+        return ret;
 
     }
 
-    public Template parseTemplate(String template)  {
+    public Template parseTemplate(String template) {
         try {
-            SSPTParser parser = new SSPTParser(new StringReader(template));
 
+            SSPTParser parser = new SSPTParser(new StringReader(template));
             return validate(parser.parse());
-        }catch(ParseException parseException) {
+        } catch (ParseException parseException) {
             throw new ParseRuntimeException(parseException);
         }
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
index edd9f17..e43d17b 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
@@ -2,6 +2,8 @@
 
 options {
     STATIC = false;
+    FORCE_LA_CHECK = true;
+    SANITY_CHECK = true;
 }
 
 

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
index 81b6b5a..9982138 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
@@ -17,7 +17,7 @@ import java.sql.Types;
 
 public class ParserTest extends CamelTestSupport {
 
-    TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory();
+    TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory(null);
 
 
     @Test

http://git-wip-us.apache.org/repos/asf/camel/blob/c8cbcde3/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
index 73e9711..3b06390 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
@@ -16,7 +16,7 @@ import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
 
 public class TemplateStoredProcedureTest extends CamelTestSupport {
 
-    TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory();
+    TemplateStoredProcedureFactory parser;
 
     private EmbeddedDatabase db;
     private JdbcTemplate jdbcTemplate;
@@ -28,13 +28,16 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
 
         jdbcTemplate = new JdbcTemplate(db);
 
+
+        parser = new TemplateStoredProcedureFactory(jdbcTemplate);
+
         super.setUp();
     }
 
 
     @Test
     public void shouldExecuteStoredProcedure() {
-        TemplateStoredProcedure sp = new TemplateStoredProcedure(db, parser.parseTemplate("ADDNUMBERS" +
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("ADDNUMBERS" +
                 "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
 
         Exchange exchange = createExchangeWithBody(null);
@@ -52,7 +55,7 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
 
     @Test
     public void shouldExecuteNilacidProcedure() {
-        TemplateStoredProcedure sp = new TemplateStoredProcedure(db, parser.parseTemplate("NILADIC" +
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("NILADIC" +
                 "()"));
 
         Exchange exchange = createExchangeWithBody(null);


[7/9] camel git commit: CAMEL-4725: Polished

Posted by da...@apache.org.
CAMEL-4725: Polished


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/b240b3e4
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/b240b3e4
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/b240b3e4

Branch: refs/heads/master
Commit: b240b3e4a2eb64ad760cace92ea2ca326e58a15b
Parents: 0dcd69a
Author: Claus Ibsen <da...@apache.org>
Authored: Sat Jan 9 11:21:26 2016 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 11:21:26 2016 +0100

----------------------------------------------------------------------
 .../sql/stored/SqlStoredComponent.java          |  7 +--
 .../TemplateStoredProcedureFactory.java         |  4 +-
 .../sql/stored/template/ast/ParseHelper.java    | 58 ++++++++++----------
 .../template/ast/ParseRuntimeException.java     | 16 ++++++
 .../camel/component/sql/stored/ParserTest.java  | 16 +++---
 .../sql/stored/TemplateStoredProcedureTest.java |  4 +-
 .../sql/stored/TestStoredProcedure.java         |  5 +-
 7 files changed, 65 insertions(+), 45 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
index 4814be9..7012186 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -16,16 +16,15 @@
  */
 package org.apache.camel.component.sql.stored;
 
+import java.util.Map;
+import javax.sql.DataSource;
+
 import org.apache.camel.CamelContext;
 import org.apache.camel.Endpoint;
-import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.UriEndpointComponent;
 import org.apache.camel.util.CamelContextHelper;
 import org.springframework.jdbc.core.JdbcTemplate;
 
-import javax.sql.DataSource;
-import java.util.Map;
-
 public class SqlStoredComponent extends UriEndpointComponent {
 
     private DataSource dataSource;

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
index 78f034e..5d5a329 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -27,9 +27,9 @@ import org.springframework.jdbc.core.JdbcTemplate;
 
 public class TemplateStoredProcedureFactory {
 
-    private final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
+    public static final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
     private final JdbcTemplate jdbcTemplate;
-    private LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(200);
+    private LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(TEMPLATE_CACHE_DEFAULT_SIZE);
 
     public TemplateStoredProcedureFactory(JdbcTemplate jdbcTemplate) {
         this.jdbcTemplate = jdbcTemplate;

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
index 8e88691..19417de 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
@@ -5,9 +5,9 @@
  * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
+ *
+ *      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.
@@ -23,7 +23,10 @@ import java.sql.Types;
 
 import org.springframework.util.ReflectionUtils;
 
-public class ParseHelper {
+public final class ParseHelper {
+
+    private ParseHelper() {
+    }
 
     public static int parseSqlType(String sqlType) {
         Field field = ReflectionUtils.findField(Types.class, sqlType);
@@ -42,32 +45,31 @@ public class ParseHelper {
         //TODO: add test for each type.
         Class ret = null;
         switch (sqlType) {
-            case Types.INTEGER:
-                ret = Integer.class;
-                break;
-            case Types.VARCHAR:
-                ret = String.class;
-                break;
-            case Types.BIGINT:
-                ret = BigInteger.class;
-                break;
-            case Types.CHAR:
-                ret = String.class;
-                break;
-            case Types.BOOLEAN:
-                ret = Boolean.class;
-                break;
-            case Types.DATE:
-                ret = Date.class;
-                break;
-            case Types.TIMESTAMP:
-                ret = Date.class;
-                break;
-        }
-
-        if (ret == null) {
+        case Types.INTEGER:
+            ret = Integer.class;
+            break;
+        case Types.VARCHAR:
+            ret = String.class;
+            break;
+        case Types.BIGINT:
+            ret = BigInteger.class;
+            break;
+        case Types.CHAR:
+            ret = String.class;
+            break;
+        case Types.BOOLEAN:
+            ret = Boolean.class;
+            break;
+        case Types.DATE:
+            ret = Date.class;
+            break;
+        case Types.TIMESTAMP:
+            ret = Date.class;
+            break;
+        default:
             throw new ParseRuntimeException("Unable to map SQL type " + sqlTypeStr + " to Java type");
         }
+
         return ret;
     }
 

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
index 80fe52c..2092afa 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
@@ -1,3 +1,19 @@
+/**
+ * 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.sql.stored.template.ast;
 
 public class ParseRuntimeException extends RuntimeException {

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
index 1141886..36ccc76 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
@@ -35,8 +35,8 @@ public class ParserTest extends CamelTestSupport {
 
     @Test
     public void shouldParseOk() {
-        Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1}," +
-                "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
+        Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1},"
+                + "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
 
         Assert.assertEquals("addnumbers", template.getProcedureName());
         Assert.assertEquals(3, template.getInputParameterList().size());
@@ -69,21 +69,21 @@ public class ParserTest extends CamelTestSupport {
 
     @Test(expected = ParseRuntimeException.class)
     public void noOutputParameterShouldFail() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(INTEGER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+        parser.parseTemplate("ADDNUMBERS2"
+                + "(INTEGER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
 
     }
 
     @Test(expected = ParseRuntimeException.class)
     public void unexistingTypeShouldFail() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
+        parser.parseTemplate("ADDNUMBERS2"
+                + "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
     }
 
     @Test(expected = ParseRuntimeException.class)
     public void unmappedTypeShouldFaild() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+        parser.parseTemplate("ADDNUMBERS2"
+                + "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
     }
 
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
index f92f7df..f538ce5 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
@@ -47,8 +47,8 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
 
     @Test
     public void shouldExecuteStoredProcedure() {
-        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("ADDNUMBERS" +
-                "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("ADDNUMBERS"
+                + "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
 
         Exchange exchange = createExchangeWithBody(null);
         exchange.getIn().setHeader("v1", 1);

http://git-wip-us.apache.org/repos/asf/camel/blob/b240b3e4/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
index cf05611..55e2624 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
@@ -19,10 +19,13 @@ package org.apache.camel.component.sql.stored;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TestStoredProcedure {
+public final class TestStoredProcedure {
 
     private static final Logger LOG = LoggerFactory.getLogger(TestStoredProcedure.class);
 
+    private TestStoredProcedure() {
+    }
+
     public static void addnumbers(int val1, int val2, int[] ret) {
         LOG.info("calling addnumbers:{} + {}", val1, val2);
         ret[0] = val1 + val2;


[3/9] camel git commit: Saving work. Simple Producer.

Posted by da...@apache.org.
Saving work. Simple Producer.


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/3ee2bb46
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/3ee2bb46
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/3ee2bb46

Branch: refs/heads/master
Commit: 3ee2bb467cafd810fb5bf78869a9ab117ac83114
Parents: 6dac645
Author: Sami Nurminen <sn...@gmail.com>
Authored: Sun Jan 3 14:13:52 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 10:59:46 2016 +0100

----------------------------------------------------------------------
 components/camel-sql/pom.xml                    |  21 +
 .../apache/camel/component/sql/SqlEndpoint.java |   4 +-
 .../apache/camel/component/sql/SqlProducer.java |  17 +-
 .../component/sql/sspt/ProducerSSPTHelper.java  |  36 --
 .../sql/sspt/SimpleStoredProcedure.java         |  56 ---
 .../sql/sspt/SimpleStoredProcedureFactory.java  |  33 --
 .../component/sql/sspt/ast/InputParameter.java  |  47 --
 .../component/sql/sspt/ast/OutParameter.java    |  33 --
 .../component/sql/sspt/ast/ParseException.java  | 189 --------
 .../component/sql/sspt/ast/ParseHelper.java     |  58 ---
 .../camel/component/sql/sspt/ast/Template.java  |  43 --
 .../component/sql/sspt/parser/SSPTParser.java   | 282 -----------
 .../sql/sspt/parser/SSPTParserConstants.java    |  39 --
 .../sql/sspt/parser/SSPTParserTokenManager.java | 366 --------------
 .../sql/sspt/parser/SimpleCharStream.java       | 471 -------------------
 .../camel/component/sql/sspt/parser/Token.java  | 131 ------
 .../sql/sspt/parser/TokenMgrError.java          | 147 ------
 .../sql/sspt/parser/generate_sptp_classes.sh    |   4 -
 .../camel/component/sql/sspt/parser/sspt.jj     | 136 ------
 .../sql/stored/SqlStoredComponent.java          |  44 ++
 .../component/sql/stored/SqlStoredEndpoint.java |  45 ++
 .../component/sql/stored/SqlStoredProducer.java |  25 +
 .../template/TemplateStoredProcedure.java       |  56 +++
 .../TemplateStoredProcedureFactory.java         |  38 ++
 .../sql/stored/template/ast/InputParameter.java |  47 ++
 .../sql/stored/template/ast/OutParameter.java   |  33 ++
 .../sql/stored/template/ast/ParseHelper.java    |  58 +++
 .../template/ast/ParseRuntimeException.java     |  14 +
 .../sql/stored/template/ast/Template.java       |  43 ++
 .../sql/stored/template/grammar/sspt.jj         | 136 ++++++
 .../org/apache/camel/component/sql-stored       |   1 +
 .../camel/component/sql/sspt/ParserTest.java    |  81 ----
 .../camel/component/sql/sspt/ProducerTest.java  |  72 ---
 .../sql/sspt/SimpleStoredProcedureTest.java     |  57 ---
 .../sql/sspt/SimpleStoredProcedureUdf.java      |  15 -
 .../camel/component/sql/stored/ParserTest.java  |  83 ++++
 .../component/sql/stored/ProducerTest.java      |  72 +++
 .../sql/stored/SimpleStoredProcedureUdf.java    |  15 +
 .../sql/stored/TemplateStoredProcedureTest.java |  58 +++
 .../test/resources/sql/storedProcedureTest.sql  |   2 +-
 40 files changed, 792 insertions(+), 2316 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/pom.xml
----------------------------------------------------------------------
diff --git a/components/camel-sql/pom.xml b/components/camel-sql/pom.xml
index aed0886..99f04a0 100644
--- a/components/camel-sql/pom.xml
+++ b/components/camel-sql/pom.xml
@@ -98,6 +98,27 @@
 	  <reuseForks>false</reuseForks>
         </configuration>
       </plugin>
+
+      <plugin>
+        <groupId>org.codehaus.mojo</groupId>
+        <artifactId>javacc-maven-plugin</artifactId>
+        <executions>
+          <execution>
+            <phase>generate-sources</phase>
+            <configuration>
+              <sourceDirectory>${basedir}/src/main/java/org/apache/camel/component/sql/stored/template/grammar</sourceDirectory>
+              <outputDirectory>${basedir}/src/main/java</outputDirectory>
+            </configuration>
+            <goals>
+              <goal>javacc</goal>
+            </goals>
+          </execution>
+        </executions>
+        <version>2.6</version>
+      </plugin>
+
+
+
     </plugins>
   </build>
 </project>

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
index 247952d..c521339 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlEndpoint.java
@@ -20,7 +20,6 @@ import org.apache.camel.Component;
 import org.apache.camel.Consumer;
 import org.apache.camel.Processor;
 import org.apache.camel.Producer;
-import org.apache.camel.component.sql.sspt.ProducerSSPTHelper;
 import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriPath;
@@ -62,9 +61,8 @@ public class SqlEndpoint extends DefaultSqlEndpoint {
 
     public Producer createProducer() throws Exception {
         SqlPrepareStatementStrategy prepareStrategy = getPrepareStatementStrategy() != null ? getPrepareStatementStrategy() : new DefaultSqlPrepareStatementStrategy(getSeparator());
-        ProducerSSPTHelper producerSSPTHelper = new ProducerSSPTHelper(getJdbcTemplate().getDataSource());
         SqlProducer result = new SqlProducer(this, query, getJdbcTemplate(), prepareStrategy, isBatch(),
-                isAlwaysPopulateStatement(), isUseMessageBodyForSql(),producerSSPTHelper);
+                isAlwaysPopulateStatement(), isUseMessageBodyForSql());
         result.setParametersCount(getParametersCount());
         return result;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
index a8a85ac..483bd72 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/SqlProducer.java
@@ -27,8 +27,6 @@ import java.util.List;
 import java.util.Map;
 
 import org.apache.camel.Exchange;
-
-import org.apache.camel.component.sql.sspt.ProducerSSPTHelper;
 import org.apache.camel.impl.DefaultProducer;
 import org.springframework.jdbc.core.JdbcTemplate;
 import org.springframework.jdbc.core.PreparedStatementCallback;
@@ -44,11 +42,9 @@ public class SqlProducer extends DefaultProducer {
     private final SqlPrepareStatementStrategy sqlPrepareStatementStrategy;
     private final boolean useMessageBodyForSql;
     private int parametersCount;
-    private final ProducerSSPTHelper producerSSPTHelper;
 
     public SqlProducer(SqlEndpoint endpoint, String query, JdbcTemplate jdbcTemplate, SqlPrepareStatementStrategy sqlPrepareStatementStrategy,
-                       boolean batch, boolean alwaysPopulateStatement, boolean useMessageBodyForSql,
-                       ProducerSSPTHelper producerSSPTHelper) {
+                       boolean batch, boolean alwaysPopulateStatement, boolean useMessageBodyForSql) {
         super(endpoint);
         this.jdbcTemplate = jdbcTemplate;
         this.sqlPrepareStatementStrategy = sqlPrepareStatementStrategy;
@@ -56,7 +52,6 @@ public class SqlProducer extends DefaultProducer {
         this.batch = batch;
         this.alwaysPopulateStatement = alwaysPopulateStatement;
         this.useMessageBodyForSql = useMessageBodyForSql;
-        this.producerSSPTHelper = producerSSPTHelper;
     }
 
     @Override
@@ -66,20 +61,12 @@ public class SqlProducer extends DefaultProducer {
 
     public void process(final Exchange exchange) throws Exception {
         final String sql;
-
         if (useMessageBodyForSql) {
             sql = exchange.getIn().getBody(String.class);
         } else {
             String queryHeader = exchange.getIn().getHeader(SqlConstants.SQL_QUERY, String.class);
             sql = queryHeader != null ? queryHeader : query;
         }
-
-        if(producerSSPTHelper.isSSPTQuery(sql)) {
-            producerSSPTHelper.handleSstpQuery(sql,exchange);
-            return;
-        }
-
-
         final String preparedQuery = sqlPrepareStatementStrategy.prepareQuery(sql, getEndpoint().isAllowNamedParameters());
 
         // CAMEL-7313 - check whether to return generated keys
@@ -221,8 +208,6 @@ public class SqlProducer extends DefaultProducer {
         });
     }
 
-
-
     public void setParametersCount(int parametersCount) {
         this.parametersCount = parametersCount;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
deleted file mode 100644
index 75e7a71..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ProducerSSPTHelper.java
+++ /dev/null
@@ -1,36 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.RuntimeCamelException;
-import org.apache.camel.component.sql.sspt.ast.ParseException;
-
-import javax.sql.DataSource;
-
-/**
- * Created by snurmine on 1/1/16.
- */
-public class ProducerSSPTHelper {
-
-    public static final String SSPT_QUERY_PREFIX = "sspt:";
-    final DataSource dataSource;
-    SimpleStoredProcedureFactory simpleStoredProcedureFactory = new SimpleStoredProcedureFactory();
-
-    public ProducerSSPTHelper(DataSource dataSource) {
-        this.dataSource = dataSource;
-    }
-
-    public void handleSstpQuery(String sql, Exchange exchange) {
-        try {
-            String sstp = sql.substring(SSPT_QUERY_PREFIX.length());
-            //TODO: cache parsed SimpleStoredProcedure to LRU-cache.
-            SimpleStoredProcedure storedProcedure = simpleStoredProcedureFactory.createFromString(sstp, dataSource);
-            storedProcedure.execute(exchange);
-        } catch (ParseException parseException) {
-            throw new RuntimeCamelException(parseException);
-        }
-    }
-
-    public boolean isSSPTQuery(String sql) {
-        return sql.startsWith(SSPT_QUERY_PREFIX);
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
deleted file mode 100644
index 55da509..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedure.java
+++ /dev/null
@@ -1,56 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.component.sql.sspt.ast.InputParameter;
-import org.apache.camel.component.sql.sspt.ast.OutParameter;
-import org.apache.camel.component.sql.sspt.ast.Template;
-import org.springframework.jdbc.core.SqlOutParameter;
-import org.springframework.jdbc.core.SqlParameter;
-import org.springframework.jdbc.object.StoredProcedure;
-
-import javax.sql.DataSource;
-import java.util.HashMap;
-import java.util.Map;
-
-
-public class SimpleStoredProcedure extends StoredProcedure {
-
-    Template template;
-
-    public SimpleStoredProcedure(DataSource dataSource, Template template) {
-        this.template = template;
-        setDataSource(dataSource);
-
-        setSql(template.getProcedureName());
-
-        for (InputParameter inputParameter : template.getInputParameterList()) {
-            declareParameter(new SqlParameter(inputParameter.getName(), inputParameter.getSqlType()));
-        }
-
-        for (OutParameter outParameter : template.getOutParameterList()) {
-            declareParameter(new SqlOutParameter(outParameter.getName(), outParameter.getSqlType()));
-            setFunction(false);
-        }
-
-        compile();
-    }
-
-
-    public void execute(Exchange exchange) {
-
-        Map<String, Object> params = new HashMap<>();
-
-        for (InputParameter inputParameter : template.getInputParameterList()) {
-            params.put(inputParameter.getName(), inputParameter.getValueExpression().evaluate(exchange, inputParameter.getJavaType()));
-        }
-
-        Map<String, Object> ret = super.execute(params);
-
-        for (OutParameter out : template.getOutParameterList()) {
-            exchange.getOut().setHeader(out.getOutHeader(), ret.get(out.getName()));
-        }
-
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
deleted file mode 100644
index 43765b2..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureFactory.java
+++ /dev/null
@@ -1,33 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-import org.apache.camel.component.sql.sspt.ast.ParseException;
-import org.apache.camel.component.sql.sspt.ast.Template;
-import org.apache.camel.component.sql.sspt.parser.SSPTParser;
-
-import javax.sql.DataSource;
-import java.io.StringReader;
-
-public class SimpleStoredProcedureFactory {
-
-
-    public SimpleStoredProcedure createFromString(String string, DataSource dataSource) throws ParseException {
-        Template sptpRootNode = parseTemplate(string);
-        return new SimpleStoredProcedure(dataSource, sptpRootNode);
-
-    }
-
-    public Template parseTemplate(String template) throws ParseException {
-        SSPTParser parser = new SSPTParser(new StringReader(template));
-
-        return validate(parser.parse());
-    }
-
-    private Template validate(Template input) throws ParseException {
-        if (input.getOutParameterList().isEmpty()) {
-            throw new ParseException("At least one OUT parameter must be given.");
-        }
-        return input;
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
deleted file mode 100644
index 2dfd62b..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/InputParameter.java
+++ /dev/null
@@ -1,47 +0,0 @@
-package org.apache.camel.component.sql.sspt.ast;
-
-import org.apache.camel.Expression;
-import org.apache.camel.builder.ExpressionBuilder;
-
-
-public class InputParameter {
-
-    String name;
-
-    int sqlType;
-
-    Expression valueExpression;
-
-    Class javaType;
-
-
-    public InputParameter(String name, int sqlType, String valueSrcAsStr, Class javaType) {
-        this.name = name;
-        this.sqlType = sqlType;
-        this.javaType = javaType;
-        this.valueExpression = parseValueExpression(valueSrcAsStr);
-    }
-
-
-    private Expression parseValueExpression(String str) {
-        return ExpressionBuilder.simpleExpression(str);
-    }
-
-    public String getName() {
-        return name;
-    }
-
-    public int getSqlType() {
-        return sqlType;
-    }
-
-    public Expression getValueExpression() {
-        return valueExpression;
-    }
-
-    public Class getJavaType() {
-        return javaType;
-    }
-
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
deleted file mode 100644
index b7914e4..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/OutParameter.java
+++ /dev/null
@@ -1,33 +0,0 @@
-package org.apache.camel.component.sql.sspt.ast;
-
-/**
- * Created by snurmine on 12/20/15.
- */
-public class OutParameter {
-
-
-    String name;
-
-    int sqlType;
-
-    String outHeader;
-
-
-    public OutParameter(String name, int sqlType, String outHeader) {
-        this.name = name;
-        this.sqlType = sqlType;
-        this.outHeader = outHeader;
-    }
-
-    public String getName() {
-        return name;
-    }
-
-    public int getSqlType() {
-        return sqlType;
-    }
-
-    public String getOutHeader() {
-        return outHeader;
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
deleted file mode 100644
index f6b5878..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseException.java
+++ /dev/null
@@ -1,189 +0,0 @@
-/* Generated By:JavaCC: Do not edit this line. ParseException.java Version 5.0 */
-/* JavaCCOptions:KEEP_LINE_COL=null */
-package org.apache.camel.component.sql.sspt.ast;
-
-import org.apache.camel.component.sql.sspt.parser.Token;
-
-/**
- * This exception is thrown when parse errors are encountered.
- * You can explicitly create objects of this exception type by
- * calling the method generateParseException in the generated
- * parser.
- * <p>
- * You can modify this class to customize your error reporting
- * mechanisms so long as you retain the public fields.
- */
-public class ParseException extends RuntimeException {
-
-    /**
-     * The version identifier for this Serializable class.
-     * Increment only if the <i>serialized</i> form of the
-     * class changes.
-     */
-    private static final long serialVersionUID = 1L;
-    /**
-     * This is the last token that has been consumed successfully.  If
-     * this object has been created due to a parse error, the token
-     * followng this token will (therefore) be the first error token.
-     */
-    public Token currentToken;
-    /**
-     * Each entry in this array is an array of integers.  Each array
-     * of integers represents a sequence of tokens (by their ordinal
-     * values) that is expected at this point of the parse.
-     */
-    public int[][] expectedTokenSequences;
-    /**
-     * This is a reference to the "tokenImage" array of the generated
-     * parser within which the parse error occurred.  This array is
-     * defined in the generated ...Constants interface.
-     */
-    public String[] tokenImage;
-    /**
-     * The end of line string for this machine.
-     */
-    protected String eol = System.getProperty("line.separator", "\n");
-
-
-    /**
-     * This constructor is used by the method "generateParseException"
-     * in the generated parser.  Calling this constructor generates
-     * a new object of this type with the fields "currentToken",
-     * "expectedTokenSequences", and "tokenImage" set.
-     */
-    public ParseException(Token currentTokenVal,
-                          int[][] expectedTokenSequencesVal,
-                          String[] tokenImageVal
-    ) {
-        super(initialise(currentTokenVal, expectedTokenSequencesVal, tokenImageVal));
-        currentToken = currentTokenVal;
-        expectedTokenSequences = expectedTokenSequencesVal;
-        tokenImage = tokenImageVal;
-    }
-
-    /**
-     * The following constructors are for use by you for whatever
-     * purpose you can think of.  Constructing the exception in this
-     * manner makes the exception behave in the normal way - i.e., as
-     * documented in the class "Throwable".  The fields "errorToken",
-     * "expectedTokenSequences", and "tokenImage" do not contain
-     * relevant information.  The JavaCC generated code does not use
-     * these constructors.
-     */
-
-    public ParseException() {
-        super();
-    }
-
-    /**
-     * Constructor with message.
-     */
-    public ParseException(String message) {
-        super(message);
-    }
-
-    public ParseException(Exception cause) {
-        super(cause);
-    }
-
-    /**
-     * It uses "currentToken" and "expectedTokenSequences" to generate a parse
-     * error message and returns it.  If this object has been created
-     * due to a parse error, and you do not catch it (it gets thrown
-     * from the parser) the correct error message
-     * gets displayed.
-     */
-    private static String initialise(Token currentToken,
-                                     int[][] expectedTokenSequences,
-                                     String[] tokenImage) {
-        String eol = System.getProperty("line.separator", "\n");
-        StringBuffer expected = new StringBuffer();
-        int maxSize = 0;
-        for (int i = 0; i < expectedTokenSequences.length; i++) {
-            if (maxSize < expectedTokenSequences[i].length) {
-                maxSize = expectedTokenSequences[i].length;
-            }
-            for (int j = 0; j < expectedTokenSequences[i].length; j++) {
-                expected.append(tokenImage[expectedTokenSequences[i][j]]).append(' ');
-            }
-            if (expectedTokenSequences[i][expectedTokenSequences[i].length - 1] != 0) {
-                expected.append("...");
-            }
-            expected.append(eol).append("    ");
-        }
-        String retval = "Encountered \"";
-        Token tok = currentToken.next;
-        for (int i = 0; i < maxSize; i++) {
-            if (i != 0) retval += " ";
-            if (tok.kind == 0) {
-                retval += tokenImage[0];
-                break;
-            }
-            retval += " " + tokenImage[tok.kind];
-            retval += " \"";
-            retval += add_escapes(tok.image);
-            retval += " \"";
-            tok = tok.next;
-        }
-        retval += "\" at line " + currentToken.next.beginLine + ", column " + currentToken.next.beginColumn;
-        retval += "." + eol;
-        if (expectedTokenSequences.length == 1) {
-            retval += "Was expecting:" + eol + "    ";
-        } else {
-            retval += "Was expecting one of:" + eol + "    ";
-        }
-        retval += expected.toString();
-        return retval;
-    }
-
-    /**
-     * Used to convert raw characters to their escaped version
-     * when these raw version cannot be used as part of an ASCII
-     * string literal.
-     */
-    static String add_escapes(String str) {
-        StringBuffer retval = new StringBuffer();
-        char ch;
-        for (int i = 0; i < str.length(); i++) {
-            switch (str.charAt(i)) {
-                case 0:
-                    continue;
-                case '\b':
-                    retval.append("\\b");
-                    continue;
-                case '\t':
-                    retval.append("\\t");
-                    continue;
-                case '\n':
-                    retval.append("\\n");
-                    continue;
-                case '\f':
-                    retval.append("\\f");
-                    continue;
-                case '\r':
-                    retval.append("\\r");
-                    continue;
-                case '\"':
-                    retval.append("\\\"");
-                    continue;
-                case '\'':
-                    retval.append("\\\'");
-                    continue;
-                case '\\':
-                    retval.append("\\\\");
-                    continue;
-                default:
-                    if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
-                        String s = "0000" + Integer.toString(ch, 16);
-                        retval.append("\\u" + s.substring(s.length() - 4, s.length()));
-                    } else {
-                        retval.append(ch);
-                    }
-                    continue;
-            }
-        }
-        return retval.toString();
-    }
-
-}
-/* JavaCC - OriginalChecksum=9df9fe5c4e531f41d82ff5964724c931 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
deleted file mode 100644
index 1b372db..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/ParseHelper.java
+++ /dev/null
@@ -1,58 +0,0 @@
-package org.apache.camel.component.sql.sspt.ast;
-
-import org.springframework.util.ReflectionUtils;
-
-import java.lang.reflect.Field;
-import java.math.BigInteger;
-import java.sql.Date;
-import java.sql.Types;
-
-
-public class ParseHelper {
-
-    public static int parseSqlType(String sqlType) {
-        Field field = ReflectionUtils.findField(Types.class, sqlType);
-        if (field == null) {
-            throw new ParseException("Field " + sqlType + " not found from java.procedureName.Types");
-        }
-        try {
-            return field.getInt(Types.class);
-        } catch (IllegalAccessException e) {
-            throw new ParseException(e);
-        }
-    }
-
-    public static Class sqlTypeToJavaType(int sqlType, String sqlTypeStr) {
-        //TODO: as rest of types.
-        //TODO: add test for each type.
-        Class ret = null;
-        switch (sqlType) {
-            case Types.INTEGER:
-                ret = Integer.class;
-                break;
-            case Types.VARCHAR:
-                ret = String.class;
-                break;
-            case Types.BIGINT:
-                ret = BigInteger.class;
-                break;
-            case Types.CHAR:
-                ret = String.class;
-                break;
-            case Types.BOOLEAN:
-                ret = Boolean.class;
-                break;
-            case Types.DATE:
-                ret = Date.class;
-                break;
-            case Types.TIMESTAMP:
-                ret = Date.class;
-                break;
-        }
-        if (ret == null) {
-            throw new ParseException("Unable to map SQL type " + sqlTypeStr + " to Java type");
-
-        }
-        return ret;
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
deleted file mode 100644
index adcb740..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/ast/Template.java
+++ /dev/null
@@ -1,43 +0,0 @@
-package org.apache.camel.component.sql.sspt.ast;
-
-import java.util.ArrayList;
-import java.util.List;
-
-/**
- * Root element of Simple Stored Procedure Template AST.
- */
-public class Template {
-
-    String procedureName;
-
-    List<InputParameter> inputParameterList = new ArrayList<>();
-
-    List<OutParameter> outParameterList = new ArrayList<>();
-
-    public void addParameter(Object parameter) {
-
-        if (parameter instanceof OutParameter) {
-            outParameterList.add((OutParameter) parameter);
-        } else {
-            inputParameterList.add((InputParameter) parameter);
-
-        }
-    }
-
-    public String getProcedureName() {
-        return procedureName;
-    }
-
-    public void setProcedureName(String procedureName) {
-        this.procedureName = procedureName;
-    }
-
-    public List<InputParameter> getInputParameterList() {
-        return inputParameterList;
-    }
-
-    public List<OutParameter> getOutParameterList() {
-        return outParameterList;
-    }
-}
-

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
deleted file mode 100644
index 66b0843..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParser.java
+++ /dev/null
@@ -1,282 +0,0 @@
-/* Generated By: http&JavaCC: Do not edit this line. SSPTParser.java */
-package org.apache.camel.component.sql.sspt.parser;
-
-import org.apache.camel.component.sql.sspt.ast.*;
-
-public class SSPTParser implements SSPTParserConstants {
-   int paramaterNameCounter = 0;
-
-   String createNextParameterName() {
-      return "_"+(paramaterNameCounter++);
-   }
-
-  final public Template parse() throws ParseException {
-    Token procudureName;
-    Template template = new Template();
-    Object parameter = null;
-    procudureName = jj_consume_token(IDENTIFIER);
-    jj_consume_token(1);
-    parameter = Parameter();
-                                                               template.addParameter(parameter);
-    label_1:
-    while (true) {
-      switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
-      case 2:
-        ;
-        break;
-      default:
-        jj_la1[0] = jj_gen;
-        break label_1;
-      }
-      jj_consume_token(2);
-      parameter = Parameter();
-                template.addParameter(parameter);
-    }
-    jj_consume_token(3);
-    jj_consume_token(0);
-   template.setProcedureName(procudureName.toString());
-   {if (true) return template;}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public Object Parameter() throws ParseException {
-    Object param;
-    switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
-    case IDENTIFIER:
-      param = InputParameter();
-                                {if (true) return param;}
-      break;
-    case 5:
-      param = OutParameter();
-                                                                          {if (true) return param;}
-      break;
-    default:
-      jj_la1[1] = jj_gen;
-      jj_consume_token(-1);
-      throw new ParseException();
-    }
-    throw new Error("Missing return statement in function");
-  }
-
-  final public InputParameter InputParameter() throws ParseException {
-     String sqlTypeAsStr;
-     String name;
-     String valueSrcAsStr;
-    sqlTypeAsStr = ParameterSqlType();
-    jj_consume_token(4);
-    valueSrcAsStr = InputParameterSrc();
-        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
-        {if (true) return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public OutParameter OutParameter() throws ParseException {
-     String sqlType;
-     String name;
-     String outHeader;
-    jj_consume_token(5);
-    jj_consume_token(4);
-    sqlType = ParameterSqlType();
-    jj_consume_token(4);
-    outHeader = OutHeader();
-        {if (true) return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public String ParameterSqlType() throws ParseException {
-    Token t;
-    t = jj_consume_token(IDENTIFIER);
-        {if (true) return t.toString();}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public String OutHeader() throws ParseException {
- Token token;
-    token = jj_consume_token(IDENTIFIER);
-        {if (true) return token.toString();}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public String InputParameterSrc() throws ParseException {
-    String ret;
-    ret = SimpleExpression();
-        {if (true) return ret;}
-    throw new Error("Missing return statement in function");
-  }
-
-  final public String SimpleExpression() throws ParseException {
- Token t = null;
-    t = jj_consume_token(SIMPLE_EXP_TOKEN);
-    {if (true) return t.toString();}
-    throw new Error("Missing return statement in function");
-  }
-
-  /** Generated Token Manager. */
-  public SSPTParserTokenManager token_source;
-  SimpleCharStream jj_input_stream;
-  /** Current token. */
-  public Token token;
-  /** Next token. */
-  public Token jj_nt;
-  private int jj_ntk;
-  private int jj_gen;
-  final private int[] jj_la1 = new int[2];
-  static private int[] jj_la1_0;
-  static {
-      jj_la1_init_0();
-   }
-   private static void jj_la1_init_0() {
-      jj_la1_0 = new int[] {0x4,0x220,};
-   }
-
-  /** Constructor with InputStream. */
-  public SSPTParser(java.io.InputStream stream) {
-     this(stream, null);
-  }
-  /** Constructor with InputStream and supplied encoding */
-  public SSPTParser(java.io.InputStream stream, String encoding) {
-    try { jj_input_stream = new SimpleCharStream(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
-    token_source = new SSPTParserTokenManager(jj_input_stream);
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream stream) {
-     ReInit(stream, null);
-  }
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream stream, String encoding) {
-    try { jj_input_stream.ReInit(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
-    token_source.ReInit(jj_input_stream);
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  /** Constructor. */
-  public SSPTParser(java.io.Reader stream) {
-    jj_input_stream = new SimpleCharStream(stream, 1, 1);
-    token_source = new SSPTParserTokenManager(jj_input_stream);
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.Reader stream) {
-    jj_input_stream.ReInit(stream, 1, 1);
-    token_source.ReInit(jj_input_stream);
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  /** Constructor with generated Token Manager. */
-  public SSPTParser(SSPTParserTokenManager tm) {
-    token_source = tm;
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  /** Reinitialise. */
-  public void ReInit(SSPTParserTokenManager tm) {
-    token_source = tm;
-    token = new Token();
-    jj_ntk = -1;
-    jj_gen = 0;
-    for (int i = 0; i < 2; i++) jj_la1[i] = -1;
-  }
-
-  private Token jj_consume_token(int kind) throws ParseException {
-    Token oldToken;
-    if ((oldToken = token).next != null) token = token.next;
-    else token = token.next = token_source.getNextToken();
-    jj_ntk = -1;
-    if (token.kind == kind) {
-      jj_gen++;
-      return token;
-    }
-    token = oldToken;
-    jj_kind = kind;
-    throw generateParseException();
-  }
-
-
-/** Get the next Token. */
-  final public Token getNextToken() {
-    if (token.next != null) token = token.next;
-    else token = token.next = token_source.getNextToken();
-    jj_ntk = -1;
-    jj_gen++;
-    return token;
-  }
-
-/** Get the specific Token. */
-  final public Token getToken(int index) {
-    Token t = token;
-    for (int i = 0; i < index; i++) {
-      if (t.next != null) t = t.next;
-      else t = t.next = token_source.getNextToken();
-    }
-    return t;
-  }
-
-  private int jj_ntk() {
-    if ((jj_nt=token.next) == null)
-      return (jj_ntk = (token.next=token_source.getNextToken()).kind);
-    else
-      return (jj_ntk = jj_nt.kind);
-  }
-
-  private java.util.List<int[]> jj_expentries = new java.util.ArrayList<int[]>();
-  private int[] jj_expentry;
-  private int jj_kind = -1;
-
-  /** Generate ParseException. */
-  public ParseException generateParseException() {
-    jj_expentries.clear();
-    boolean[] la1tokens = new boolean[10];
-    if (jj_kind >= 0) {
-      la1tokens[jj_kind] = true;
-      jj_kind = -1;
-    }
-    for (int i = 0; i < 2; i++) {
-      if (jj_la1[i] == jj_gen) {
-        for (int j = 0; j < 32; j++) {
-          if ((jj_la1_0[i] & (1<<j)) != 0) {
-            la1tokens[j] = true;
-          }
-        }
-      }
-    }
-    for (int i = 0; i < 10; i++) {
-      if (la1tokens[i]) {
-        jj_expentry = new int[1];
-        jj_expentry[0] = i;
-        jj_expentries.add(jj_expentry);
-      }
-    }
-    int[][] exptokseq = new int[jj_expentries.size()][];
-    for (int i = 0; i < jj_expentries.size(); i++) {
-      exptokseq[i] = jj_expentries.get(i);
-    }
-    return new ParseException(token, exptokseq, tokenImage);
-  }
-
-  /** Enable tracing. */
-  final public void enable_tracing() {
-  }
-
-  /** Disable tracing. */
-  final public void disable_tracing() {
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
deleted file mode 100644
index 54e57d3..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserConstants.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/* Generated By: http&JavaCC: Do not edit this line. SSPTParserConstants.java */
-package org.apache.camel.component.sql.sspt.parser;
-
-
-/**
- * Token literal values and constants.
- * Generated by org.javacc.parser.OtherFilesGen#start()
- */
-public interface SSPTParserConstants {
-
-  /** End of File. */
-  int EOF = 0;
-  /** RegularExpression Id. */
-  int DIGIT = 6;
-  /** RegularExpression Id. */
-  int LETTER = 7;
-  /** RegularExpression Id. */
-  int SIMPLE_EXP_TOKEN = 8;
-  /** RegularExpression Id. */
-  int IDENTIFIER = 9;
-
-  /** Lexical state. */
-  int DEFAULT = 0;
-
-  /** Literal token values. */
-  String[] tokenImage = {
-    "<EOF>",
-    "\"(\"",
-    "\",\"",
-    "\")\"",
-    "\" \"",
-    "\"OUT\"",
-    "<DIGIT>",
-    "<LETTER>",
-    "<SIMPLE_EXP_TOKEN>",
-    "<IDENTIFIER>",
-  };
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
deleted file mode 100644
index 4daa202..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SSPTParserTokenManager.java
+++ /dev/null
@@ -1,366 +0,0 @@
-/* Generated By: http&JavaCC: Do not edit this line. SSPTParserTokenManager.java */
-package org.apache.camel.component.sql.sspt.parser;
-import org.apache.camel.component.sql.sspt.ast.*;
-
-/** Token Manager. */
-public class SSPTParserTokenManager implements SSPTParserConstants
-{
-
-  /** Debug output. */
-  public  java.io.PrintStream debugStream = System.out;
-  /** Set debug output. */
-  public  void setDebugStream(java.io.PrintStream ds) { debugStream = ds; }
-private final int jjStopStringLiteralDfa_0(int pos, long active0)
-{
-   switch (pos)
-   {
-      case 0:
-         if ((active0 & 0x20L) != 0L)
-         {
-            jjmatchedKind = 9;
-            return 5;
-         }
-         return -1;
-      case 1:
-         if ((active0 & 0x20L) != 0L)
-         {
-            jjmatchedKind = 9;
-            jjmatchedPos = 1;
-            return 5;
-         }
-         return -1;
-      default :
-         return -1;
-   }
-}
-private final int jjStartNfa_0(int pos, long active0)
-{
-   return jjMoveNfa_0(jjStopStringLiteralDfa_0(pos, active0), pos + 1);
-}
-private int jjStopAtPos(int pos, int kind)
-{
-   jjmatchedKind = kind;
-   jjmatchedPos = pos;
-   return pos + 1;
-}
-private int jjMoveStringLiteralDfa0_0()
-{
-   switch(curChar)
-   {
-      case 32:
-         return jjStopAtPos(0, 4);
-      case 40:
-         return jjStopAtPos(0, 1);
-      case 41:
-         return jjStopAtPos(0, 3);
-      case 44:
-         return jjStopAtPos(0, 2);
-      case 79:
-         return jjMoveStringLiteralDfa1_0(0x20L);
-      default :
-         return jjMoveNfa_0(3, 0);
-   }
-}
-private int jjMoveStringLiteralDfa1_0(long active0)
-{
-   try { curChar = input_stream.readChar(); }
-   catch(java.io.IOException e) {
-      jjStopStringLiteralDfa_0(0, active0);
-      return 1;
-   }
-   switch(curChar)
-   {
-      case 85:
-         return jjMoveStringLiteralDfa2_0(active0, 0x20L);
-      default :
-         break;
-   }
-   return jjStartNfa_0(0, active0);
-}
-private int jjMoveStringLiteralDfa2_0(long old0, long active0)
-{
-   if (((active0 &= old0)) == 0L)
-      return jjStartNfa_0(0, old0);
-   try { curChar = input_stream.readChar(); }
-   catch(java.io.IOException e) {
-      jjStopStringLiteralDfa_0(1, active0);
-      return 2;
-   }
-   switch(curChar)
-   {
-      case 84:
-         if ((active0 & 0x20L) != 0L)
-            return jjStartNfaWithStates_0(2, 5, 5);
-         break;
-      default :
-         break;
-   }
-   return jjStartNfa_0(1, active0);
-}
-private int jjStartNfaWithStates_0(int pos, int kind, int state)
-{
-   jjmatchedKind = kind;
-   jjmatchedPos = pos;
-   try { curChar = input_stream.readChar(); }
-   catch(java.io.IOException e) { return pos + 1; }
-   return jjMoveNfa_0(state, pos + 1);
-}
-private int jjMoveNfa_0(int startState, int curPos)
-{
-   int startsAt = 0;
-   jjnewStateCnt = 6;
-   int i = 1;
-   jjstateSet[0] = startState;
-   int kind = 0x7fffffff;
-   for (;;)
-   {
-      if (++jjround == 0x7fffffff)
-         ReInitRounds();
-      if (curChar < 64)
-      {
-         long l = 1L << curChar;
-         do
-         {
-            switch(jjstateSet[--i])
-            {
-               case 3:
-                  if (curChar == 36)
-                     jjstateSet[jjnewStateCnt++] = 0;
-                  break;
-               case 1:
-                  if ((0x3ff408100000000L & l) != 0L)
-                     jjAddStates(0, 1);
-                  break;
-               case 5:
-                  if ((0x3ff400000000000L & l) == 0L)
-                     break;
-                  if (kind > 9)
-                     kind = 9;
-                  jjstateSet[jjnewStateCnt++] = 5;
-                  break;
-               default : break;
-            }
-         } while(i != startsAt);
-      }
-      else if (curChar < 128)
-      {
-         long l = 1L << (curChar & 077);
-         do
-         {
-            switch(jjstateSet[--i])
-            {
-               case 3:
-               case 5:
-                  if ((0x7fffffe07fffffeL & l) == 0L)
-                     break;
-                  if (kind > 9)
-                     kind = 9;
-                  jjCheckNAdd(5);
-                  break;
-               case 0:
-                  if (curChar == 123)
-                     jjCheckNAddTwoStates(1, 2);
-                  break;
-               case 1:
-                  if ((0x7fffffe07fffffeL & l) != 0L)
-                     jjCheckNAddTwoStates(1, 2);
-                  break;
-               case 2:
-                  if (curChar == 125)
-                     kind = 8;
-                  break;
-               default : break;
-            }
-         } while(i != startsAt);
-      }
-      else
-      {
-         int i2 = (curChar & 0xff) >> 6;
-         long l2 = 1L << (curChar & 077);
-         do
-         {
-            switch(jjstateSet[--i])
-            {
-               default : break;
-            }
-         } while(i != startsAt);
-      }
-      if (kind != 0x7fffffff)
-      {
-         jjmatchedKind = kind;
-         jjmatchedPos = curPos;
-         kind = 0x7fffffff;
-      }
-      ++curPos;
-      if ((i = jjnewStateCnt) == (startsAt = 6 - (jjnewStateCnt = startsAt)))
-         return curPos;
-      try { curChar = input_stream.readChar(); }
-      catch(java.io.IOException e) { return curPos; }
-   }
-}
-static final int[] jjnextStates = {
-   1, 2, 
-};
-
-/** Token literal values. */
-public static final String[] jjstrLiteralImages = {
-"", "\50", "\54", "\51", "\40", "\117\125\124", null, null, null, null, };
-
-/** Lexer state names. */
-public static final String[] lexStateNames = {
-   "DEFAULT",
-};
-protected SimpleCharStream input_stream;
-private final int[] jjrounds = new int[6];
-private final int[] jjstateSet = new int[12];
-protected char curChar;
-/** Constructor. */
-public SSPTParserTokenManager(SimpleCharStream stream){
-   if (SimpleCharStream.staticFlag)
-      throw new Error("ERROR: Cannot use a static CharStream class with a non-static lexical analyzer.");
-   input_stream = stream;
-}
-
-/** Constructor. */
-public SSPTParserTokenManager(SimpleCharStream stream, int lexState){
-   this(stream);
-   SwitchTo(lexState);
-}
-
-/** Reinitialise parser. */
-public void ReInit(SimpleCharStream stream)
-{
-   jjmatchedPos = jjnewStateCnt = 0;
-   curLexState = defaultLexState;
-   input_stream = stream;
-   ReInitRounds();
-}
-private void ReInitRounds()
-{
-   int i;
-   jjround = 0x80000001;
-   for (i = 6; i-- > 0;)
-      jjrounds[i] = 0x80000000;
-}
-
-/** Reinitialise parser. */
-public void ReInit(SimpleCharStream stream, int lexState)
-{
-   ReInit(stream);
-   SwitchTo(lexState);
-}
-
-/** Switch to specified lex state. */
-public void SwitchTo(int lexState)
-{
-   if (lexState >= 1 || lexState < 0)
-      throw new TokenMgrError("Error: Ignoring invalid lexical state : " + lexState + ". State unchanged.", TokenMgrError.INVALID_LEXICAL_STATE);
-   else
-      curLexState = lexState;
-}
-
-protected Token jjFillToken()
-{
-   final Token t;
-   final String curTokenImage;
-   final int beginLine;
-   final int endLine;
-   final int beginColumn;
-   final int endColumn;
-   String im = jjstrLiteralImages[jjmatchedKind];
-   curTokenImage = (im == null) ? input_stream.GetImage() : im;
-   beginLine = input_stream.getBeginLine();
-   beginColumn = input_stream.getBeginColumn();
-   endLine = input_stream.getEndLine();
-   endColumn = input_stream.getEndColumn();
-   t = Token.newToken(jjmatchedKind, curTokenImage);
-
-   t.beginLine = beginLine;
-   t.endLine = endLine;
-   t.beginColumn = beginColumn;
-   t.endColumn = endColumn;
-
-   return t;
-}
-
-int curLexState = 0;
-int defaultLexState = 0;
-int jjnewStateCnt;
-int jjround;
-int jjmatchedPos;
-int jjmatchedKind;
-
-/** Get the next Token. */
-public Token getNextToken() 
-{
-  Token matchedToken;
-  int curPos = 0;
-
-  EOFLoop :
-  for (;;)
-  {
-   try
-   {
-      curChar = input_stream.BeginToken();
-   }
-   catch(java.io.IOException e)
-   {
-      jjmatchedKind = 0;
-      matchedToken = jjFillToken();
-      return matchedToken;
-   }
-
-   jjmatchedKind = 0x7fffffff;
-   jjmatchedPos = 0;
-   curPos = jjMoveStringLiteralDfa0_0();
-   if (jjmatchedKind != 0x7fffffff)
-   {
-      if (jjmatchedPos + 1 < curPos)
-         input_stream.backup(curPos - jjmatchedPos - 1);
-         matchedToken = jjFillToken();
-         return matchedToken;
-   }
-   int error_line = input_stream.getEndLine();
-   int error_column = input_stream.getEndColumn();
-   String error_after = null;
-   boolean EOFSeen = false;
-   try { input_stream.readChar(); input_stream.backup(1); }
-   catch (java.io.IOException e1) {
-      EOFSeen = true;
-      error_after = curPos <= 1 ? "" : input_stream.GetImage();
-      if (curChar == '\n' || curChar == '\r') {
-         error_line++;
-         error_column = 0;
-      }
-      else
-         error_column++;
-   }
-   if (!EOFSeen) {
-      input_stream.backup(1);
-      error_after = curPos <= 1 ? "" : input_stream.GetImage();
-   }
-   throw new TokenMgrError(EOFSeen, curLexState, error_line, error_column, error_after, curChar, TokenMgrError.LEXICAL_ERROR);
-  }
-}
-
-private void jjCheckNAdd(int state)
-{
-   if (jjrounds[state] != jjround)
-   {
-      jjstateSet[jjnewStateCnt++] = state;
-      jjrounds[state] = jjround;
-   }
-}
-private void jjAddStates(int start, int end)
-{
-   do {
-      jjstateSet[jjnewStateCnt++] = jjnextStates[start];
-   } while (start++ != end);
-}
-private void jjCheckNAddTwoStates(int state1, int state2)
-{
-   jjCheckNAdd(state1);
-   jjCheckNAdd(state2);
-}
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
deleted file mode 100644
index 58a03ae..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/SimpleCharStream.java
+++ /dev/null
@@ -1,471 +0,0 @@
-/* Generated By:JavaCC: Do not edit this line. SimpleCharStream.java Version 5.0 */
-/* JavaCCOptions:STATIC=false,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
-package org.apache.camel.component.sql.sspt.parser;
-
-/**
- * An implementation of interface CharStream, where the stream is assumed to
- * contain only ASCII characters (without unicode processing).
- */
-
-public class SimpleCharStream
-{
-/** Whether parser is static. */
-  public static final boolean staticFlag = false;
-  int bufsize;
-  int available;
-  int tokenBegin;
-/** Position in buffer. */
-  public int bufpos = -1;
-  protected int bufline[];
-  protected int bufcolumn[];
-
-  protected int column = 0;
-  protected int line = 1;
-
-  protected boolean prevCharIsCR = false;
-  protected boolean prevCharIsLF = false;
-
-  protected java.io.Reader inputStream;
-
-  protected char[] buffer;
-  protected int maxNextCharInd = 0;
-  protected int inBuf = 0;
-  protected int tabSize = 8;
-
-  protected void setTabSize(int i) { tabSize = i; }
-  protected int getTabSize(int i) { return tabSize; }
-
-
-  protected void ExpandBuff(boolean wrapAround)
-  {
-    char[] newbuffer = new char[bufsize + 2048];
-    int newbufline[] = new int[bufsize + 2048];
-    int newbufcolumn[] = new int[bufsize + 2048];
-
-    try
-    {
-      if (wrapAround)
-      {
-        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
-        System.arraycopy(buffer, 0, newbuffer, bufsize - tokenBegin, bufpos);
-        buffer = newbuffer;
-
-        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
-        System.arraycopy(bufline, 0, newbufline, bufsize - tokenBegin, bufpos);
-        bufline = newbufline;
-
-        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
-        System.arraycopy(bufcolumn, 0, newbufcolumn, bufsize - tokenBegin, bufpos);
-        bufcolumn = newbufcolumn;
-
-        maxNextCharInd = (bufpos += (bufsize - tokenBegin));
-      }
-      else
-      {
-        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
-        buffer = newbuffer;
-
-        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
-        bufline = newbufline;
-
-        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
-        bufcolumn = newbufcolumn;
-
-        maxNextCharInd = (bufpos -= tokenBegin);
-      }
-    }
-    catch (Throwable t)
-    {
-      throw new Error(t.getMessage());
-    }
-
-
-    bufsize += 2048;
-    available = bufsize;
-    tokenBegin = 0;
-  }
-
-  protected void FillBuff() throws java.io.IOException
-  {
-    if (maxNextCharInd == available)
-    {
-      if (available == bufsize)
-      {
-        if (tokenBegin > 2048)
-        {
-          bufpos = maxNextCharInd = 0;
-          available = tokenBegin;
-        }
-        else if (tokenBegin < 0)
-          bufpos = maxNextCharInd = 0;
-        else
-          ExpandBuff(false);
-      }
-      else if (available > tokenBegin)
-        available = bufsize;
-      else if ((tokenBegin - available) < 2048)
-        ExpandBuff(true);
-      else
-        available = tokenBegin;
-    }
-
-    int i;
-    try {
-      if ((i = inputStream.read(buffer, maxNextCharInd, available - maxNextCharInd)) == -1)
-      {
-        inputStream.close();
-        throw new java.io.IOException();
-      }
-      else
-        maxNextCharInd += i;
-      return;
-    }
-    catch(java.io.IOException e) {
-      --bufpos;
-      backup(0);
-      if (tokenBegin == -1)
-        tokenBegin = bufpos;
-      throw e;
-    }
-  }
-
-/** Start. */
-  public char BeginToken() throws java.io.IOException
-  {
-    tokenBegin = -1;
-    char c = readChar();
-    tokenBegin = bufpos;
-
-    return c;
-  }
-
-  protected void UpdateLineColumn(char c)
-  {
-    column++;
-
-    if (prevCharIsLF)
-    {
-      prevCharIsLF = false;
-      line += (column = 1);
-    }
-    else if (prevCharIsCR)
-    {
-      prevCharIsCR = false;
-      if (c == '\n')
-      {
-        prevCharIsLF = true;
-      }
-      else
-        line += (column = 1);
-    }
-
-    switch (c)
-    {
-      case '\r' :
-        prevCharIsCR = true;
-        break;
-      case '\n' :
-        prevCharIsLF = true;
-        break;
-      case '\t' :
-        column--;
-        column += (tabSize - (column % tabSize));
-        break;
-      default :
-        break;
-    }
-
-    bufline[bufpos] = line;
-    bufcolumn[bufpos] = column;
-  }
-
-/** Read a character. */
-  public char readChar() throws java.io.IOException
-  {
-    if (inBuf > 0)
-    {
-      --inBuf;
-
-      if (++bufpos == bufsize)
-        bufpos = 0;
-
-      return buffer[bufpos];
-    }
-
-    if (++bufpos >= maxNextCharInd)
-      FillBuff();
-
-    char c = buffer[bufpos];
-
-    UpdateLineColumn(c);
-    return c;
-  }
-
-  @Deprecated
-  /**
-   * @deprecated
-   * @see #getEndColumn
-   */
-
-  public int getColumn() {
-    return bufcolumn[bufpos];
-  }
-
-  @Deprecated
-  /**
-   * @deprecated
-   * @see #getEndLine
-   */
-
-  public int getLine() {
-    return bufline[bufpos];
-  }
-
-  /** Get token end column number. */
-  public int getEndColumn() {
-    return bufcolumn[bufpos];
-  }
-
-  /** Get token end line number. */
-  public int getEndLine() {
-     return bufline[bufpos];
-  }
-
-  /** Get token beginning column number. */
-  public int getBeginColumn() {
-    return bufcolumn[tokenBegin];
-  }
-
-  /** Get token beginning line number. */
-  public int getBeginLine() {
-    return bufline[tokenBegin];
-  }
-
-/** Backup a number of characters. */
-  public void backup(int amount) {
-
-    inBuf += amount;
-    if ((bufpos -= amount) < 0)
-      bufpos += bufsize;
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.Reader dstream, int startline,
-  int startcolumn, int buffersize)
-  {
-    inputStream = dstream;
-    line = startline;
-    column = startcolumn - 1;
-
-    available = bufsize = buffersize;
-    buffer = new char[buffersize];
-    bufline = new int[buffersize];
-    bufcolumn = new int[buffersize];
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.Reader dstream, int startline,
-                          int startcolumn)
-  {
-    this(dstream, startline, startcolumn, 4096);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.Reader dstream)
-  {
-    this(dstream, 1, 1, 4096);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.Reader dstream, int startline,
-  int startcolumn, int buffersize)
-  {
-    inputStream = dstream;
-    line = startline;
-    column = startcolumn - 1;
-
-    if (buffer == null || buffersize != buffer.length)
-    {
-      available = bufsize = buffersize;
-      buffer = new char[buffersize];
-      bufline = new int[buffersize];
-      bufcolumn = new int[buffersize];
-    }
-    prevCharIsLF = prevCharIsCR = false;
-    tokenBegin = inBuf = maxNextCharInd = 0;
-    bufpos = -1;
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.Reader dstream, int startline,
-                     int startcolumn)
-  {
-    ReInit(dstream, startline, startcolumn, 4096);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.Reader dstream)
-  {
-    ReInit(dstream, 1, 1, 4096);
-  }
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
-  int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
-  {
-    this(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream, int startline,
-  int startcolumn, int buffersize)
-  {
-    this(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
-                          int startcolumn) throws java.io.UnsupportedEncodingException
-  {
-    this(dstream, encoding, startline, startcolumn, 4096);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream, int startline,
-                          int startcolumn)
-  {
-    this(dstream, startline, startcolumn, 4096);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
-  {
-    this(dstream, encoding, 1, 1, 4096);
-  }
-
-  /** Constructor. */
-  public SimpleCharStream(java.io.InputStream dstream)
-  {
-    this(dstream, 1, 1, 4096);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
-                          int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
-  {
-    ReInit(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream, int startline,
-                          int startcolumn, int buffersize)
-  {
-    ReInit(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
-  {
-    ReInit(dstream, encoding, 1, 1, 4096);
-  }
-
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream)
-  {
-    ReInit(dstream, 1, 1, 4096);
-  }
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
-                     int startcolumn) throws java.io.UnsupportedEncodingException
-  {
-    ReInit(dstream, encoding, startline, startcolumn, 4096);
-  }
-  /** Reinitialise. */
-  public void ReInit(java.io.InputStream dstream, int startline,
-                     int startcolumn)
-  {
-    ReInit(dstream, startline, startcolumn, 4096);
-  }
-  /** Get token literal value. */
-  public String GetImage()
-  {
-    if (bufpos >= tokenBegin)
-      return new String(buffer, tokenBegin, bufpos - tokenBegin + 1);
-    else
-      return new String(buffer, tokenBegin, bufsize - tokenBegin) +
-                            new String(buffer, 0, bufpos + 1);
-  }
-
-  /** Get the suffix. */
-  public char[] GetSuffix(int len)
-  {
-    char[] ret = new char[len];
-
-    if ((bufpos + 1) >= len)
-      System.arraycopy(buffer, bufpos - len + 1, ret, 0, len);
-    else
-    {
-      System.arraycopy(buffer, bufsize - (len - bufpos - 1), ret, 0,
-                                                        len - bufpos - 1);
-      System.arraycopy(buffer, 0, ret, len - bufpos - 1, bufpos + 1);
-    }
-
-    return ret;
-  }
-
-  /** Reset buffer when finished. */
-  public void Done()
-  {
-    buffer = null;
-    bufline = null;
-    bufcolumn = null;
-  }
-
-  /**
-   * Method to adjust line and column numbers for the start of a token.
-   */
-  public void adjustBeginLineColumn(int newLine, int newCol)
-  {
-    int start = tokenBegin;
-    int len;
-
-    if (bufpos >= tokenBegin)
-    {
-      len = bufpos - tokenBegin + inBuf + 1;
-    }
-    else
-    {
-      len = bufsize - tokenBegin + bufpos + 1 + inBuf;
-    }
-
-    int i = 0, j = 0, k = 0;
-    int nextColDiff = 0, columnDiff = 0;
-
-    while (i < len && bufline[j = start % bufsize] == bufline[k = ++start % bufsize])
-    {
-      bufline[j] = newLine;
-      nextColDiff = columnDiff + bufcolumn[k] - bufcolumn[j];
-      bufcolumn[j] = newCol + columnDiff;
-      columnDiff = nextColDiff;
-      i++;
-    }
-
-    if (i < len)
-    {
-      bufline[j] = newLine++;
-      bufcolumn[j] = newCol + columnDiff;
-
-      while (i++ < len)
-      {
-        if (bufline[j = start % bufsize] != bufline[++start % bufsize])
-          bufline[j] = newLine++;
-        else
-          bufline[j] = newLine;
-      }
-    }
-
-    line = bufline[j];
-    column = bufcolumn[j];
-  }
-
-}
-/* JavaCC - OriginalChecksum=740c413ce2f513b4d926ea988f37e3da (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
deleted file mode 100644
index a7ed978..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/Token.java
+++ /dev/null
@@ -1,131 +0,0 @@
-/* Generated By:JavaCC: Do not edit this line. Token.java Version 5.0 */
-/* JavaCCOptions:TOKEN_EXTENDS=,KEEP_LINE_COL=null,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
-package org.apache.camel.component.sql.sspt.parser;
-
-/**
- * Describes the input token stream.
- */
-
-public class Token implements java.io.Serializable {
-
-  /**
-   * The version identifier for this Serializable class.
-   * Increment only if the <i>serialized</i> form of the
-   * class changes.
-   */
-  private static final long serialVersionUID = 1L;
-
-  /**
-   * An integer that describes the kind of this token.  This numbering
-   * system is determined by JavaCCParser, and a table of these numbers is
-   * stored in the file ...Constants.java.
-   */
-  public int kind;
-
-  /** The line number of the first character of this Token. */
-  public int beginLine;
-  /** The column number of the first character of this Token. */
-  public int beginColumn;
-  /** The line number of the last character of this Token. */
-  public int endLine;
-  /** The column number of the last character of this Token. */
-  public int endColumn;
-
-  /**
-   * The string image of the token.
-   */
-  public String image;
-
-  /**
-   * A reference to the next regular (non-special) token from the input
-   * stream.  If this is the last token from the input stream, or if the
-   * token manager has not read tokens beyond this one, this field is
-   * set to null.  This is true only if this token is also a regular
-   * token.  Otherwise, see below for a description of the contents of
-   * this field.
-   */
-  public Token next;
-
-  /**
-   * This field is used to access special tokens that occur prior to this
-   * token, but after the immediately preceding regular (non-special) token.
-   * If there are no such special tokens, this field is set to null.
-   * When there are more than one such special token, this field refers
-   * to the last of these special tokens, which in turn refers to the next
-   * previous special token through its specialToken field, and so on
-   * until the first special token (whose specialToken field is null).
-   * The next fields of special tokens refer to other special tokens that
-   * immediately follow it (without an intervening regular token).  If there
-   * is no such token, this field is null.
-   */
-  public Token specialToken;
-
-  /**
-   * An optional attribute value of the Token.
-   * Tokens which are not used as syntactic sugar will often contain
-   * meaningful values that will be used later on by the compiler or
-   * interpreter. This attribute value is often different from the image.
-   * Any subclass of Token that actually wants to return a non-null value can
-   * override this method as appropriate.
-   */
-  public Object getValue() {
-    return null;
-  }
-
-  /**
-   * No-argument constructor
-   */
-  public Token() {}
-
-  /**
-   * Constructs a new token for the specified Image.
-   */
-  public Token(int kind)
-  {
-    this(kind, null);
-  }
-
-  /**
-   * Constructs a new token for the specified Image and Kind.
-   */
-  public Token(int kind, String image)
-  {
-    this.kind = kind;
-    this.image = image;
-  }
-
-  /**
-   * Returns the image.
-   */
-  public String toString()
-  {
-    return image;
-  }
-
-  /**
-   * Returns a new Token object, by default. However, if you want, you
-   * can create and return subclass objects based on the value of ofKind.
-   * Simply add the cases to the switch for all those special cases.
-   * For example, if you have a subclass of Token called IDToken that
-   * you want to create if ofKind is ID, simply add something like :
-   *
-   *    case MyParserConstants.ID : return new IDToken(ofKind, image);
-   *
-   * to the following switch statement. Then you can cast matchedToken
-   * variable to the appropriate type and use sit in your lexical actions.
-   */
-  public static Token newToken(int ofKind, String image)
-  {
-    switch(ofKind)
-    {
-      default : return new Token(ofKind, image);
-    }
-  }
-
-  public static Token newToken(int ofKind)
-  {
-    return newToken(ofKind, null);
-  }
-
-}
-/* JavaCC - OriginalChecksum=49813021262cb0b6d876cbaf57667539 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
deleted file mode 100644
index b58d63b..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/TokenMgrError.java
+++ /dev/null
@@ -1,147 +0,0 @@
-/* Generated By:JavaCC: Do not edit this line. TokenMgrError.java Version 5.0 */
-/* JavaCCOptions: */
-package org.apache.camel.component.sql.sspt.parser;
-
-/** Token Manager Error. */
-public class TokenMgrError extends Error
-{
-
-  /**
-   * The version identifier for this Serializable class.
-   * Increment only if the <i>serialized</i> form of the
-   * class changes.
-   */
-  private static final long serialVersionUID = 1L;
-
-  /*
-   * Ordinals for various reasons why an Error of this type can be thrown.
-   */
-
-  /**
-   * Lexical error occurred.
-   */
-  static final int LEXICAL_ERROR = 0;
-
-  /**
-   * An attempt was made to create a second instance of a static token manager.
-   */
-  static final int STATIC_LEXER_ERROR = 1;
-
-  /**
-   * Tried to change to an invalid lexical state.
-   */
-  static final int INVALID_LEXICAL_STATE = 2;
-
-  /**
-   * Detected (and bailed out of) an infinite loop in the token manager.
-   */
-  static final int LOOP_DETECTED = 3;
-
-  /**
-   * Indicates the reason why the exception is thrown. It will have
-   * one of the above 4 values.
-   */
-  int errorCode;
-
-  /**
-   * Replaces unprintable characters by their escaped (or unicode escaped)
-   * equivalents in the given string
-   */
-  protected static final String addEscapes(String str) {
-    StringBuffer retval = new StringBuffer();
-    char ch;
-    for (int i = 0; i < str.length(); i++) {
-      switch (str.charAt(i))
-      {
-        case 0 :
-          continue;
-        case '\b':
-          retval.append("\\b");
-          continue;
-        case '\t':
-          retval.append("\\t");
-          continue;
-        case '\n':
-          retval.append("\\n");
-          continue;
-        case '\f':
-          retval.append("\\f");
-          continue;
-        case '\r':
-          retval.append("\\r");
-          continue;
-        case '\"':
-          retval.append("\\\"");
-          continue;
-        case '\'':
-          retval.append("\\\'");
-          continue;
-        case '\\':
-          retval.append("\\\\");
-          continue;
-        default:
-          if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
-            String s = "0000" + Integer.toString(ch, 16);
-            retval.append("\\u" + s.substring(s.length() - 4, s.length()));
-          } else {
-            retval.append(ch);
-          }
-          continue;
-      }
-    }
-    return retval.toString();
-  }
-
-  /**
-   * Returns a detailed message for the Error when it is thrown by the
-   * token manager to indicate a lexical error.
-   * Parameters :
-   *    EOFSeen     : indicates if EOF caused the lexical error
-   *    curLexState : lexical state in which this error occurred
-   *    errorLine   : line number when the error occurred
-   *    errorColumn : column number when the error occurred
-   *    errorAfter  : prefix that was seen before this error occurred
-   *    curchar     : the offending character
-   * Note: You can customize the lexical error message by modifying this method.
-   */
-  protected static String LexicalError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar) {
-    return("Lexical error at line " +
-          errorLine + ", column " +
-          errorColumn + ".  Encountered: " +
-          (EOFSeen ? "<EOF> " : ("\"" + addEscapes(String.valueOf(curChar)) + "\"") + " (" + (int)curChar + "), ") +
-          "after : \"" + addEscapes(errorAfter) + "\"");
-  }
-
-  /**
-   * You can also modify the body of this method to customize your error messages.
-   * For example, cases like LOOP_DETECTED and INVALID_LEXICAL_STATE are not
-   * of end-users concern, so you can return something like :
-   *
-   *     "Internal Error : Please file a bug report .... "
-   *
-   * from this method for such cases in the release version of your parser.
-   */
-  public String getMessage() {
-    return super.getMessage();
-  }
-
-  /*
-   * Constructors of various flavors follow.
-   */
-
-  /** No arg constructor. */
-  public TokenMgrError() {
-  }
-
-  /** Constructor with message and reason. */
-  public TokenMgrError(String message, int reason) {
-    super(message);
-    errorCode = reason;
-  }
-
-  /** Full Constructor. */
-  public TokenMgrError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar, int reason) {
-    this(LexicalError(EOFSeen, lexState, errorLine, errorColumn, errorAfter, curChar), reason);
-  }
-}
-/* JavaCC - OriginalChecksum=40bf525b6801e308b2ddf5874ae68024 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
deleted file mode 100755
index e80e9a5..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/generate_sptp_classes.sh
+++ /dev/null
@@ -1,4 +0,0 @@
-#!/usr/bin/env bash
-rm -f *.java
-javacc sspt.jj
-rm -f ParseException.java

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
deleted file mode 100644
index db2f33c..0000000
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/sspt/parser/sspt.jj
+++ /dev/null
@@ -1,136 +0,0 @@
-//Using some token definions from: http://kiwwito.com/build-a-lexical-analyzer-with-javacc/
-
-options {
-    STATIC = false;
-}
-
-
-PARSER_BEGIN(SSPTParser)
-
-package org.apache.camel.component.sql.sspt.parser;
-
-import org.apache.camel.component.sql.sspt.ast.*;
-
-public class SSPTParser {
-   int paramaterNameCounter = 0;
-
-   String createNextParameterName() {
-      return "_"+(paramaterNameCounter++);
-   }
-}
-
-PARSER_END(SSPTParser)
-
-public Template parse() :
-{   Token procudureName;
-    Template template = new Template();
-    Object parameter = null;
-}
-{
-  (procudureName = <IDENTIFIER> "(" (parameter = Parameter() { template.addParameter(parameter);}) (","
-  parameter
-  = Parameter(){template.addParameter(parameter);})*  ")" <EOF>)
-  {
-   template.setProcedureName(procudureName.toString());
-   return template;
-  }
-}
-
-Object Parameter() :
-{
-    Object param;
-}
-{
-     (param = InputParameter() {return param;}) | (param = OutParameter(){return param;})
-}
-
-InputParameter InputParameter() :
-{
-     String sqlTypeAsStr;
-     String name;
-     String valueSrcAsStr;
-}
-{
-    (sqlTypeAsStr = ParameterSqlType() " " valueSrcAsStr =
-    InputParameterSrc())
-    {
-        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
-        return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));
-    }
-}
-
-OutParameter OutParameter() :
-{
-     String sqlType;
-     String name;
-     String outHeader;
-}
-{
-    ("OUT" " " sqlType = ParameterSqlType() " " outHeader =
-    OutHeader())
-    {
-        return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);
-    }
-}
-
-String ParameterSqlType():
-{
-    Token t;
-}
-{
-    (t = <IDENTIFIER>)
-    {
-        return t.toString();
-    }
-}
-
-String OutHeader():
-{
- Token token;
-}
-{
-    (token = <IDENTIFIER>)
-    {
-        return token.toString();
-    }
-}
-
-String InputParameterSrc():
-{
-    String ret;
-}
-{
-    (ret = SimpleExpression())
-    {
-        return ret;
-    }
-}
-
-String SimpleExpression() :
-{
- Token t = null;
-}
-{
-    (t = <SIMPLE_EXP_TOKEN>)
-    {
-    return t.toString();
-    }
-}
-
-TOKEN: {
-    <#DIGIT: (["0"-"9"])>
-}
-
-TOKEN: {
-    <#LETTER: (["a"-"z","A"-"Z"])>
-}
-
-TOKEN : {
-    <SIMPLE_EXP_TOKEN: "${"(<LETTER>|<DIGIT> | " " | "'" | "." )* "}">
-}
-
-
-TOKEN : {
-    <IDENTIFIER: <LETTER>( <LETTER> | <DIGIT> | ".") *>
-}
-

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
new file mode 100644
index 0000000..da2850a
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -0,0 +1,44 @@
+package org.apache.camel.component.sql.stored;
+
+import org.apache.camel.CamelContext;
+import org.apache.camel.Endpoint;
+import org.apache.camel.RuntimeCamelException;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
+import org.apache.camel.impl.UriEndpointComponent;
+
+import javax.sql.DataSource;
+import java.util.Map;
+
+/**
+ * Created by snurmine on 1/3/16.
+ */
+public class SqlStoredComponent extends UriEndpointComponent {
+
+    private DataSource dataSource;
+
+    public SqlStoredComponent() {
+        super(SqlStoredEndpoint.class);
+    }
+
+
+
+    TemplateStoredProcedureFactory templateStoredProcedureFactory = new TemplateStoredProcedureFactory();
+
+    public SqlStoredComponent(CamelContext context, Class<? extends Endpoint> endpointClass) {
+        super(context, endpointClass);
+    }
+
+    @Override
+    protected Endpoint createEndpoint(String uri, String remaining, Map<String, Object> parameters) throws Exception {
+
+            return new SqlStoredEndpoint(templateStoredProcedureFactory,dataSource,remaining);
+    }
+
+    public DataSource getDataSource() {
+        return dataSource;
+    }
+
+    public void setDataSource(DataSource dataSource) {
+        this.dataSource = dataSource;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
new file mode 100644
index 0000000..cee6223
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
@@ -0,0 +1,45 @@
+package org.apache.camel.component.sql.stored;
+
+import org.apache.camel.Producer;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
+import org.apache.camel.impl.DefaultPollingEndpoint;
+import org.apache.camel.spi.Metadata;
+import org.apache.camel.spi.UriEndpoint;
+import org.apache.camel.spi.UriPath;
+
+import javax.sql.DataSource;
+
+@UriEndpoint(scheme = "sql-stored", title = "SQL stored", syntax = "sql-stored:template", label = "database,sql")
+public class SqlStoredEndpoint extends DefaultPollingEndpoint {
+
+    @UriPath(description = "Sets the stored procedure template to perform")
+    @Metadata(required = "true")
+    private String template;
+
+    private final TemplateStoredProcedureFactory templateStoredProcedureFactory;
+
+    private final DataSource dataSource;
+
+
+    public SqlStoredEndpoint(TemplateStoredProcedureFactory templateStoredProcedureFactory, DataSource dataSource,
+                             String template) {
+        this.templateStoredProcedureFactory = templateStoredProcedureFactory;
+        this.dataSource = dataSource;
+        this.template = template;
+    }
+
+    @Override
+    public Producer createProducer() throws Exception {
+        return new SqlStoredProducer(this, templateStoredProcedureFactory.createFromString(template, dataSource));
+    }
+
+    @Override
+    public boolean isSingleton() {
+        return false;
+    }
+
+    @Override
+    protected String createEndpointUri() {
+        return "sql-stored:" + template;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
new file mode 100644
index 0000000..9d2210d
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
@@ -0,0 +1,25 @@
+package org.apache.camel.component.sql.stored;
+
+import org.apache.camel.Endpoint;
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedure;
+import org.apache.camel.impl.DefaultProducer;
+
+/**
+ * Created by snurmine on 1/3/16.
+ */
+public class SqlStoredProducer extends DefaultProducer {
+
+    final TemplateStoredProcedure templateStoredProcedure;
+
+    public SqlStoredProducer(Endpoint endpoint, TemplateStoredProcedure templateStoredProcedure) {
+        super(endpoint);
+        this.templateStoredProcedure = templateStoredProcedure;
+    }
+
+    @Override
+    public void process(Exchange exchange) throws Exception {
+        templateStoredProcedure.execute(exchange);
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
new file mode 100644
index 0000000..7c1f415
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
@@ -0,0 +1,56 @@
+package org.apache.camel.component.sql.stored.template;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.stored.template.ast.InputParameter;
+import org.apache.camel.component.sql.stored.template.ast.OutParameter;
+import org.apache.camel.component.sql.stored.template.ast.Template;
+import org.springframework.jdbc.core.SqlOutParameter;
+import org.springframework.jdbc.core.SqlParameter;
+import org.springframework.jdbc.object.StoredProcedure;
+
+import javax.sql.DataSource;
+import java.util.HashMap;
+import java.util.Map;
+
+
+public class TemplateStoredProcedure extends StoredProcedure {
+
+    Template template;
+
+    public TemplateStoredProcedure(DataSource dataSource, Template template) {
+        this.template = template;
+        setDataSource(dataSource);
+
+        setSql(template.getProcedureName());
+
+        for (InputParameter inputParameter : template.getInputParameterList()) {
+            declareParameter(new SqlParameter(inputParameter.getName(), inputParameter.getSqlType()));
+        }
+
+        for (OutParameter outParameter : template.getOutParameterList()) {
+            declareParameter(new SqlOutParameter(outParameter.getName(), outParameter.getSqlType()));
+            setFunction(false);
+        }
+
+        compile();
+    }
+
+
+    public void execute(Exchange exchange) {
+
+        Map<String, Object> params = new HashMap<>();
+
+        for (InputParameter inputParameter : template.getInputParameterList()) {
+            params.put(inputParameter.getName(), inputParameter.getValueExpression().evaluate(exchange, inputParameter.getJavaType()));
+        }
+
+        Map<String, Object> ret = super.execute(params);
+
+        for (OutParameter out : template.getOutParameterList()) {
+            exchange.getOut().setHeader(out.getOutHeader(), ret.get(out.getName()));
+        }
+
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
new file mode 100644
index 0000000..f1b4da3
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -0,0 +1,38 @@
+package org.apache.camel.component.sql.stored.template;
+
+import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
+import org.apache.camel.component.sql.stored.template.ast.Template;
+import org.apache.camel.component.sql.stored.template.generated.ParseException;
+import org.apache.camel.component.sql.stored.template.generated.SSPTParser;
+
+import javax.sql.DataSource;
+import java.io.StringReader;
+
+public class TemplateStoredProcedureFactory {
+
+
+    public TemplateStoredProcedure createFromString(String string, DataSource dataSource)  {
+        Template sptpRootNode = parseTemplate(string);
+        return new TemplateStoredProcedure(dataSource, sptpRootNode);
+
+    }
+
+    public Template parseTemplate(String template)  {
+        try {
+            SSPTParser parser = new SSPTParser(new StringReader(template));
+
+            return validate(parser.parse());
+        }catch(ParseException parseException) {
+            throw new ParseRuntimeException(parseException);
+        }
+    }
+
+    private Template validate(Template input) {
+        if (input.getOutParameterList().isEmpty()) {
+            throw new ParseRuntimeException("At least one OUT parameter must be given.");
+        }
+        return input;
+    }
+
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
new file mode 100644
index 0000000..69a9703
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
@@ -0,0 +1,47 @@
+package org.apache.camel.component.sql.stored.template.ast;
+
+import org.apache.camel.Expression;
+import org.apache.camel.builder.ExpressionBuilder;
+
+
+public class InputParameter {
+
+    String name;
+
+    int sqlType;
+
+    Expression valueExpression;
+
+    Class javaType;
+
+
+    public InputParameter(String name, int sqlType, String valueSrcAsStr, Class javaType) {
+        this.name = name;
+        this.sqlType = sqlType;
+        this.javaType = javaType;
+        this.valueExpression = parseValueExpression(valueSrcAsStr);
+    }
+
+
+    private Expression parseValueExpression(String str) {
+        return ExpressionBuilder.simpleExpression(str);
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public int getSqlType() {
+        return sqlType;
+    }
+
+    public Expression getValueExpression() {
+        return valueExpression;
+    }
+
+    public Class getJavaType() {
+        return javaType;
+    }
+
+
+}


[2/9] camel git commit: Saving work. Simple Producer.

Posted by da...@apache.org.
http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
new file mode 100644
index 0000000..2182bd7
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
@@ -0,0 +1,33 @@
+package org.apache.camel.component.sql.stored.template.ast;
+
+/**
+ * Created by snurmine on 12/20/15.
+ */
+public class OutParameter {
+
+
+    String name;
+
+    int sqlType;
+
+    String outHeader;
+
+
+    public OutParameter(String name, int sqlType, String outHeader) {
+        this.name = name;
+        this.sqlType = sqlType;
+        this.outHeader = outHeader;
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public int getSqlType() {
+        return sqlType;
+    }
+
+    public String getOutHeader() {
+        return outHeader;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
new file mode 100644
index 0000000..e84c7a9
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
@@ -0,0 +1,58 @@
+package org.apache.camel.component.sql.stored.template.ast;
+
+import org.springframework.util.ReflectionUtils;
+
+import java.lang.reflect.Field;
+import java.math.BigInteger;
+import java.sql.Date;
+import java.sql.Types;
+
+
+public class ParseHelper {
+
+    public static int parseSqlType(String sqlType) {
+        Field field = ReflectionUtils.findField(Types.class, sqlType);
+        if (field == null) {
+            throw new ParseRuntimeException("Field " + sqlType + " not found from java.procedureName.Types");
+        }
+        try {
+            return field.getInt(Types.class);
+        } catch (IllegalAccessException e) {
+            throw new ParseRuntimeException(e);
+        }
+    }
+
+    public static Class sqlTypeToJavaType(int sqlType, String sqlTypeStr) {
+        //TODO: as rest of types.
+        //TODO: add test for each type.
+        Class ret = null;
+        switch (sqlType) {
+            case Types.INTEGER:
+                ret = Integer.class;
+                break;
+            case Types.VARCHAR:
+                ret = String.class;
+                break;
+            case Types.BIGINT:
+                ret = BigInteger.class;
+                break;
+            case Types.CHAR:
+                ret = String.class;
+                break;
+            case Types.BOOLEAN:
+                ret = Boolean.class;
+                break;
+            case Types.DATE:
+                ret = Date.class;
+                break;
+            case Types.TIMESTAMP:
+                ret = Date.class;
+                break;
+        }
+        if (ret == null) {
+            throw new ParseRuntimeException("Unable to map SQL type " + sqlTypeStr + " to Java type");
+
+        }
+        return ret;
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
new file mode 100644
index 0000000..b3b8fc8
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
@@ -0,0 +1,14 @@
+package org.apache.camel.component.sql.stored.template.ast;
+
+/**
+ * Created by snurmine on 1/3/16.
+ */
+public class ParseRuntimeException extends RuntimeException {
+    public ParseRuntimeException(String message) {
+        super(message);
+    }
+
+    public ParseRuntimeException(Throwable cause) {
+        super(cause);
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
new file mode 100644
index 0000000..b442fde
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
@@ -0,0 +1,43 @@
+package org.apache.camel.component.sql.stored.template.ast;
+
+import java.util.ArrayList;
+import java.util.List;
+
+/**
+ * Root element of Simple Stored Procedure Template AST.
+ */
+public class Template {
+
+    String procedureName;
+
+    List<InputParameter> inputParameterList = new ArrayList<>();
+
+    List<OutParameter> outParameterList = new ArrayList<>();
+
+    public void addParameter(Object parameter) {
+
+        if (parameter instanceof OutParameter) {
+            outParameterList.add((OutParameter) parameter);
+        } else {
+            inputParameterList.add((InputParameter) parameter);
+
+        }
+    }
+
+    public String getProcedureName() {
+        return procedureName;
+    }
+
+    public void setProcedureName(String procedureName) {
+        this.procedureName = procedureName;
+    }
+
+    public List<InputParameter> getInputParameterList() {
+        return inputParameterList;
+    }
+
+    public List<OutParameter> getOutParameterList() {
+        return outParameterList;
+    }
+}
+

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
new file mode 100644
index 0000000..764764c
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
@@ -0,0 +1,136 @@
+//Using some token definions from: http://kiwwito.com/build-a-lexical-analyzer-with-javacc/
+
+options {
+    STATIC = false;
+}
+
+
+PARSER_BEGIN(SSPTParser)
+
+package org.apache.camel.component.sql.stored.template.generated;
+
+import org.apache.camel.component.sql.stored.template.ast.*;
+
+public class SSPTParser {
+   int paramaterNameCounter = 0;
+
+   String createNextParameterName() {
+      return "_"+(paramaterNameCounter++);
+   }
+}
+
+PARSER_END(SSPTParser)
+
+public Template parse() :
+{   Token procudureName;
+    Template template = new Template();
+    Object parameter = null;
+}
+{
+  (procudureName = <IDENTIFIER> "(" (parameter = Parameter() { template.addParameter(parameter);}) (","
+  parameter
+  = Parameter(){template.addParameter(parameter);})*  ")" <EOF>)
+  {
+   template.setProcedureName(procudureName.toString());
+   return template;
+  }
+}
+
+Object Parameter() :
+{
+    Object param;
+}
+{
+     (param = InputParameter() {return param;}) | (param = OutParameter(){return param;})
+}
+
+InputParameter InputParameter() :
+{
+     String sqlTypeAsStr;
+     String name;
+     String valueSrcAsStr;
+}
+{
+    (sqlTypeAsStr = ParameterSqlType() " " valueSrcAsStr =
+    InputParameterSrc())
+    {
+        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
+        return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));
+    }
+}
+
+OutParameter OutParameter() :
+{
+     String sqlType;
+     String name;
+     String outHeader;
+}
+{
+    ("OUT" " " sqlType = ParameterSqlType() " " outHeader =
+    OutHeader())
+    {
+        return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);
+    }
+}
+
+String ParameterSqlType():
+{
+    Token t;
+}
+{
+    (t = <IDENTIFIER>)
+    {
+        return t.toString();
+    }
+}
+
+String OutHeader():
+{
+ Token token;
+}
+{
+    (token = <IDENTIFIER>)
+    {
+        return token.toString();
+    }
+}
+
+String InputParameterSrc():
+{
+    String ret;
+}
+{
+    (ret = SimpleExpression())
+    {
+        return ret;
+    }
+}
+
+String SimpleExpression() :
+{
+ Token t = null;
+}
+{
+    (t = <SIMPLE_EXP_TOKEN>)
+    {
+    return t.toString();
+    }
+}
+
+TOKEN: {
+    <#DIGIT: (["0"-"9"])>
+}
+
+TOKEN: {
+    <#LETTER: (["a"-"z","A"-"Z"])>
+}
+
+TOKEN : {
+    <SIMPLE_EXP_TOKEN: "${"(<LETTER>|<DIGIT> | " " | "'" | "." )* "}">
+}
+
+
+TOKEN : {
+    <IDENTIFIER: <LETTER>( <LETTER> | <DIGIT> | ".") *>
+}
+

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored b/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
new file mode 100644
index 0000000..74e07fd
--- /dev/null
+++ b/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
@@ -0,0 +1 @@
+class=org.apache.camel.component.sql.stored.SqlStoredComponent

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
deleted file mode 100644
index ba36baf..0000000
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ParserTest.java
+++ /dev/null
@@ -1,81 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-
-import org.apache.camel.Exchange;
-import org.apache.camel.component.sql.sspt.ast.InputParameter;
-import org.apache.camel.component.sql.sspt.ast.OutParameter;
-import org.apache.camel.component.sql.sspt.ast.ParseException;
-import org.apache.camel.component.sql.sspt.ast.Template;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.Assert;
-import org.junit.Test;
-
-import java.math.BigInteger;
-import java.sql.Types;
-
-public class ParserTest extends CamelTestSupport {
-
-    SimpleStoredProcedureFactory parser = new SimpleStoredProcedureFactory();
-
-
-    @Test
-    public void shouldParseOk() {
-
-
-        Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1}," +
-                "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
-
-        Assert.assertEquals("addnumbers", template.getProcedureName());
-        Assert.assertEquals(3, template.getInputParameterList().size());
-
-        Exchange exchange = createExchangeWithBody(null);
-        exchange.getIn().setHeader("header1", 1);
-        exchange.setProperty("property1", "constant string");
-        exchange.getIn().setHeader("header2", BigInteger.valueOf(2));
-
-        InputParameter param1 = template.getInputParameterList().get(0);
-        Assert.assertEquals("_0", param1.getName());
-        Assert.assertEquals(Types.INTEGER, param1.getSqlType());
-        Assert.assertEquals(Integer.valueOf(1), param1.getValueExpression().evaluate(exchange, Integer.class));
-
-        InputParameter param2 = template.getInputParameterList().get(1);
-        Assert.assertEquals("_1", param2.getName());
-        Assert.assertEquals(Types.VARCHAR, param2.getSqlType());
-        Assert.assertEquals("constant string", param2.getValueExpression().evaluate(exchange, String.class));
-
-        InputParameter param3 = template.getInputParameterList().get(2);
-        Assert.assertEquals("_2", param3.getName());
-        Assert.assertEquals(Types.BIGINT, param3.getSqlType());
-        Assert.assertEquals(BigInteger.valueOf(2), param3.getValueExpression().evaluate(exchange, BigInteger.class));
-
-        OutParameter sptpOutputNode = template.getOutParameterList().get(0);
-        Assert.assertEquals("_3", sptpOutputNode.getName());
-        Assert.assertEquals(Types.INTEGER, sptpOutputNode.getSqlType());
-        Assert.assertEquals("header1", sptpOutputNode.getOutHeader());
-
-    }
-
-
-    @Test(expected = ParseException.class)
-    public void noOutputParameterShouldFail() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(INTEGER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
-
-    }
-
-    @Test(expected = ParseException.class)
-    public void unexistingTypeShouldFail() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
-
-    }
-
-
-    @Test(expected = ParseException.class)
-    public void unmappedTypeShouldFaild() {
-        parser.parseTemplate("ADDNUMBERS2" +
-                "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
-
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
deleted file mode 100644
index d00108c..0000000
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/ProducerTest.java
+++ /dev/null
@@ -1,72 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-import org.apache.camel.Exchange;
-import org.apache.camel.builder.RouteBuilder;
-import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.sql.SqlComponent;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.After;
-import org.junit.Before;
-import org.junit.Test;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
-
-import java.util.HashMap;
-import java.util.Map;
-
-/**
- * Created by snurmine on 12/30/15.
- */
-public class ProducerTest extends CamelTestSupport {
-
-
-    private EmbeddedDatabase db;
-
-    @Before
-    public void setUp() throws Exception {
-        db = new EmbeddedDatabaseBuilder()
-                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
-
-        super.setUp();
-    }
-
-    @After
-    public void tearDown() throws Exception {
-        super.tearDown();
-
-        db.shutdown();
-    }
-
-    @Test
-    public void shouldExecuteStoredProcedure() throws InterruptedException {
-        MockEndpoint mock = getMockEndpoint("mock:query");
-        mock.expectedMessageCount(1);
-
-
-        Map<String, Object> headers = new HashMap<>();
-        headers.put("num1", 1);
-        headers.put("num2", 2);
-        template.requestBodyAndHeaders("direct:query", null, headers);
-
-        assertMockEndpointsSatisfied();
-
-        Exchange exchange = mock.getExchanges().get(0);
-
-        assertEquals(Integer.valueOf(3), exchange.getIn().getHeader("resultofsum"));
-    }
-
-    @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
-        return new RouteBuilder() {
-            @Override
-            public void configure() throws Exception {
-                // required for the sql component
-                getContext().getComponent("sql", SqlComponent.class).setDataSource(db);
-
-                from("direct:query").to("sql:sspt:ADDNUMBERS(INTEGER ${headers.num1},INTEGER ${headers"
-                        + ".num2},OUT INTEGER resultofsum)").to("mock:query");
-            }
-        };
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
deleted file mode 100644
index 5fc4fef..0000000
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureTest.java
+++ /dev/null
@@ -1,57 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-
-import org.apache.camel.Exchange;
-import org.apache.camel.component.sql.sspt.ast.ParseException;
-import org.apache.camel.test.junit4.CamelTestSupport;
-import org.junit.After;
-import org.junit.Assert;
-import org.junit.Before;
-import org.junit.Test;
-import org.springframework.jdbc.core.JdbcTemplate;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
-import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
-
-public class SimpleStoredProcedureTest extends CamelTestSupport {
-
-    SimpleStoredProcedureFactory parser = new SimpleStoredProcedureFactory();
-
-    private EmbeddedDatabase db;
-    private JdbcTemplate jdbcTemplate;
-
-    @Before
-    public void setUp() throws Exception {
-        db = new EmbeddedDatabaseBuilder()
-                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
-
-        jdbcTemplate = new JdbcTemplate(db);
-
-        super.setUp();
-    }
-
-
-    @Test
-    public void shouldExecuteStoredProcedure() throws ParseException {
-        SimpleStoredProcedure sp = new SimpleStoredProcedure(db, parser.parseTemplate("ADDNUMBERS" +
-                "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
-
-        Exchange exchange = createExchangeWithBody(null);
-        exchange.getIn().setHeader("v1", 1);
-        exchange.getIn().setHeader("v2", 2);
-
-
-        sp.execute(exchange);
-
-        Assert.assertEquals(Integer.valueOf(3), exchange.getOut().getHeader("resultofsum"));
-
-
-    }
-
-    @After
-    public void tearDown() throws Exception {
-        super.tearDown();
-
-        db.shutdown();
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
deleted file mode 100644
index f88ebd4..0000000
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/sspt/SimpleStoredProcedureUdf.java
+++ /dev/null
@@ -1,15 +0,0 @@
-package org.apache.camel.component.sql.sspt;
-
-/**
- * Created by snurmine on 12/20/15.
- */
-public class SimpleStoredProcedureUdf {
-
-    public static void addnumbers(int VALUE1, int VALUE2, int[] RESULT) {
-        System.out.println("calling addnumbers:" + VALUE1 + "," + VALUE2);
-
-        RESULT[0] = VALUE1 + VALUE2;
-
-
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
new file mode 100644
index 0000000..81b6b5a
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
@@ -0,0 +1,83 @@
+package org.apache.camel.component.sql.stored;
+
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.stored.template.ast.InputParameter;
+import org.apache.camel.component.sql.stored.template.ast.OutParameter;
+import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
+import org.apache.camel.component.sql.stored.template.ast.Template;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
+import org.apache.camel.component.sql.stored.template.generated.ParseException;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.Assert;
+import org.junit.Test;
+
+import java.math.BigInteger;
+import java.sql.Types;
+
+public class ParserTest extends CamelTestSupport {
+
+    TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory();
+
+
+    @Test
+    public void shouldParseOk() {
+
+
+        Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1}," +
+                "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
+
+        Assert.assertEquals("addnumbers", template.getProcedureName());
+        Assert.assertEquals(3, template.getInputParameterList().size());
+
+        Exchange exchange = createExchangeWithBody(null);
+        exchange.getIn().setHeader("header1", 1);
+        exchange.setProperty("property1", "constant string");
+        exchange.getIn().setHeader("header2", BigInteger.valueOf(2));
+
+        InputParameter param1 = template.getInputParameterList().get(0);
+        Assert.assertEquals("_0", param1.getName());
+        Assert.assertEquals(Types.INTEGER, param1.getSqlType());
+        Assert.assertEquals(Integer.valueOf(1), param1.getValueExpression().evaluate(exchange, Integer.class));
+
+        InputParameter param2 = template.getInputParameterList().get(1);
+        Assert.assertEquals("_1", param2.getName());
+        Assert.assertEquals(Types.VARCHAR, param2.getSqlType());
+        Assert.assertEquals("constant string", param2.getValueExpression().evaluate(exchange, String.class));
+
+        InputParameter param3 = template.getInputParameterList().get(2);
+        Assert.assertEquals("_2", param3.getName());
+        Assert.assertEquals(Types.BIGINT, param3.getSqlType());
+        Assert.assertEquals(BigInteger.valueOf(2), param3.getValueExpression().evaluate(exchange, BigInteger.class));
+
+        OutParameter sptpOutputNode = template.getOutParameterList().get(0);
+        Assert.assertEquals("_3", sptpOutputNode.getName());
+        Assert.assertEquals(Types.INTEGER, sptpOutputNode.getSqlType());
+        Assert.assertEquals("header1", sptpOutputNode.getOutHeader());
+
+    }
+
+
+    @Test(expected = ParseRuntimeException.class)
+    public void noOutputParameterShouldFail() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(INTEGER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+
+    }
+
+    @Test(expected = ParseRuntimeException.class)
+    public void unexistingTypeShouldFail() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
+
+    }
+
+
+    @Test(expected = ParseRuntimeException.class)
+    public void unmappedTypeShouldFaild() {
+        parser.parseTemplate("ADDNUMBERS2" +
+                "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
+
+    }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
new file mode 100644
index 0000000..969bca1
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
@@ -0,0 +1,72 @@
+package org.apache.camel.component.sql.stored;
+
+import org.apache.camel.Exchange;
+import org.apache.camel.builder.RouteBuilder;
+import org.apache.camel.component.mock.MockEndpoint;
+import org.apache.camel.component.sql.SqlComponent;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.After;
+import org.junit.Before;
+import org.junit.Test;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
+
+import java.util.HashMap;
+import java.util.Map;
+
+/**
+ * Created by snurmine on 12/30/15.
+ */
+public class ProducerTest extends CamelTestSupport {
+
+
+    private EmbeddedDatabase db;
+
+    @Before
+    public void setUp() throws Exception {
+        db = new EmbeddedDatabaseBuilder()
+                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
+
+        super.setUp();
+    }
+
+    @After
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        db.shutdown();
+    }
+
+    @Test
+    public void shouldExecuteStoredProcedure() throws InterruptedException {
+        MockEndpoint mock = getMockEndpoint("mock:query");
+        mock.expectedMessageCount(1);
+
+
+        Map<String, Object> headers = new HashMap<>();
+        headers.put("num1", 1);
+        headers.put("num2", 2);
+        template.requestBodyAndHeaders("direct:query", null, headers);
+
+        assertMockEndpointsSatisfied();
+
+        Exchange exchange = mock.getExchanges().get(0);
+
+        assertEquals(Integer.valueOf(3), exchange.getIn().getHeader("resultofsum"));
+    }
+
+    @Override
+    protected RouteBuilder createRouteBuilder() throws Exception {
+        return new RouteBuilder() {
+            @Override
+            public void configure() throws Exception {
+                // required for the sql component
+                getContext().getComponent("sql-stored", SqlStoredComponent.class).setDataSource(db);
+
+                from("direct:query").to("sql-stored:ADDNUMBERS(INTEGER ${headers.num1},INTEGER ${headers"
+                        + ".num2},OUT INTEGER resultofsum)").to("mock:query");
+            }
+        };
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
new file mode 100644
index 0000000..2802b70
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
@@ -0,0 +1,15 @@
+package org.apache.camel.component.sql.stored;
+
+/**
+ * Created by snurmine on 12/20/15.
+ */
+public class SimpleStoredProcedureUdf {
+
+    public static void addnumbers(int VALUE1, int VALUE2, int[] RESULT) {
+        System.out.println("calling addnumbers:" + VALUE1 + "," + VALUE2);
+
+        RESULT[0] = VALUE1 + VALUE2;
+
+
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
new file mode 100644
index 0000000..752dcaa
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
@@ -0,0 +1,58 @@
+package org.apache.camel.component.sql.stored;
+
+
+import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedure;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
+import org.apache.camel.test.junit4.CamelTestSupport;
+import org.junit.After;
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+import org.springframework.jdbc.core.JdbcTemplate;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
+import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
+
+public class TemplateStoredProcedureTest extends CamelTestSupport {
+
+    TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory();
+
+    private EmbeddedDatabase db;
+    private JdbcTemplate jdbcTemplate;
+
+    @Before
+    public void setUp() throws Exception {
+        db = new EmbeddedDatabaseBuilder()
+                .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
+
+        jdbcTemplate = new JdbcTemplate(db);
+
+        super.setUp();
+    }
+
+
+    @Test
+    public void shouldExecuteStoredProcedure()  {
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(db, parser.parseTemplate("ADDNUMBERS" +
+                "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
+
+        Exchange exchange = createExchangeWithBody(null);
+        exchange.getIn().setHeader("v1", 1);
+        exchange.getIn().setHeader("v2", 2);
+
+
+        sp.execute(exchange);
+
+        Assert.assertEquals(Integer.valueOf(3), exchange.getOut().getHeader("resultofsum"));
+
+
+    }
+
+    @After
+    public void tearDown() throws Exception {
+        super.tearDown();
+
+        db.shutdown();
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/3ee2bb46/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
index edee883..3f6ed74 100644
--- a/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
+++ b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
@@ -19,4 +19,4 @@ CREATE PROCEDURE ADDNUMBERS(VALUE1 INTEGER, VALUE2 INTEGER,OUT RESULT INTEGER)
  PARAMETER STYLE JAVA
  LANGUAGE JAVA
  EXTERNAL NAME
-'org.apache.camel.component.sql.sspt.SimpleStoredProcedureUdf.addnumbers';
\ No newline at end of file
+'org.apache.camel.component.sql.stored.SimpleStoredProcedureUdf.addnumbers';
\ No newline at end of file


[8/9] camel git commit: CAMEL-4725: Polished

Posted by da...@apache.org.
CAMEL-4725: Polished


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/83ef4e62
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/83ef4e62
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/83ef4e62

Branch: refs/heads/master
Commit: 83ef4e62aa49564ef977c6acc69fe49947a1dafa
Parents: b240b3e
Author: Claus Ibsen <da...@apache.org>
Authored: Sat Jan 9 11:27:36 2016 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 11:27:36 2016 +0100

----------------------------------------------------------------------
 components/camel-sql/pom.xml                    |  27 +-
 .../template/generated/ParseException.java      | 187 ++++++++
 .../stored/template/generated/SSPTParser.java   | 290 ++++++++++++
 .../template/generated/SSPTParserConstants.java |  39 ++
 .../generated/SSPTParserTokenManager.java       | 366 ++++++++++++++
 .../template/generated/SimpleCharStream.java    | 471 +++++++++++++++++++
 .../sql/stored/template/generated/Token.java    | 131 ++++++
 .../template/generated/TokenMgrError.java       | 147 ++++++
 .../sql/stored/template/grammar/sspt.jj         |  18 +-
 .../org/apache/camel/component/sql-stored       |  17 +
 parent/pom.xml                                  |   1 +
 11 files changed, 1682 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/pom.xml
----------------------------------------------------------------------
diff --git a/components/camel-sql/pom.xml b/components/camel-sql/pom.xml
index 99f04a0..6c24876 100644
--- a/components/camel-sql/pom.xml
+++ b/components/camel-sql/pom.xml
@@ -42,10 +42,14 @@
       ${camel.osgi.import.defaults},
       *
     </camel.osgi.import.pkg>
-    <camel.osgi.export.service>org.apache.camel.spi.ComponentResolver;component=sql</camel.osgi.export.service>
+    <camel.osgi.export.service>
+      org.apache.camel.spi.ComponentResolver;component=sql,
+      org.apache.camel.spi.ComponentResolver;component=sql-stored
+    </camel.osgi.export.service>
   </properties>
 
   <dependencies>
+
     <dependency>
       <groupId>org.apache.camel</groupId>
       <artifactId>camel-core</artifactId>
@@ -90,18 +94,12 @@
 
   <build>
     <plugins>
-      <!-- use per test fork mode to avoid side effects -->
-      <plugin>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <configuration>
-          <forkCount>1</forkCount>
-	  <reuseForks>false</reuseForks>
-        </configuration>
-      </plugin>
 
+      <!-- generate source code from grammar for the stored procedure component -->
       <plugin>
         <groupId>org.codehaus.mojo</groupId>
         <artifactId>javacc-maven-plugin</artifactId>
+        <version>${javacc-maven-plugin-version}</version>
         <executions>
           <execution>
             <phase>generate-sources</phase>
@@ -114,11 +112,18 @@
             </goals>
           </execution>
         </executions>
-        <version>2.6</version>
       </plugin>
 
-
+      <!-- use per test fork mode to avoid side effects -->
+      <plugin>
+        <artifactId>maven-surefire-plugin</artifactId>
+        <configuration>
+          <forkCount>1</forkCount>
+          <reuseForks>false</reuseForks>
+        </configuration>
+      </plugin>
 
     </plugins>
   </build>
+
 </project>

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/ParseException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/ParseException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/ParseException.java
new file mode 100644
index 0000000..30e4737
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/ParseException.java
@@ -0,0 +1,187 @@
+/* Generated By:JavaCC: Do not edit this line. ParseException.java Version 5.0 */
+/* JavaCCOptions:KEEP_LINE_COL=null */
+package org.apache.camel.component.sql.stored.template.generated;
+
+/**
+ * This exception is thrown when parse errors are encountered.
+ * You can explicitly create objects of this exception type by
+ * calling the method generateParseException in the generated
+ * parser.
+ *
+ * You can modify this class to customize your error reporting
+ * mechanisms so long as you retain the public fields.
+ */
+public class ParseException extends Exception {
+
+  /**
+   * The version identifier for this Serializable class.
+   * Increment only if the <i>serialized</i> form of the
+   * class changes.
+   */
+  private static final long serialVersionUID = 1L;
+
+  /**
+   * This constructor is used by the method "generateParseException"
+   * in the generated parser.  Calling this constructor generates
+   * a new object of this type with the fields "currentToken",
+   * "expectedTokenSequences", and "tokenImage" set.
+   */
+  public ParseException(Token currentTokenVal,
+                        int[][] expectedTokenSequencesVal,
+                        String[] tokenImageVal
+                       )
+  {
+    super(initialise(currentTokenVal, expectedTokenSequencesVal, tokenImageVal));
+    currentToken = currentTokenVal;
+    expectedTokenSequences = expectedTokenSequencesVal;
+    tokenImage = tokenImageVal;
+  }
+
+  /**
+   * The following constructors are for use by you for whatever
+   * purpose you can think of.  Constructing the exception in this
+   * manner makes the exception behave in the normal way - i.e., as
+   * documented in the class "Throwable".  The fields "errorToken",
+   * "expectedTokenSequences", and "tokenImage" do not contain
+   * relevant information.  The JavaCC generated code does not use
+   * these constructors.
+   */
+
+  public ParseException() {
+    super();
+  }
+
+  /** Constructor with message. */
+  public ParseException(String message) {
+    super(message);
+  }
+
+
+  /**
+   * This is the last token that has been consumed successfully.  If
+   * this object has been created due to a parse error, the token
+   * followng this token will (therefore) be the first error token.
+   */
+  public Token currentToken;
+
+  /**
+   * Each entry in this array is an array of integers.  Each array
+   * of integers represents a sequence of tokens (by their ordinal
+   * values) that is expected at this point of the parse.
+   */
+  public int[][] expectedTokenSequences;
+
+  /**
+   * This is a reference to the "tokenImage" array of the generated
+   * parser within which the parse error occurred.  This array is
+   * defined in the generated ...Constants interface.
+   */
+  public String[] tokenImage;
+
+  /**
+   * It uses "currentToken" and "expectedTokenSequences" to generate a parse
+   * error message and returns it.  If this object has been created
+   * due to a parse error, and you do not catch it (it gets thrown
+   * from the parser) the correct error message
+   * gets displayed.
+   */
+  private static String initialise(Token currentToken,
+                           int[][] expectedTokenSequences,
+                           String[] tokenImage) {
+    String eol = System.getProperty("line.separator", "\n");
+    StringBuffer expected = new StringBuffer();
+    int maxSize = 0;
+    for (int i = 0; i < expectedTokenSequences.length; i++) {
+      if (maxSize < expectedTokenSequences[i].length) {
+        maxSize = expectedTokenSequences[i].length;
+      }
+      for (int j = 0; j < expectedTokenSequences[i].length; j++) {
+        expected.append(tokenImage[expectedTokenSequences[i][j]]).append(' ');
+      }
+      if (expectedTokenSequences[i][expectedTokenSequences[i].length - 1] != 0) {
+        expected.append("...");
+      }
+      expected.append(eol).append("    ");
+    }
+    String retval = "Encountered \"";
+    Token tok = currentToken.next;
+    for (int i = 0; i < maxSize; i++) {
+      if (i != 0) retval += " ";
+      if (tok.kind == 0) {
+        retval += tokenImage[0];
+        break;
+      }
+      retval += " " + tokenImage[tok.kind];
+      retval += " \"";
+      retval += add_escapes(tok.image);
+      retval += " \"";
+      tok = tok.next;
+    }
+    retval += "\" at line " + currentToken.next.beginLine + ", column " + currentToken.next.beginColumn;
+    retval += "." + eol;
+    if (expectedTokenSequences.length == 1) {
+      retval += "Was expecting:" + eol + "    ";
+    } else {
+      retval += "Was expecting one of:" + eol + "    ";
+    }
+    retval += expected.toString();
+    return retval;
+  }
+
+  /**
+   * The end of line string for this machine.
+   */
+  protected String eol = System.getProperty("line.separator", "\n");
+
+  /**
+   * Used to convert raw characters to their escaped version
+   * when these raw version cannot be used as part of an ASCII
+   * string literal.
+   */
+  static String add_escapes(String str) {
+      StringBuffer retval = new StringBuffer();
+      char ch;
+      for (int i = 0; i < str.length(); i++) {
+        switch (str.charAt(i))
+        {
+           case 0 :
+              continue;
+           case '\b':
+              retval.append("\\b");
+              continue;
+           case '\t':
+              retval.append("\\t");
+              continue;
+           case '\n':
+              retval.append("\\n");
+              continue;
+           case '\f':
+              retval.append("\\f");
+              continue;
+           case '\r':
+              retval.append("\\r");
+              continue;
+           case '\"':
+              retval.append("\\\"");
+              continue;
+           case '\'':
+              retval.append("\\\'");
+              continue;
+           case '\\':
+              retval.append("\\\\");
+              continue;
+           default:
+              if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
+                 String s = "0000" + Integer.toString(ch, 16);
+                 retval.append("\\u" + s.substring(s.length() - 4, s.length()));
+              } else {
+                 retval.append(ch);
+              }
+              continue;
+        }
+      }
+      return retval.toString();
+   }
+
+}
+/* JavaCC - OriginalChecksum=5189b93605d5a3d3833ed059f46e94c9 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParser.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParser.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParser.java
new file mode 100644
index 0000000..b1e488c
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParser.java
@@ -0,0 +1,290 @@
+/* Generated By:JavaCC: Do not edit this line. SSPTParser.java */
+package org.apache.camel.component.sql.stored.template.generated;
+
+import org.apache.camel.component.sql.stored.template.ast.*;
+
+public class SSPTParser implements SSPTParserConstants {
+   int paramaterNameCounter = 0;
+
+   String createNextParameterName() {
+      return "_"+(paramaterNameCounter++);
+   }
+
+  final public Template parse() throws ParseException {
+    Token procudureName;
+    Template template = new Template();
+    Object parameter = null;
+    procudureName = jj_consume_token(IDENTIFIER);
+    jj_consume_token(1);
+    switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
+    case 5:
+    case IDENTIFIER:
+      parameter = Parameter();
+                                                                 template.addParameter(parameter);
+      label_1:
+      while (true) {
+        switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
+        case 2:
+          ;
+          break;
+        default:
+          jj_la1[0] = jj_gen;
+          break label_1;
+        }
+        jj_consume_token(2);
+        parameter = Parameter();
+                template.addParameter(parameter);
+      }
+      break;
+    default:
+      jj_la1[1] = jj_gen;
+      ;
+    }
+    jj_consume_token(3);
+    jj_consume_token(0);
+   template.setProcedureName(procudureName.toString());
+   {if (true) return template;}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public Object Parameter() throws ParseException {
+    Object param;
+    switch ((jj_ntk==-1)?jj_ntk():jj_ntk) {
+    case IDENTIFIER:
+      param = InputParameter();
+                                {if (true) return param;}
+      break;
+    case 5:
+      param = OutParameter();
+                                                                          {if (true) return param;}
+      break;
+    default:
+      jj_la1[2] = jj_gen;
+      jj_consume_token(-1);
+      throw new ParseException();
+    }
+    throw new Error("Missing return statement in function");
+  }
+
+  final public InputParameter InputParameter() throws ParseException {
+     String sqlTypeAsStr;
+     String name;
+     String valueSrcAsStr;
+    sqlTypeAsStr = ParameterSqlType();
+    jj_consume_token(4);
+    valueSrcAsStr = InputParameterSrc();
+        int sqlType = ParseHelper.parseSqlType(sqlTypeAsStr);
+        {if (true) return new InputParameter(createNextParameterName(),sqlType,valueSrcAsStr,ParseHelper.sqlTypeToJavaType(sqlType,sqlTypeAsStr));}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public OutParameter OutParameter() throws ParseException {
+     String sqlType;
+     String name;
+     String outHeader;
+    jj_consume_token(5);
+    jj_consume_token(4);
+    sqlType = ParameterSqlType();
+    jj_consume_token(4);
+    outHeader = OutHeader();
+        {if (true) return new OutParameter(createNextParameterName(),ParseHelper.parseSqlType(sqlType),outHeader);}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String ParameterSqlType() throws ParseException {
+    Token t;
+    t = jj_consume_token(IDENTIFIER);
+        {if (true) return t.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String OutHeader() throws ParseException {
+ Token token;
+    token = jj_consume_token(IDENTIFIER);
+        {if (true) return token.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String InputParameterSrc() throws ParseException {
+    String ret;
+    ret = SimpleExpression();
+        {if (true) return ret;}
+    throw new Error("Missing return statement in function");
+  }
+
+  final public String SimpleExpression() throws ParseException {
+ Token t = null;
+    t = jj_consume_token(SIMPLE_EXP_TOKEN);
+    {if (true) return t.toString();}
+    throw new Error("Missing return statement in function");
+  }
+
+  /** Generated Token Manager. */
+  public SSPTParserTokenManager token_source;
+  SimpleCharStream jj_input_stream;
+  /** Current token. */
+  public Token token;
+  /** Next token. */
+  public Token jj_nt;
+  private int jj_ntk;
+  private int jj_gen;
+  final private int[] jj_la1 = new int[3];
+  static private int[] jj_la1_0;
+  static {
+      jj_la1_init_0();
+   }
+   private static void jj_la1_init_0() {
+      jj_la1_0 = new int[] {0x4,0x220,0x220,};
+   }
+
+  /** Constructor with InputStream. */
+  public SSPTParser(java.io.InputStream stream) {
+     this(stream, null);
+  }
+  /** Constructor with InputStream and supplied encoding */
+  public SSPTParser(java.io.InputStream stream, String encoding) {
+    try { jj_input_stream = new SimpleCharStream(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
+    token_source = new SSPTParserTokenManager(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream stream) {
+     ReInit(stream, null);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream stream, String encoding) {
+    try { jj_input_stream.ReInit(stream, encoding, 1, 1); } catch(java.io.UnsupportedEncodingException e) { throw new RuntimeException(e); }
+    token_source.ReInit(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  /** Constructor. */
+  public SSPTParser(java.io.Reader stream) {
+    jj_input_stream = new SimpleCharStream(stream, 1, 1);
+    token_source = new SSPTParserTokenManager(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader stream) {
+    jj_input_stream.ReInit(stream, 1, 1);
+    token_source.ReInit(jj_input_stream);
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  /** Constructor with generated Token Manager. */
+  public SSPTParser(SSPTParserTokenManager tm) {
+    token_source = tm;
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(SSPTParserTokenManager tm) {
+    token_source = tm;
+    token = new Token();
+    jj_ntk = -1;
+    jj_gen = 0;
+    for (int i = 0; i < 3; i++) jj_la1[i] = -1;
+  }
+
+  private Token jj_consume_token(int kind) throws ParseException {
+    Token oldToken;
+    if ((oldToken = token).next != null) token = token.next;
+    else token = token.next = token_source.getNextToken();
+    jj_ntk = -1;
+    if (token.kind == kind) {
+      jj_gen++;
+      return token;
+    }
+    token = oldToken;
+    jj_kind = kind;
+    throw generateParseException();
+  }
+
+
+/** Get the next Token. */
+  final public Token getNextToken() {
+    if (token.next != null) token = token.next;
+    else token = token.next = token_source.getNextToken();
+    jj_ntk = -1;
+    jj_gen++;
+    return token;
+  }
+
+/** Get the specific Token. */
+  final public Token getToken(int index) {
+    Token t = token;
+    for (int i = 0; i < index; i++) {
+      if (t.next != null) t = t.next;
+      else t = t.next = token_source.getNextToken();
+    }
+    return t;
+  }
+
+  private int jj_ntk() {
+    if ((jj_nt=token.next) == null)
+      return (jj_ntk = (token.next=token_source.getNextToken()).kind);
+    else
+      return (jj_ntk = jj_nt.kind);
+  }
+
+  private java.util.List<int[]> jj_expentries = new java.util.ArrayList<int[]>();
+  private int[] jj_expentry;
+  private int jj_kind = -1;
+
+  /** Generate ParseException. */
+  public ParseException generateParseException() {
+    jj_expentries.clear();
+    boolean[] la1tokens = new boolean[10];
+    if (jj_kind >= 0) {
+      la1tokens[jj_kind] = true;
+      jj_kind = -1;
+    }
+    for (int i = 0; i < 3; i++) {
+      if (jj_la1[i] == jj_gen) {
+        for (int j = 0; j < 32; j++) {
+          if ((jj_la1_0[i] & (1<<j)) != 0) {
+            la1tokens[j] = true;
+          }
+        }
+      }
+    }
+    for (int i = 0; i < 10; i++) {
+      if (la1tokens[i]) {
+        jj_expentry = new int[1];
+        jj_expentry[0] = i;
+        jj_expentries.add(jj_expentry);
+      }
+    }
+    int[][] exptokseq = new int[jj_expentries.size()][];
+    for (int i = 0; i < jj_expentries.size(); i++) {
+      exptokseq[i] = jj_expentries.get(i);
+    }
+    return new ParseException(token, exptokseq, tokenImage);
+  }
+
+  /** Enable tracing. */
+  final public void enable_tracing() {
+  }
+
+  /** Disable tracing. */
+  final public void disable_tracing() {
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserConstants.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserConstants.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserConstants.java
new file mode 100644
index 0000000..fe80c22
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserConstants.java
@@ -0,0 +1,39 @@
+/* Generated By:JavaCC: Do not edit this line. SSPTParserConstants.java */
+package org.apache.camel.component.sql.stored.template.generated;
+
+
+/**
+ * Token literal values and constants.
+ * Generated by org.javacc.parser.OtherFilesGen#start()
+ */
+public interface SSPTParserConstants {
+
+  /** End of File. */
+  int EOF = 0;
+  /** RegularExpression Id. */
+  int DIGIT = 6;
+  /** RegularExpression Id. */
+  int LETTER = 7;
+  /** RegularExpression Id. */
+  int SIMPLE_EXP_TOKEN = 8;
+  /** RegularExpression Id. */
+  int IDENTIFIER = 9;
+
+  /** Lexical state. */
+  int DEFAULT = 0;
+
+  /** Literal token values. */
+  String[] tokenImage = {
+    "<EOF>",
+    "\"(\"",
+    "\",\"",
+    "\")\"",
+    "\" \"",
+    "\"OUT\"",
+    "<DIGIT>",
+    "<LETTER>",
+    "<SIMPLE_EXP_TOKEN>",
+    "<IDENTIFIER>",
+  };
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserTokenManager.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserTokenManager.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserTokenManager.java
new file mode 100644
index 0000000..4f76cb9
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SSPTParserTokenManager.java
@@ -0,0 +1,366 @@
+/* Generated By:JavaCC: Do not edit this line. SSPTParserTokenManager.java */
+package org.apache.camel.component.sql.stored.template.generated;
+import org.apache.camel.component.sql.stored.template.ast.*;
+
+/** Token Manager. */
+public class SSPTParserTokenManager implements SSPTParserConstants
+{
+
+  /** Debug output. */
+  public  java.io.PrintStream debugStream = System.out;
+  /** Set debug output. */
+  public  void setDebugStream(java.io.PrintStream ds) { debugStream = ds; }
+private final int jjStopStringLiteralDfa_0(int pos, long active0)
+{
+   switch (pos)
+   {
+      case 0:
+         if ((active0 & 0x20L) != 0L)
+         {
+            jjmatchedKind = 9;
+            return 5;
+         }
+         return -1;
+      case 1:
+         if ((active0 & 0x20L) != 0L)
+         {
+            jjmatchedKind = 9;
+            jjmatchedPos = 1;
+            return 5;
+         }
+         return -1;
+      default :
+         return -1;
+   }
+}
+private final int jjStartNfa_0(int pos, long active0)
+{
+   return jjMoveNfa_0(jjStopStringLiteralDfa_0(pos, active0), pos + 1);
+}
+private int jjStopAtPos(int pos, int kind)
+{
+   jjmatchedKind = kind;
+   jjmatchedPos = pos;
+   return pos + 1;
+}
+private int jjMoveStringLiteralDfa0_0()
+{
+   switch(curChar)
+   {
+      case 32:
+         return jjStopAtPos(0, 4);
+      case 40:
+         return jjStopAtPos(0, 1);
+      case 41:
+         return jjStopAtPos(0, 3);
+      case 44:
+         return jjStopAtPos(0, 2);
+      case 79:
+         return jjMoveStringLiteralDfa1_0(0x20L);
+      default :
+         return jjMoveNfa_0(3, 0);
+   }
+}
+private int jjMoveStringLiteralDfa1_0(long active0)
+{
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) {
+      jjStopStringLiteralDfa_0(0, active0);
+      return 1;
+   }
+   switch(curChar)
+   {
+      case 85:
+         return jjMoveStringLiteralDfa2_0(active0, 0x20L);
+      default :
+         break;
+   }
+   return jjStartNfa_0(0, active0);
+}
+private int jjMoveStringLiteralDfa2_0(long old0, long active0)
+{
+   if (((active0 &= old0)) == 0L)
+      return jjStartNfa_0(0, old0);
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) {
+      jjStopStringLiteralDfa_0(1, active0);
+      return 2;
+   }
+   switch(curChar)
+   {
+      case 84:
+         if ((active0 & 0x20L) != 0L)
+            return jjStartNfaWithStates_0(2, 5, 5);
+         break;
+      default :
+         break;
+   }
+   return jjStartNfa_0(1, active0);
+}
+private int jjStartNfaWithStates_0(int pos, int kind, int state)
+{
+   jjmatchedKind = kind;
+   jjmatchedPos = pos;
+   try { curChar = input_stream.readChar(); }
+   catch(java.io.IOException e) { return pos + 1; }
+   return jjMoveNfa_0(state, pos + 1);
+}
+private int jjMoveNfa_0(int startState, int curPos)
+{
+   int startsAt = 0;
+   jjnewStateCnt = 6;
+   int i = 1;
+   jjstateSet[0] = startState;
+   int kind = 0x7fffffff;
+   for (;;)
+   {
+      if (++jjround == 0x7fffffff)
+         ReInitRounds();
+      if (curChar < 64)
+      {
+         long l = 1L << curChar;
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               case 3:
+                  if (curChar == 36)
+                     jjstateSet[jjnewStateCnt++] = 0;
+                  break;
+               case 1:
+                  if ((0x3ff408100000000L & l) != 0L)
+                     jjAddStates(0, 1);
+                  break;
+               case 5:
+                  if ((0x3ff400000000000L & l) == 0L)
+                     break;
+                  if (kind > 9)
+                     kind = 9;
+                  jjstateSet[jjnewStateCnt++] = 5;
+                  break;
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      else if (curChar < 128)
+      {
+         long l = 1L << (curChar & 077);
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               case 3:
+               case 5:
+                  if ((0x7fffffe07fffffeL & l) == 0L)
+                     break;
+                  if (kind > 9)
+                     kind = 9;
+                  jjCheckNAdd(5);
+                  break;
+               case 0:
+                  if (curChar == 123)
+                     jjCheckNAddTwoStates(1, 2);
+                  break;
+               case 1:
+                  if ((0x7fffffe07fffffeL & l) != 0L)
+                     jjCheckNAddTwoStates(1, 2);
+                  break;
+               case 2:
+                  if (curChar == 125)
+                     kind = 8;
+                  break;
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      else
+      {
+         int i2 = (curChar & 0xff) >> 6;
+         long l2 = 1L << (curChar & 077);
+         do
+         {
+            switch(jjstateSet[--i])
+            {
+               default : break;
+            }
+         } while(i != startsAt);
+      }
+      if (kind != 0x7fffffff)
+      {
+         jjmatchedKind = kind;
+         jjmatchedPos = curPos;
+         kind = 0x7fffffff;
+      }
+      ++curPos;
+      if ((i = jjnewStateCnt) == (startsAt = 6 - (jjnewStateCnt = startsAt)))
+         return curPos;
+      try { curChar = input_stream.readChar(); }
+      catch(java.io.IOException e) { return curPos; }
+   }
+}
+static final int[] jjnextStates = {
+   1, 2, 
+};
+
+/** Token literal values. */
+public static final String[] jjstrLiteralImages = {
+"", "\50", "\54", "\51", "\40", "\117\125\124", null, null, null, null, };
+
+/** Lexer state names. */
+public static final String[] lexStateNames = {
+   "DEFAULT",
+};
+protected SimpleCharStream input_stream;
+private final int[] jjrounds = new int[6];
+private final int[] jjstateSet = new int[12];
+protected char curChar;
+/** Constructor. */
+public SSPTParserTokenManager(SimpleCharStream stream){
+   if (SimpleCharStream.staticFlag)
+      throw new Error("ERROR: Cannot use a static CharStream class with a non-static lexical analyzer.");
+   input_stream = stream;
+}
+
+/** Constructor. */
+public SSPTParserTokenManager(SimpleCharStream stream, int lexState){
+   this(stream);
+   SwitchTo(lexState);
+}
+
+/** Reinitialise parser. */
+public void ReInit(SimpleCharStream stream)
+{
+   jjmatchedPos = jjnewStateCnt = 0;
+   curLexState = defaultLexState;
+   input_stream = stream;
+   ReInitRounds();
+}
+private void ReInitRounds()
+{
+   int i;
+   jjround = 0x80000001;
+   for (i = 6; i-- > 0;)
+      jjrounds[i] = 0x80000000;
+}
+
+/** Reinitialise parser. */
+public void ReInit(SimpleCharStream stream, int lexState)
+{
+   ReInit(stream);
+   SwitchTo(lexState);
+}
+
+/** Switch to specified lex state. */
+public void SwitchTo(int lexState)
+{
+   if (lexState >= 1 || lexState < 0)
+      throw new TokenMgrError("Error: Ignoring invalid lexical state : " + lexState + ". State unchanged.", TokenMgrError.INVALID_LEXICAL_STATE);
+   else
+      curLexState = lexState;
+}
+
+protected Token jjFillToken()
+{
+   final Token t;
+   final String curTokenImage;
+   final int beginLine;
+   final int endLine;
+   final int beginColumn;
+   final int endColumn;
+   String im = jjstrLiteralImages[jjmatchedKind];
+   curTokenImage = (im == null) ? input_stream.GetImage() : im;
+   beginLine = input_stream.getBeginLine();
+   beginColumn = input_stream.getBeginColumn();
+   endLine = input_stream.getEndLine();
+   endColumn = input_stream.getEndColumn();
+   t = Token.newToken(jjmatchedKind, curTokenImage);
+
+   t.beginLine = beginLine;
+   t.endLine = endLine;
+   t.beginColumn = beginColumn;
+   t.endColumn = endColumn;
+
+   return t;
+}
+
+int curLexState = 0;
+int defaultLexState = 0;
+int jjnewStateCnt;
+int jjround;
+int jjmatchedPos;
+int jjmatchedKind;
+
+/** Get the next Token. */
+public Token getNextToken() 
+{
+  Token matchedToken;
+  int curPos = 0;
+
+  EOFLoop :
+  for (;;)
+  {
+   try
+   {
+      curChar = input_stream.BeginToken();
+   }
+   catch(java.io.IOException e)
+   {
+      jjmatchedKind = 0;
+      matchedToken = jjFillToken();
+      return matchedToken;
+   }
+
+   jjmatchedKind = 0x7fffffff;
+   jjmatchedPos = 0;
+   curPos = jjMoveStringLiteralDfa0_0();
+   if (jjmatchedKind != 0x7fffffff)
+   {
+      if (jjmatchedPos + 1 < curPos)
+         input_stream.backup(curPos - jjmatchedPos - 1);
+         matchedToken = jjFillToken();
+         return matchedToken;
+   }
+   int error_line = input_stream.getEndLine();
+   int error_column = input_stream.getEndColumn();
+   String error_after = null;
+   boolean EOFSeen = false;
+   try { input_stream.readChar(); input_stream.backup(1); }
+   catch (java.io.IOException e1) {
+      EOFSeen = true;
+      error_after = curPos <= 1 ? "" : input_stream.GetImage();
+      if (curChar == '\n' || curChar == '\r') {
+         error_line++;
+         error_column = 0;
+      }
+      else
+         error_column++;
+   }
+   if (!EOFSeen) {
+      input_stream.backup(1);
+      error_after = curPos <= 1 ? "" : input_stream.GetImage();
+   }
+   throw new TokenMgrError(EOFSeen, curLexState, error_line, error_column, error_after, curChar, TokenMgrError.LEXICAL_ERROR);
+  }
+}
+
+private void jjCheckNAdd(int state)
+{
+   if (jjrounds[state] != jjround)
+   {
+      jjstateSet[jjnewStateCnt++] = state;
+      jjrounds[state] = jjround;
+   }
+}
+private void jjAddStates(int start, int end)
+{
+   do {
+      jjstateSet[jjnewStateCnt++] = jjnextStates[start];
+   } while (start++ != end);
+}
+private void jjCheckNAddTwoStates(int state1, int state2)
+{
+   jjCheckNAdd(state1);
+   jjCheckNAdd(state2);
+}
+
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SimpleCharStream.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SimpleCharStream.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SimpleCharStream.java
new file mode 100644
index 0000000..38d998e
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/SimpleCharStream.java
@@ -0,0 +1,471 @@
+/* Generated By:JavaCC: Do not edit this line. SimpleCharStream.java Version 5.0 */
+/* JavaCCOptions:STATIC=false,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
+package org.apache.camel.component.sql.stored.template.generated;
+
+/**
+ * An implementation of interface CharStream, where the stream is assumed to
+ * contain only ASCII characters (without unicode processing).
+ */
+
+public class SimpleCharStream
+{
+/** Whether parser is static. */
+  public static final boolean staticFlag = false;
+  int bufsize;
+  int available;
+  int tokenBegin;
+/** Position in buffer. */
+  public int bufpos = -1;
+  protected int bufline[];
+  protected int bufcolumn[];
+
+  protected int column = 0;
+  protected int line = 1;
+
+  protected boolean prevCharIsCR = false;
+  protected boolean prevCharIsLF = false;
+
+  protected java.io.Reader inputStream;
+
+  protected char[] buffer;
+  protected int maxNextCharInd = 0;
+  protected int inBuf = 0;
+  protected int tabSize = 8;
+
+  protected void setTabSize(int i) { tabSize = i; }
+  protected int getTabSize(int i) { return tabSize; }
+
+
+  protected void ExpandBuff(boolean wrapAround)
+  {
+    char[] newbuffer = new char[bufsize + 2048];
+    int newbufline[] = new int[bufsize + 2048];
+    int newbufcolumn[] = new int[bufsize + 2048];
+
+    try
+    {
+      if (wrapAround)
+      {
+        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
+        System.arraycopy(buffer, 0, newbuffer, bufsize - tokenBegin, bufpos);
+        buffer = newbuffer;
+
+        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
+        System.arraycopy(bufline, 0, newbufline, bufsize - tokenBegin, bufpos);
+        bufline = newbufline;
+
+        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
+        System.arraycopy(bufcolumn, 0, newbufcolumn, bufsize - tokenBegin, bufpos);
+        bufcolumn = newbufcolumn;
+
+        maxNextCharInd = (bufpos += (bufsize - tokenBegin));
+      }
+      else
+      {
+        System.arraycopy(buffer, tokenBegin, newbuffer, 0, bufsize - tokenBegin);
+        buffer = newbuffer;
+
+        System.arraycopy(bufline, tokenBegin, newbufline, 0, bufsize - tokenBegin);
+        bufline = newbufline;
+
+        System.arraycopy(bufcolumn, tokenBegin, newbufcolumn, 0, bufsize - tokenBegin);
+        bufcolumn = newbufcolumn;
+
+        maxNextCharInd = (bufpos -= tokenBegin);
+      }
+    }
+    catch (Throwable t)
+    {
+      throw new Error(t.getMessage());
+    }
+
+
+    bufsize += 2048;
+    available = bufsize;
+    tokenBegin = 0;
+  }
+
+  protected void FillBuff() throws java.io.IOException
+  {
+    if (maxNextCharInd == available)
+    {
+      if (available == bufsize)
+      {
+        if (tokenBegin > 2048)
+        {
+          bufpos = maxNextCharInd = 0;
+          available = tokenBegin;
+        }
+        else if (tokenBegin < 0)
+          bufpos = maxNextCharInd = 0;
+        else
+          ExpandBuff(false);
+      }
+      else if (available > tokenBegin)
+        available = bufsize;
+      else if ((tokenBegin - available) < 2048)
+        ExpandBuff(true);
+      else
+        available = tokenBegin;
+    }
+
+    int i;
+    try {
+      if ((i = inputStream.read(buffer, maxNextCharInd, available - maxNextCharInd)) == -1)
+      {
+        inputStream.close();
+        throw new java.io.IOException();
+      }
+      else
+        maxNextCharInd += i;
+      return;
+    }
+    catch(java.io.IOException e) {
+      --bufpos;
+      backup(0);
+      if (tokenBegin == -1)
+        tokenBegin = bufpos;
+      throw e;
+    }
+  }
+
+/** Start. */
+  public char BeginToken() throws java.io.IOException
+  {
+    tokenBegin = -1;
+    char c = readChar();
+    tokenBegin = bufpos;
+
+    return c;
+  }
+
+  protected void UpdateLineColumn(char c)
+  {
+    column++;
+
+    if (prevCharIsLF)
+    {
+      prevCharIsLF = false;
+      line += (column = 1);
+    }
+    else if (prevCharIsCR)
+    {
+      prevCharIsCR = false;
+      if (c == '\n')
+      {
+        prevCharIsLF = true;
+      }
+      else
+        line += (column = 1);
+    }
+
+    switch (c)
+    {
+      case '\r' :
+        prevCharIsCR = true;
+        break;
+      case '\n' :
+        prevCharIsLF = true;
+        break;
+      case '\t' :
+        column--;
+        column += (tabSize - (column % tabSize));
+        break;
+      default :
+        break;
+    }
+
+    bufline[bufpos] = line;
+    bufcolumn[bufpos] = column;
+  }
+
+/** Read a character. */
+  public char readChar() throws java.io.IOException
+  {
+    if (inBuf > 0)
+    {
+      --inBuf;
+
+      if (++bufpos == bufsize)
+        bufpos = 0;
+
+      return buffer[bufpos];
+    }
+
+    if (++bufpos >= maxNextCharInd)
+      FillBuff();
+
+    char c = buffer[bufpos];
+
+    UpdateLineColumn(c);
+    return c;
+  }
+
+  @Deprecated
+  /**
+   * @deprecated
+   * @see #getEndColumn
+   */
+
+  public int getColumn() {
+    return bufcolumn[bufpos];
+  }
+
+  @Deprecated
+  /**
+   * @deprecated
+   * @see #getEndLine
+   */
+
+  public int getLine() {
+    return bufline[bufpos];
+  }
+
+  /** Get token end column number. */
+  public int getEndColumn() {
+    return bufcolumn[bufpos];
+  }
+
+  /** Get token end line number. */
+  public int getEndLine() {
+     return bufline[bufpos];
+  }
+
+  /** Get token beginning column number. */
+  public int getBeginColumn() {
+    return bufcolumn[tokenBegin];
+  }
+
+  /** Get token beginning line number. */
+  public int getBeginLine() {
+    return bufline[tokenBegin];
+  }
+
+/** Backup a number of characters. */
+  public void backup(int amount) {
+
+    inBuf += amount;
+    if ((bufpos -= amount) < 0)
+      bufpos += bufsize;
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    inputStream = dstream;
+    line = startline;
+    column = startcolumn - 1;
+
+    available = bufsize = buffersize;
+    buffer = new char[buffersize];
+    bufline = new int[buffersize];
+    bufcolumn = new int[buffersize];
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream, int startline,
+                          int startcolumn)
+  {
+    this(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.Reader dstream)
+  {
+    this(dstream, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    inputStream = dstream;
+    line = startline;
+    column = startcolumn - 1;
+
+    if (buffer == null || buffersize != buffer.length)
+    {
+      available = bufsize = buffersize;
+      buffer = new char[buffersize];
+      bufline = new int[buffersize];
+      bufcolumn = new int[buffersize];
+    }
+    prevCharIsLF = prevCharIsCR = false;
+    tokenBegin = inBuf = maxNextCharInd = 0;
+    bufpos = -1;
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream, int startline,
+                     int startcolumn)
+  {
+    ReInit(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.Reader dstream)
+  {
+    ReInit(dstream, 1, 1, 4096);
+  }
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
+  int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
+  {
+    this(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, int startline,
+  int startcolumn, int buffersize)
+  {
+    this(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding, int startline,
+                          int startcolumn) throws java.io.UnsupportedEncodingException
+  {
+    this(dstream, encoding, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, int startline,
+                          int startcolumn)
+  {
+    this(dstream, startline, startcolumn, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
+  {
+    this(dstream, encoding, 1, 1, 4096);
+  }
+
+  /** Constructor. */
+  public SimpleCharStream(java.io.InputStream dstream)
+  {
+    this(dstream, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
+                          int startcolumn, int buffersize) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(encoding == null ? new java.io.InputStreamReader(dstream) : new java.io.InputStreamReader(dstream, encoding), startline, startcolumn, buffersize);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, int startline,
+                          int startcolumn, int buffersize)
+  {
+    ReInit(new java.io.InputStreamReader(dstream), startline, startcolumn, buffersize);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(dstream, encoding, 1, 1, 4096);
+  }
+
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream)
+  {
+    ReInit(dstream, 1, 1, 4096);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, String encoding, int startline,
+                     int startcolumn) throws java.io.UnsupportedEncodingException
+  {
+    ReInit(dstream, encoding, startline, startcolumn, 4096);
+  }
+  /** Reinitialise. */
+  public void ReInit(java.io.InputStream dstream, int startline,
+                     int startcolumn)
+  {
+    ReInit(dstream, startline, startcolumn, 4096);
+  }
+  /** Get token literal value. */
+  public String GetImage()
+  {
+    if (bufpos >= tokenBegin)
+      return new String(buffer, tokenBegin, bufpos - tokenBegin + 1);
+    else
+      return new String(buffer, tokenBegin, bufsize - tokenBegin) +
+                            new String(buffer, 0, bufpos + 1);
+  }
+
+  /** Get the suffix. */
+  public char[] GetSuffix(int len)
+  {
+    char[] ret = new char[len];
+
+    if ((bufpos + 1) >= len)
+      System.arraycopy(buffer, bufpos - len + 1, ret, 0, len);
+    else
+    {
+      System.arraycopy(buffer, bufsize - (len - bufpos - 1), ret, 0,
+                                                        len - bufpos - 1);
+      System.arraycopy(buffer, 0, ret, len - bufpos - 1, bufpos + 1);
+    }
+
+    return ret;
+  }
+
+  /** Reset buffer when finished. */
+  public void Done()
+  {
+    buffer = null;
+    bufline = null;
+    bufcolumn = null;
+  }
+
+  /**
+   * Method to adjust line and column numbers for the start of a token.
+   */
+  public void adjustBeginLineColumn(int newLine, int newCol)
+  {
+    int start = tokenBegin;
+    int len;
+
+    if (bufpos >= tokenBegin)
+    {
+      len = bufpos - tokenBegin + inBuf + 1;
+    }
+    else
+    {
+      len = bufsize - tokenBegin + bufpos + 1 + inBuf;
+    }
+
+    int i = 0, j = 0, k = 0;
+    int nextColDiff = 0, columnDiff = 0;
+
+    while (i < len && bufline[j = start % bufsize] == bufline[k = ++start % bufsize])
+    {
+      bufline[j] = newLine;
+      nextColDiff = columnDiff + bufcolumn[k] - bufcolumn[j];
+      bufcolumn[j] = newCol + columnDiff;
+      columnDiff = nextColDiff;
+      i++;
+    }
+
+    if (i < len)
+    {
+      bufline[j] = newLine++;
+      bufcolumn[j] = newCol + columnDiff;
+
+      while (i++ < len)
+      {
+        if (bufline[j = start % bufsize] != bufline[++start % bufsize])
+          bufline[j] = newLine++;
+        else
+          bufline[j] = newLine;
+      }
+    }
+
+    line = bufline[j];
+    column = bufcolumn[j];
+  }
+
+}
+/* JavaCC - OriginalChecksum=78e981b5210775b82383fb6e32f1e767 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/Token.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/Token.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/Token.java
new file mode 100644
index 0000000..c2d86e2
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/Token.java
@@ -0,0 +1,131 @@
+/* Generated By:JavaCC: Do not edit this line. Token.java Version 5.0 */
+/* JavaCCOptions:TOKEN_EXTENDS=,KEEP_LINE_COL=null,SUPPORT_CLASS_VISIBILITY_PUBLIC=true */
+package org.apache.camel.component.sql.stored.template.generated;
+
+/**
+ * Describes the input token stream.
+ */
+
+public class Token implements java.io.Serializable {
+
+  /**
+   * The version identifier for this Serializable class.
+   * Increment only if the <i>serialized</i> form of the
+   * class changes.
+   */
+  private static final long serialVersionUID = 1L;
+
+  /**
+   * An integer that describes the kind of this token.  This numbering
+   * system is determined by JavaCCParser, and a table of these numbers is
+   * stored in the file ...Constants.java.
+   */
+  public int kind;
+
+  /** The line number of the first character of this Token. */
+  public int beginLine;
+  /** The column number of the first character of this Token. */
+  public int beginColumn;
+  /** The line number of the last character of this Token. */
+  public int endLine;
+  /** The column number of the last character of this Token. */
+  public int endColumn;
+
+  /**
+   * The string image of the token.
+   */
+  public String image;
+
+  /**
+   * A reference to the next regular (non-special) token from the input
+   * stream.  If this is the last token from the input stream, or if the
+   * token manager has not read tokens beyond this one, this field is
+   * set to null.  This is true only if this token is also a regular
+   * token.  Otherwise, see below for a description of the contents of
+   * this field.
+   */
+  public Token next;
+
+  /**
+   * This field is used to access special tokens that occur prior to this
+   * token, but after the immediately preceding regular (non-special) token.
+   * If there are no such special tokens, this field is set to null.
+   * When there are more than one such special token, this field refers
+   * to the last of these special tokens, which in turn refers to the next
+   * previous special token through its specialToken field, and so on
+   * until the first special token (whose specialToken field is null).
+   * The next fields of special tokens refer to other special tokens that
+   * immediately follow it (without an intervening regular token).  If there
+   * is no such token, this field is null.
+   */
+  public Token specialToken;
+
+  /**
+   * An optional attribute value of the Token.
+   * Tokens which are not used as syntactic sugar will often contain
+   * meaningful values that will be used later on by the compiler or
+   * interpreter. This attribute value is often different from the image.
+   * Any subclass of Token that actually wants to return a non-null value can
+   * override this method as appropriate.
+   */
+  public Object getValue() {
+    return null;
+  }
+
+  /**
+   * No-argument constructor
+   */
+  public Token() {}
+
+  /**
+   * Constructs a new token for the specified Image.
+   */
+  public Token(int kind)
+  {
+    this(kind, null);
+  }
+
+  /**
+   * Constructs a new token for the specified Image and Kind.
+   */
+  public Token(int kind, String image)
+  {
+    this.kind = kind;
+    this.image = image;
+  }
+
+  /**
+   * Returns the image.
+   */
+  public String toString()
+  {
+    return image;
+  }
+
+  /**
+   * Returns a new Token object, by default. However, if you want, you
+   * can create and return subclass objects based on the value of ofKind.
+   * Simply add the cases to the switch for all those special cases.
+   * For example, if you have a subclass of Token called IDToken that
+   * you want to create if ofKind is ID, simply add something like :
+   *
+   *    case MyParserConstants.ID : return new IDToken(ofKind, image);
+   *
+   * to the following switch statement. Then you can cast matchedToken
+   * variable to the appropriate type and use sit in your lexical actions.
+   */
+  public static Token newToken(int ofKind, String image)
+  {
+    switch(ofKind)
+    {
+      default : return new Token(ofKind, image);
+    }
+  }
+
+  public static Token newToken(int ofKind)
+  {
+    return newToken(ofKind, null);
+  }
+
+}
+/* JavaCC - OriginalChecksum=7e8baa74d8a01b01496421112dcea294 (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/TokenMgrError.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/TokenMgrError.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/TokenMgrError.java
new file mode 100644
index 0000000..3689f73
--- /dev/null
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/generated/TokenMgrError.java
@@ -0,0 +1,147 @@
+/* Generated By:JavaCC: Do not edit this line. TokenMgrError.java Version 5.0 */
+/* JavaCCOptions: */
+package org.apache.camel.component.sql.stored.template.generated;
+
+/** Token Manager Error. */
+public class TokenMgrError extends Error
+{
+
+  /**
+   * The version identifier for this Serializable class.
+   * Increment only if the <i>serialized</i> form of the
+   * class changes.
+   */
+  private static final long serialVersionUID = 1L;
+
+  /*
+   * Ordinals for various reasons why an Error of this type can be thrown.
+   */
+
+  /**
+   * Lexical error occurred.
+   */
+  static final int LEXICAL_ERROR = 0;
+
+  /**
+   * An attempt was made to create a second instance of a static token manager.
+   */
+  static final int STATIC_LEXER_ERROR = 1;
+
+  /**
+   * Tried to change to an invalid lexical state.
+   */
+  static final int INVALID_LEXICAL_STATE = 2;
+
+  /**
+   * Detected (and bailed out of) an infinite loop in the token manager.
+   */
+  static final int LOOP_DETECTED = 3;
+
+  /**
+   * Indicates the reason why the exception is thrown. It will have
+   * one of the above 4 values.
+   */
+  int errorCode;
+
+  /**
+   * Replaces unprintable characters by their escaped (or unicode escaped)
+   * equivalents in the given string
+   */
+  protected static final String addEscapes(String str) {
+    StringBuffer retval = new StringBuffer();
+    char ch;
+    for (int i = 0; i < str.length(); i++) {
+      switch (str.charAt(i))
+      {
+        case 0 :
+          continue;
+        case '\b':
+          retval.append("\\b");
+          continue;
+        case '\t':
+          retval.append("\\t");
+          continue;
+        case '\n':
+          retval.append("\\n");
+          continue;
+        case '\f':
+          retval.append("\\f");
+          continue;
+        case '\r':
+          retval.append("\\r");
+          continue;
+        case '\"':
+          retval.append("\\\"");
+          continue;
+        case '\'':
+          retval.append("\\\'");
+          continue;
+        case '\\':
+          retval.append("\\\\");
+          continue;
+        default:
+          if ((ch = str.charAt(i)) < 0x20 || ch > 0x7e) {
+            String s = "0000" + Integer.toString(ch, 16);
+            retval.append("\\u" + s.substring(s.length() - 4, s.length()));
+          } else {
+            retval.append(ch);
+          }
+          continue;
+      }
+    }
+    return retval.toString();
+  }
+
+  /**
+   * Returns a detailed message for the Error when it is thrown by the
+   * token manager to indicate a lexical error.
+   * Parameters :
+   *    EOFSeen     : indicates if EOF caused the lexical error
+   *    curLexState : lexical state in which this error occurred
+   *    errorLine   : line number when the error occurred
+   *    errorColumn : column number when the error occurred
+   *    errorAfter  : prefix that was seen before this error occurred
+   *    curchar     : the offending character
+   * Note: You can customize the lexical error message by modifying this method.
+   */
+  protected static String LexicalError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar) {
+    return("Lexical error at line " +
+          errorLine + ", column " +
+          errorColumn + ".  Encountered: " +
+          (EOFSeen ? "<EOF> " : ("\"" + addEscapes(String.valueOf(curChar)) + "\"") + " (" + (int)curChar + "), ") +
+          "after : \"" + addEscapes(errorAfter) + "\"");
+  }
+
+  /**
+   * You can also modify the body of this method to customize your error messages.
+   * For example, cases like LOOP_DETECTED and INVALID_LEXICAL_STATE are not
+   * of end-users concern, so you can return something like :
+   *
+   *     "Internal Error : Please file a bug report .... "
+   *
+   * from this method for such cases in the release version of your parser.
+   */
+  public String getMessage() {
+    return super.getMessage();
+  }
+
+  /*
+   * Constructors of various flavors follow.
+   */
+
+  /** No arg constructor. */
+  public TokenMgrError() {
+  }
+
+  /** Constructor with message and reason. */
+  public TokenMgrError(String message, int reason) {
+    super(message);
+    errorCode = reason;
+  }
+
+  /** Full Constructor. */
+  public TokenMgrError(boolean EOFSeen, int lexState, int errorLine, int errorColumn, String errorAfter, char curChar, int reason) {
+    this(LexicalError(EOFSeen, lexState, errorLine, errorColumn, errorAfter, curChar), reason);
+  }
+}
+/* JavaCC - OriginalChecksum=076ac52ededde06a2bcb85f2834da49c (do not edit this line) */

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
index e43d17b..ac138ad 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
@@ -1,4 +1,20 @@
-//Using some token definions from: http://kiwwito.com/build-a-lexical-analyzer-with-javacc/
+//
+// 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.
+//
+// Using some token definions from: http://kiwwito.com/build-a-lexical-analyzer-with-javacc/
 
 options {
     STATIC = false;

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored b/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
index 74e07fd..5e04520 100644
--- a/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
+++ b/components/camel-sql/src/main/resources/META-INF/services/org/apache/camel/component/sql-stored
@@ -1 +1,18 @@
+#
+# 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.
+#
+
 class=org.apache.camel.component.sql.stored.SqlStoredComponent

http://git-wip-us.apache.org/repos/asf/camel/blob/83ef4e62/parent/pom.xml
----------------------------------------------------------------------
diff --git a/parent/pom.xml b/parent/pom.xml
index 74c1b57..63e8459 100644
--- a/parent/pom.xml
+++ b/parent/pom.xml
@@ -258,6 +258,7 @@
     <java-apns-bundle-version>1.0.0.Beta6_1</java-apns-bundle-version>
     <java-apns-version>1.0.0.Beta6</java-apns-version>
     <java-ewah-version>0.7.9</java-ewah-version>
+    <javacc-maven-plugin-version>2.6</javacc-maven-plugin-version>
     <javacrumbs-version>0.22</javacrumbs-version>
     <javassist-bundle-version>3.12.1.GA_3</javassist-bundle-version>
     <javax.el-api-version>2.2.5</javax.el-api-version>


[6/9] camel git commit: CAMEL-4725: Polished

Posted by da...@apache.org.
CAMEL-4725: Polished


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/0dcd69af
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/0dcd69af
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/0dcd69af

Branch: refs/heads/master
Commit: 0dcd69af5a0f880ce994ab88f2d4390d9b83123b
Parents: c8cbcde
Author: Claus Ibsen <da...@apache.org>
Authored: Sat Jan 9 11:16:06 2016 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 11:16:06 2016 +0100

----------------------------------------------------------------------
 .../sql/stored/SqlStoredComponent.java          | 23 ++++++++++---
 .../component/sql/stored/SqlStoredEndpoint.java | 16 +++++++++
 .../component/sql/stored/SqlStoredProducer.java | 31 ++++++++++++------
 .../template/TemplateStoredProcedure.java       | 30 +++++++++++------
 .../TemplateStoredProcedureFactory.java         | 34 ++++++++++++--------
 .../sql/stored/template/ast/InputParameter.java | 31 +++++++++++-------
 .../sql/stored/template/ast/OutParameter.java   | 29 +++++++++++------
 .../sql/stored/template/ast/ParseHelper.java    | 22 +++++++++++--
 .../template/ast/ParseRuntimeException.java     |  3 --
 .../sql/stored/template/ast/Template.java       | 26 +++++++++++----
 .../camel/component/sql/stored/ParserTest.java  | 32 ++++++++++--------
 .../component/sql/stored/ProducerTest.java      | 31 +++++++++++-------
 .../sql/stored/TemplateStoredProcedureTest.java | 34 +++++++++++---------
 .../sql/stored/TestStoredProcedure.java         | 23 +++++++++----
 14 files changed, 249 insertions(+), 116 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
index 20aedf1..4814be9 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -1,3 +1,19 @@
+/**
+ * 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.sql.stored;
 
 import org.apache.camel.CamelContext;
@@ -10,9 +26,6 @@ import org.springframework.jdbc.core.JdbcTemplate;
 import javax.sql.DataSource;
 import java.util.Map;
 
-/**
- * Created by snurmine on 1/3/16.
- */
 public class SqlStoredComponent extends UriEndpointComponent {
 
     private DataSource dataSource;
@@ -46,7 +59,6 @@ public class SqlStoredComponent extends UriEndpointComponent {
             throw new IllegalArgumentException("DataSource must be configured");
         }
 
-
         return new SqlStoredEndpoint(new JdbcTemplate(target), remaining);
     }
 
@@ -54,6 +66,9 @@ public class SqlStoredComponent extends UriEndpointComponent {
         return dataSource;
     }
 
+    /**
+     * Sets the DataSource to use to communicate with the database.
+     */
     public void setDataSource(DataSource dataSource) {
         this.dataSource = dataSource;
     }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
index ae7348c..8ded03a 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
@@ -1,3 +1,19 @@
+/**
+ * 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.sql.stored;
 
 import org.apache.camel.Producer;

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
index f306a4c..81ff287 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
@@ -1,3 +1,19 @@
+/**
+ * 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.sql.stored;
 
 import org.apache.camel.Endpoint;
@@ -6,25 +22,20 @@ import org.apache.camel.component.sql.stored.template.TemplateStoredProcedure;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.DefaultProducer;
 
-/**
- * Created by snurmine on 1/3/16.
- */
 public class SqlStoredProducer extends DefaultProducer {
 
-    final TemplateStoredProcedureFactory templateStoredProcedureFactory;
+    private TemplateStoredProcedureFactory templateStoredProcedureFactory;
+    private TemplateStoredProcedure defaultTemplateStoredProcedure;
 
-    final TemplateStoredProcedure defaultTemplateStoredProcedure;
-
-    public SqlStoredProducer(Endpoint endpoint, String template, TemplateStoredProcedureFactory
-            templateStoredProcedureFactory) {
+    public SqlStoredProducer(Endpoint endpoint, String template, TemplateStoredProcedureFactory templateStoredProcedureFactory) {
         super(endpoint);
-        this.defaultTemplateStoredProcedure = templateStoredProcedureFactory.createFromString(template);
         this.templateStoredProcedureFactory = templateStoredProcedureFactory;
+        this.defaultTemplateStoredProcedure = templateStoredProcedureFactory.createFromString(template);
     }
 
     @Override
     public void process(Exchange exchange) throws Exception {
-        this.defaultTemplateStoredProcedure.execute(exchange);
+        defaultTemplateStoredProcedure.execute(exchange);
     }
 
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
index 44103d8..e0821f5 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
@@ -1,5 +1,24 @@
+/**
+ * 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.sql.stored.template;
 
+import java.util.HashMap;
+import java.util.Map;
+
 import org.apache.camel.Exchange;
 import org.apache.camel.component.sql.stored.template.ast.InputParameter;
 import org.apache.camel.component.sql.stored.template.ast.OutParameter;
@@ -9,14 +28,9 @@ import org.springframework.jdbc.core.SqlOutParameter;
 import org.springframework.jdbc.core.SqlParameter;
 import org.springframework.jdbc.object.StoredProcedure;
 
-import javax.sql.DataSource;
-import java.util.HashMap;
-import java.util.Map;
-
-
 public class TemplateStoredProcedure extends StoredProcedure {
 
-    Template template;
+    private final Template template;
 
     public TemplateStoredProcedure(JdbcTemplate jdbcTemplate, Template template) {
         this.template = template;
@@ -34,11 +48,8 @@ public class TemplateStoredProcedure extends StoredProcedure {
         }
 
         compile();
-
     }
 
-
-
     public void execute(Exchange exchange) {
 
         Map<String, Object> params = new HashMap<>();
@@ -55,5 +66,4 @@ public class TemplateStoredProcedure extends StoredProcedure {
 
     }
 
-
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
index 947a6a5..78f034e 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -1,5 +1,23 @@
+/**
+ * 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.sql.stored.template;
 
+import java.io.StringReader;
+
 import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
 import org.apache.camel.component.sql.stored.template.ast.Template;
 import org.apache.camel.component.sql.stored.template.generated.ParseException;
@@ -7,17 +25,11 @@ import org.apache.camel.component.sql.stored.template.generated.SSPTParser;
 import org.apache.camel.util.LRUCache;
 import org.springframework.jdbc.core.JdbcTemplate;
 
-import javax.sql.DataSource;
-import java.io.StringReader;
-
 public class TemplateStoredProcedureFactory {
 
-    final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
-
-    final JdbcTemplate jdbcTemplate;
-
-    LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(200);
-
+    private final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
+    private final JdbcTemplate jdbcTemplate;
+    private LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(200);
 
     public TemplateStoredProcedureFactory(JdbcTemplate jdbcTemplate) {
         this.jdbcTemplate = jdbcTemplate;
@@ -36,12 +48,10 @@ public class TemplateStoredProcedureFactory {
         templateCache.put(string, ret);
 
         return ret;
-
     }
 
     public Template parseTemplate(String template) {
         try {
-
             SSPTParser parser = new SSPTParser(new StringReader(template));
             return validate(parser.parse());
         } catch (ParseException parseException) {
@@ -50,9 +60,7 @@ public class TemplateStoredProcedureFactory {
     }
 
     private Template validate(Template input) {
-        //TODO:remove validation ?
         return input;
     }
 
-
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
index 69a9703..68927a2 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/InputParameter.java
@@ -1,19 +1,30 @@
+/**
+ * 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.sql.stored.template.ast;
 
 import org.apache.camel.Expression;
 import org.apache.camel.builder.ExpressionBuilder;
 
-
 public class InputParameter {
 
-    String name;
-
-    int sqlType;
-
-    Expression valueExpression;
-
-    Class javaType;
-
+    private final String name;
+    private final int sqlType;
+    private final Expression valueExpression;
+    private final Class javaType;
 
     public InputParameter(String name, int sqlType, String valueSrcAsStr, Class javaType) {
         this.name = name;
@@ -22,7 +33,6 @@ public class InputParameter {
         this.valueExpression = parseValueExpression(valueSrcAsStr);
     }
 
-
     private Expression parseValueExpression(String str) {
         return ExpressionBuilder.simpleExpression(str);
     }
@@ -43,5 +53,4 @@ public class InputParameter {
         return javaType;
     }
 
-
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
index 2182bd7..f01bf57 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/OutParameter.java
@@ -1,17 +1,26 @@
-package org.apache.camel.component.sql.stored.template.ast;
-
 /**
- * Created by snurmine on 12/20/15.
+ * 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.
  */
-public class OutParameter {
-
-
-    String name;
-
-    int sqlType;
+package org.apache.camel.component.sql.stored.template.ast;
 
-    String outHeader;
+public class OutParameter {
 
+    private String name;
+    private int sqlType;
+    private String outHeader;
 
     public OutParameter(String name, int sqlType, String outHeader) {
         this.name = name;

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
index e84c7a9..8e88691 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
@@ -1,12 +1,27 @@
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.sql.stored.template.ast;
 
-import org.springframework.util.ReflectionUtils;
-
 import java.lang.reflect.Field;
 import java.math.BigInteger;
 import java.sql.Date;
 import java.sql.Types;
 
+import org.springframework.util.ReflectionUtils;
 
 public class ParseHelper {
 
@@ -49,10 +64,11 @@ public class ParseHelper {
                 ret = Date.class;
                 break;
         }
+
         if (ret == null) {
             throw new ParseRuntimeException("Unable to map SQL type " + sqlTypeStr + " to Java type");
-
         }
         return ret;
     }
+
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
index b3b8fc8..80fe52c 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
@@ -1,8 +1,5 @@
 package org.apache.camel.component.sql.stored.template.ast;
 
-/**
- * Created by snurmine on 1/3/16.
- */
 public class ParseRuntimeException extends RuntimeException {
     public ParseRuntimeException(String message) {
         super(message);

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
index b442fde..935609c 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/Template.java
@@ -1,3 +1,19 @@
+/**
+ * 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.sql.stored.template.ast;
 
 import java.util.ArrayList;
@@ -8,19 +24,15 @@ import java.util.List;
  */
 public class Template {
 
-    String procedureName;
-
-    List<InputParameter> inputParameterList = new ArrayList<>();
-
-    List<OutParameter> outParameterList = new ArrayList<>();
+    private String procedureName;
+    private final List<InputParameter> inputParameterList = new ArrayList<>();
+    private final List<OutParameter> outParameterList = new ArrayList<>();
 
     public void addParameter(Object parameter) {
-
         if (parameter instanceof OutParameter) {
             outParameterList.add((OutParameter) parameter);
         } else {
             inputParameterList.add((InputParameter) parameter);
-
         }
     }
 

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
index 9982138..1141886 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ParserTest.java
@@ -1,29 +1,40 @@
+/**
+ * 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.sql.stored;
 
+import java.math.BigInteger;
+import java.sql.Types;
 
 import org.apache.camel.Exchange;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.component.sql.stored.template.ast.InputParameter;
 import org.apache.camel.component.sql.stored.template.ast.OutParameter;
 import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
 import org.apache.camel.component.sql.stored.template.ast.Template;
-import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
-import org.apache.camel.component.sql.stored.template.generated.ParseException;
 import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.Assert;
 import org.junit.Test;
 
-import java.math.BigInteger;
-import java.sql.Types;
-
 public class ParserTest extends CamelTestSupport {
 
     TemplateStoredProcedureFactory parser = new TemplateStoredProcedureFactory(null);
 
-
     @Test
     public void shouldParseOk() {
-
-
         Template template = parser.parseTemplate("addnumbers(INTEGER ${header.header1}," +
                 "VARCHAR ${property.property1},BIGINT ${header.header2},OUT INTEGER header1)");
 
@@ -54,10 +65,8 @@ public class ParserTest extends CamelTestSupport {
         Assert.assertEquals("_3", sptpOutputNode.getName());
         Assert.assertEquals(Types.INTEGER, sptpOutputNode.getSqlType());
         Assert.assertEquals("header1", sptpOutputNode.getOutHeader());
-
     }
 
-
     @Test(expected = ParseRuntimeException.class)
     public void noOutputParameterShouldFail() {
         parser.parseTemplate("ADDNUMBERS2" +
@@ -69,15 +78,12 @@ public class ParserTest extends CamelTestSupport {
     public void unexistingTypeShouldFail() {
         parser.parseTemplate("ADDNUMBERS2" +
                 "(XML VALUE1 ${header.v1},OUT INTEGER VALUE2 ${header.v2})");
-
     }
 
-
     @Test(expected = ParseRuntimeException.class)
     public void unmappedTypeShouldFaild() {
         parser.parseTemplate("ADDNUMBERS2" +
                 "(OTHER VALUE1 ${header.v1},INTEGER VALUE2 ${header.v2})");
-
     }
 
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
index f7efd87..19a8089 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
@@ -1,9 +1,27 @@
+/**
+ * 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.sql.stored;
 
+import java.util.HashMap;
+import java.util.Map;
+
 import org.apache.camel.Exchange;
 import org.apache.camel.builder.RouteBuilder;
 import org.apache.camel.component.mock.MockEndpoint;
-import org.apache.camel.component.sql.SqlComponent;
 import org.apache.camel.test.junit4.CamelTestSupport;
 import org.junit.After;
 import org.junit.Before;
@@ -12,30 +30,20 @@ import org.springframework.jdbc.datasource.embedded.EmbeddedDatabase;
 import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseBuilder;
 import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
 
-import java.util.HashMap;
-import java.util.Map;
-
-/**
- * Created by snurmine on 12/30/15.
- */
 public class ProducerTest extends CamelTestSupport {
 
-
     private EmbeddedDatabase db;
 
-
     @Before
     public void setUp() throws Exception {
         db = new EmbeddedDatabaseBuilder()
                 .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
-
         super.setUp();
     }
 
     @After
     public void tearDown() throws Exception {
         super.tearDown();
-
         db.shutdown();
     }
 
@@ -70,4 +78,5 @@ public class ProducerTest extends CamelTestSupport {
             }
         };
     }
+
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
index 3b06390..f92f7df 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
@@ -1,6 +1,21 @@
+/**
+ * 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.sql.stored;
 
-
 import org.apache.camel.Exchange;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedure;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
@@ -16,8 +31,7 @@ import org.springframework.jdbc.datasource.embedded.EmbeddedDatabaseType;
 
 public class TemplateStoredProcedureTest extends CamelTestSupport {
 
-    TemplateStoredProcedureFactory parser;
-
+    private TemplateStoredProcedureFactory parser;
     private EmbeddedDatabase db;
     private JdbcTemplate jdbcTemplate;
 
@@ -25,12 +39,8 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
     public void setUp() throws Exception {
         db = new EmbeddedDatabaseBuilder()
                 .setType(EmbeddedDatabaseType.DERBY).addScript("sql/storedProcedureTest.sql").build();
-
         jdbcTemplate = new JdbcTemplate(db);
-
-
         parser = new TemplateStoredProcedureFactory(jdbcTemplate);
-
         super.setUp();
     }
 
@@ -44,32 +54,26 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
         exchange.getIn().setHeader("v1", 1);
         exchange.getIn().setHeader("v2", 2);
 
-
         sp.execute(exchange);
 
         Assert.assertEquals(Integer.valueOf(3), exchange.getOut().getHeader("resultofsum"));
-
-
     }
 
-
     @Test
     public void shouldExecuteNilacidProcedure() {
-        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("NILADIC" +
-                "()"));
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(jdbcTemplate, parser.parseTemplate("NILADIC()"));
 
         Exchange exchange = createExchangeWithBody(null);
         exchange.getIn().setHeader("v1", 1);
         exchange.getIn().setHeader("v2", 2);
 
-
         sp.execute(exchange);
     }
 
     @After
     public void tearDown() throws Exception {
         super.tearDown();
-
         db.shutdown();
     }
+
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/0dcd69af/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
index cc514e3..cf05611 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
@@ -1,24 +1,35 @@
+/**
+ * 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.sql.stored;
 
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-/**
- * Created by snurmine on 12/20/15.
- */
 public class TestStoredProcedure {
 
     private static final Logger LOG = LoggerFactory.getLogger(TestStoredProcedure.class);
 
-
     public static void addnumbers(int val1, int val2, int[] ret) {
         LOG.info("calling addnumbers:{} + {}", val1, val2);
-
         ret[0] = val1 + val2;
-
     }
 
     public static void niladic() {
         LOG.info("nilacid called");
     }
+
 }


[9/9] camel git commit: CAMEL-4725: Polished

Posted by da...@apache.org.
CAMEL-4725: Polished


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/e9f3f60d
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/e9f3f60d
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/e9f3f60d

Branch: refs/heads/master
Commit: e9f3f60d2a5d373b5e93c9a4ef4b50e71a2165ea
Parents: 83ef4e6
Author: Claus Ibsen <da...@apache.org>
Authored: Sat Jan 9 11:42:29 2016 +0100
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 11:43:29 2016 +0100

----------------------------------------------------------------------
 .../sql/stored/SqlStoredComponent.java          | 11 ++-
 .../component/sql/stored/SqlStoredEndpoint.java | 82 ++++++++++++++++----
 .../component/sql/stored/SqlStoredProducer.java |  2 -
 .../template/TemplateStoredProcedure.java       |  5 ++
 .../TemplateStoredProcedureFactory.java         | 14 +++-
 .../sql/stored/template/ast/ParseHelper.java    |  2 +-
 .../template/ast/ParseRuntimeException.java     |  1 +
 7 files changed, 95 insertions(+), 22 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
index 7012186..3391450 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -21,6 +21,7 @@ import javax.sql.DataSource;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Endpoint;
+import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.UriEndpointComponent;
 import org.apache.camel.util.CamelContextHelper;
 import org.springframework.jdbc.core.JdbcTemplate;
@@ -58,7 +59,14 @@ public class SqlStoredComponent extends UriEndpointComponent {
             throw new IllegalArgumentException("DataSource must be configured");
         }
 
-        return new SqlStoredEndpoint(new JdbcTemplate(target), remaining);
+        JdbcTemplate template = new JdbcTemplate(target);
+        TemplateStoredProcedureFactory factory = new TemplateStoredProcedureFactory(template);
+
+        SqlStoredEndpoint answer = new SqlStoredEndpoint(uri, this);
+        answer.setJdbcTemplate(template);
+        answer.setTemplate(remaining);
+        answer.setTemplateStoredProcedureFactory(factory);
+        return answer;
     }
 
     public DataSource getDataSource() {
@@ -71,4 +79,5 @@ public class SqlStoredComponent extends UriEndpointComponent {
     public void setDataSource(DataSource dataSource) {
         this.dataSource = dataSource;
     }
+
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
index 8ded03a..e65fa8b 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
@@ -16,46 +16,96 @@
  */
 package org.apache.camel.component.sql.stored;
 
+import org.apache.camel.Component;
+import org.apache.camel.Consumer;
+import org.apache.camel.Processor;
 import org.apache.camel.Producer;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
-import org.apache.camel.impl.DefaultPollingEndpoint;
+import org.apache.camel.impl.DefaultEndpoint;
 import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriPath;
+import org.apache.camel.util.ObjectHelper;
+import org.apache.camel.util.ServiceHelper;
 import org.apache.camel.util.UnsafeUriCharactersEncoder;
 import org.springframework.jdbc.core.JdbcTemplate;
 
-@UriEndpoint(scheme = "sql-stored", title = "SQL stored", syntax = "sql-stored:template", label = "database,sql")
-public class SqlStoredEndpoint extends DefaultPollingEndpoint {
+@UriEndpoint(scheme = "sql-stored", title = "SQL StoredProcedure", syntax = "sql-stored:template", producerOnly = true, label = "database,sql")
+public class SqlStoredEndpoint extends DefaultEndpoint {
 
-    @UriPath(description = "Sets the stored procedure template to perform")
-    @Metadata(required = "true")
-    private String template;
-
-    private final TemplateStoredProcedureFactory templateStoredProcedureFactory;
-
-    private final JdbcTemplate jdbcTemplate;
+    private JdbcTemplate jdbcTemplate;
+    private TemplateStoredProcedureFactory templateStoredProcedureFactory;
 
+    @UriPath @Metadata(required = "true")
+    private String template;
 
-    public SqlStoredEndpoint(JdbcTemplate jdbcTemplate,
-                             String template) {
-        this.templateStoredProcedureFactory = new TemplateStoredProcedureFactory(jdbcTemplate);
-        this.jdbcTemplate = jdbcTemplate;
-        this.template = template;
+    public SqlStoredEndpoint(String endpointUri, Component component) {
+        super(endpointUri, component);
     }
 
     @Override
     public Producer createProducer() throws Exception {
+        ObjectHelper.notNull(template, "template");
+        ObjectHelper.notNull(templateStoredProcedureFactory, "templateStoredProcedureFactory");
+
         return new SqlStoredProducer(this, template, templateStoredProcedureFactory);
     }
 
     @Override
+    public Consumer createConsumer(Processor processor) throws Exception {
+        throw new UnsupportedOperationException("This component does not support consumer");
+    }
+
+    @Override
     public boolean isSingleton() {
-        return false;
+        return true;
     }
 
     @Override
     protected String createEndpointUri() {
         return "sql-stored:" + UnsafeUriCharactersEncoder.encode(template);
     }
+
+    @Override
+    protected void doStart() throws Exception {
+        ServiceHelper.startService(templateStoredProcedureFactory);
+    }
+
+    @Override
+    protected void doStop() throws Exception {
+        ServiceHelper.stopService(templateStoredProcedureFactory);
+    }
+
+    public String getTemplate() {
+        return template;
+    }
+
+    /**
+     * The stored procedure template to perform
+     */
+    public void setTemplate(String template) {
+        this.template = template;
+    }
+
+    public TemplateStoredProcedureFactory getTemplateStoredProcedureFactory() {
+        return templateStoredProcedureFactory;
+    }
+
+    /**
+     * To use a custom instance of TemplateStoredProcedureFactory
+     */
+    public void setTemplateStoredProcedureFactory(TemplateStoredProcedureFactory templateStoredProcedureFactory) {
+        this.templateStoredProcedureFactory = templateStoredProcedureFactory;
+    }
+
+    public JdbcTemplate getJdbcTemplate() {
+        return jdbcTemplate;
+    }
+
+    /**
+     * to use a custom instance of JdbcTemplate
+     */
+    public void setJdbcTemplate(JdbcTemplate jdbcTemplate) {
+        this.jdbcTemplate = jdbcTemplate;
+    }
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
index 81ff287..4a7ccc4 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredProducer.java
@@ -24,12 +24,10 @@ import org.apache.camel.impl.DefaultProducer;
 
 public class SqlStoredProducer extends DefaultProducer {
 
-    private TemplateStoredProcedureFactory templateStoredProcedureFactory;
     private TemplateStoredProcedure defaultTemplateStoredProcedure;
 
     public SqlStoredProducer(Endpoint endpoint, String template, TemplateStoredProcedureFactory templateStoredProcedureFactory) {
         super(endpoint);
-        this.templateStoredProcedureFactory = templateStoredProcedureFactory;
         this.defaultTemplateStoredProcedure = templateStoredProcedureFactory.createFromString(template);
     }
 

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
index e0821f5..180c1b2 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedure.java
@@ -23,6 +23,8 @@ import org.apache.camel.Exchange;
 import org.apache.camel.component.sql.stored.template.ast.InputParameter;
 import org.apache.camel.component.sql.stored.template.ast.OutParameter;
 import org.apache.camel.component.sql.stored.template.ast.Template;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
 import org.springframework.jdbc.core.JdbcTemplate;
 import org.springframework.jdbc.core.SqlOutParameter;
 import org.springframework.jdbc.core.SqlParameter;
@@ -30,6 +32,7 @@ import org.springframework.jdbc.object.StoredProcedure;
 
 public class TemplateStoredProcedure extends StoredProcedure {
 
+    private static final Logger LOG = LoggerFactory.getLogger(TemplateStoredProcedure.class);
     private final Template template;
 
     public TemplateStoredProcedure(JdbcTemplate jdbcTemplate, Template template) {
@@ -47,6 +50,7 @@ public class TemplateStoredProcedure extends StoredProcedure {
             setFunction(false);
         }
 
+        LOG.debug("Compiling stored procedure: {}", template.getProcedureName());
         compile();
     }
 
@@ -58,6 +62,7 @@ public class TemplateStoredProcedure extends StoredProcedure {
             params.put(inputParameter.getName(), inputParameter.getValueExpression().evaluate(exchange, inputParameter.getJavaType()));
         }
 
+        LOG.debug("Invoking stored procedure: {}", template.getProcedureName());
         Map<String, Object> ret = super.execute(params);
 
         for (OutParameter out : template.getOutParameterList()) {

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
index 5d5a329..f096dc8 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -22,14 +22,15 @@ import org.apache.camel.component.sql.stored.template.ast.ParseRuntimeException;
 import org.apache.camel.component.sql.stored.template.ast.Template;
 import org.apache.camel.component.sql.stored.template.generated.ParseException;
 import org.apache.camel.component.sql.stored.template.generated.SSPTParser;
+import org.apache.camel.support.ServiceSupport;
 import org.apache.camel.util.LRUCache;
 import org.springframework.jdbc.core.JdbcTemplate;
 
-public class TemplateStoredProcedureFactory {
+public class TemplateStoredProcedureFactory extends ServiceSupport {
 
     public static final int TEMPLATE_CACHE_DEFAULT_SIZE = 200;
     private final JdbcTemplate jdbcTemplate;
-    private LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(TEMPLATE_CACHE_DEFAULT_SIZE);
+    private final LRUCache<String, TemplateStoredProcedure> templateCache = new LRUCache<String, TemplateStoredProcedure>(TEMPLATE_CACHE_DEFAULT_SIZE);
 
     public TemplateStoredProcedureFactory(JdbcTemplate jdbcTemplate) {
         this.jdbcTemplate = jdbcTemplate;
@@ -63,4 +64,13 @@ public class TemplateStoredProcedureFactory {
         return input;
     }
 
+    @Override
+    protected void doStart() throws Exception {
+    }
+
+    @Override
+    protected void doStop() throws Exception {
+        // clear cache when we are stopping
+        templateCache.clear();
+    }
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
index 19417de..dd926ef 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseHelper.java
@@ -43,7 +43,7 @@ public final class ParseHelper {
     public static Class sqlTypeToJavaType(int sqlType, String sqlTypeStr) {
         //TODO: as rest of types.
         //TODO: add test for each type.
-        Class ret = null;
+        Class ret;
         switch (sqlType) {
         case Types.INTEGER:
             ret = Integer.class;

http://git-wip-us.apache.org/repos/asf/camel/blob/e9f3f60d/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
index 2092afa..2fdea24 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/ast/ParseRuntimeException.java
@@ -17,6 +17,7 @@
 package org.apache.camel.component.sql.stored.template.ast;
 
 public class ParseRuntimeException extends RuntimeException {
+
     public ParseRuntimeException(String message) {
         super(message);
     }


[4/9] camel git commit: Allow nilacid stored procedure function.

Posted by da...@apache.org.
Allow nilacid stored procedure function.


Project: http://git-wip-us.apache.org/repos/asf/camel/repo
Commit: http://git-wip-us.apache.org/repos/asf/camel/commit/f0738bbf
Tree: http://git-wip-us.apache.org/repos/asf/camel/tree/f0738bbf
Diff: http://git-wip-us.apache.org/repos/asf/camel/diff/f0738bbf

Branch: refs/heads/master
Commit: f0738bbfae35b7cdbd22a51d9a5ecdf2c5c87e0f
Parents: 3ee2bb4
Author: Sami Nurminen <sn...@gmail.com>
Authored: Mon Jan 4 21:27:17 2016 +0200
Committer: Claus Ibsen <da...@apache.org>
Committed: Sat Jan 9 10:59:46 2016 +0100

----------------------------------------------------------------------
 .../sql/stored/SqlStoredComponent.java          | 26 +++++++++++++++++---
 .../component/sql/stored/SqlStoredEndpoint.java |  3 ++-
 .../TemplateStoredProcedureFactory.java         |  4 +--
 .../sql/stored/template/grammar/sspt.jj         |  4 +--
 .../component/sql/stored/ProducerTest.java      |  1 +
 .../sql/stored/SimpleStoredProcedureUdf.java    | 15 -----------
 .../sql/stored/TemplateStoredProcedureTest.java | 16 +++++++++++-
 .../sql/stored/TestStoredProcedure.java         | 24 ++++++++++++++++++
 .../test/resources/sql/storedProcedureTest.sql  |  8 +++++-
 9 files changed, 74 insertions(+), 27 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
index da2850a..9fdb45d 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredComponent.java
@@ -2,9 +2,9 @@ package org.apache.camel.component.sql.stored;
 
 import org.apache.camel.CamelContext;
 import org.apache.camel.Endpoint;
-import org.apache.camel.RuntimeCamelException;
 import org.apache.camel.component.sql.stored.template.TemplateStoredProcedureFactory;
 import org.apache.camel.impl.UriEndpointComponent;
+import org.apache.camel.util.CamelContextHelper;
 
 import javax.sql.DataSource;
 import java.util.Map;
@@ -21,7 +21,6 @@ public class SqlStoredComponent extends UriEndpointComponent {
     }
 
 
-
     TemplateStoredProcedureFactory templateStoredProcedureFactory = new TemplateStoredProcedureFactory();
 
     public SqlStoredComponent(CamelContext context, Class<? extends Endpoint> endpointClass) {
@@ -30,8 +29,27 @@ public class SqlStoredComponent extends UriEndpointComponent {
 
     @Override
     protected Endpoint createEndpoint(String uri, String remaining, Map<String, Object> parameters) throws Exception {
-
-            return new SqlStoredEndpoint(templateStoredProcedureFactory,dataSource,remaining);
+        DataSource target = null;
+
+        // endpoint options overrule component configured datasource
+        DataSource ds = resolveAndRemoveReferenceParameter(parameters, "dataSource", DataSource.class);
+        if (ds != null) {
+            target = ds;
+        }
+        String dataSourceRef = getAndRemoveParameter(parameters, "dataSourceRef", String.class);
+        if (target == null && dataSourceRef != null) {
+            target = CamelContextHelper.mandatoryLookup(getCamelContext(), dataSourceRef, DataSource.class);
+        }
+        if (target == null) {
+            // fallback and use component
+            target = dataSource;
+        }
+        if (target == null) {
+            throw new IllegalArgumentException("DataSource must be configured");
+        }
+
+
+        return new SqlStoredEndpoint(templateStoredProcedureFactory, target, remaining);
     }
 
     public DataSource getDataSource() {

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
index cee6223..844e9e5 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/SqlStoredEndpoint.java
@@ -6,6 +6,7 @@ import org.apache.camel.impl.DefaultPollingEndpoint;
 import org.apache.camel.spi.Metadata;
 import org.apache.camel.spi.UriEndpoint;
 import org.apache.camel.spi.UriPath;
+import org.apache.camel.util.UnsafeUriCharactersEncoder;
 
 import javax.sql.DataSource;
 
@@ -40,6 +41,6 @@ public class SqlStoredEndpoint extends DefaultPollingEndpoint {
 
     @Override
     protected String createEndpointUri() {
-        return "sql-stored:" + template;
+        return "sql-stored:" + UnsafeUriCharactersEncoder.encode(template);
     }
 }

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
index f1b4da3..2229a4e 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/TemplateStoredProcedureFactory.java
@@ -28,9 +28,7 @@ public class TemplateStoredProcedureFactory {
     }
 
     private Template validate(Template input) {
-        if (input.getOutParameterList().isEmpty()) {
-            throw new ParseRuntimeException("At least one OUT parameter must be given.");
-        }
+        //TODO:remove validation ?
         return input;
     }
 

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
index 764764c..edd9f17 100644
--- a/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
+++ b/components/camel-sql/src/main/java/org/apache/camel/component/sql/stored/template/grammar/sspt.jj
@@ -27,9 +27,9 @@ public Template parse() :
     Object parameter = null;
 }
 {
-  (procudureName = <IDENTIFIER> "(" (parameter = Parameter() { template.addParameter(parameter);}) (","
+  (procudureName = <IDENTIFIER> "(" ( (parameter = Parameter() { template.addParameter(parameter);}) (","
   parameter
-  = Parameter(){template.addParameter(parameter);})*  ")" <EOF>)
+  = Parameter(){template.addParameter(parameter);})*)? ")" <EOF>)
   {
    template.setProcedureName(procudureName.toString());
    return template;

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
index 969bca1..f7efd87 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/ProducerTest.java
@@ -23,6 +23,7 @@ public class ProducerTest extends CamelTestSupport {
 
     private EmbeddedDatabase db;
 
+
     @Before
     public void setUp() throws Exception {
         db = new EmbeddedDatabaseBuilder()

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
deleted file mode 100644
index 2802b70..0000000
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/SimpleStoredProcedureUdf.java
+++ /dev/null
@@ -1,15 +0,0 @@
-package org.apache.camel.component.sql.stored;
-
-/**
- * Created by snurmine on 12/20/15.
- */
-public class SimpleStoredProcedureUdf {
-
-    public static void addnumbers(int VALUE1, int VALUE2, int[] RESULT) {
-        System.out.println("calling addnumbers:" + VALUE1 + "," + VALUE2);
-
-        RESULT[0] = VALUE1 + VALUE2;
-
-
-    }
-}

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
index 752dcaa..73e9711 100644
--- a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TemplateStoredProcedureTest.java
@@ -33,7 +33,7 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
 
 
     @Test
-    public void shouldExecuteStoredProcedure()  {
+    public void shouldExecuteStoredProcedure() {
         TemplateStoredProcedure sp = new TemplateStoredProcedure(db, parser.parseTemplate("ADDNUMBERS" +
                 "(INTEGER ${header.v1},INTEGER ${header.v2},OUT INTEGER resultofsum)"));
 
@@ -49,6 +49,20 @@ public class TemplateStoredProcedureTest extends CamelTestSupport {
 
     }
 
+
+    @Test
+    public void shouldExecuteNilacidProcedure() {
+        TemplateStoredProcedure sp = new TemplateStoredProcedure(db, parser.parseTemplate("NILADIC" +
+                "()"));
+
+        Exchange exchange = createExchangeWithBody(null);
+        exchange.getIn().setHeader("v1", 1);
+        exchange.getIn().setHeader("v2", 2);
+
+
+        sp.execute(exchange);
+    }
+
     @After
     public void tearDown() throws Exception {
         super.tearDown();

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
new file mode 100644
index 0000000..cc514e3
--- /dev/null
+++ b/components/camel-sql/src/test/java/org/apache/camel/component/sql/stored/TestStoredProcedure.java
@@ -0,0 +1,24 @@
+package org.apache.camel.component.sql.stored;
+
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+/**
+ * Created by snurmine on 12/20/15.
+ */
+public class TestStoredProcedure {
+
+    private static final Logger LOG = LoggerFactory.getLogger(TestStoredProcedure.class);
+
+
+    public static void addnumbers(int val1, int val2, int[] ret) {
+        LOG.info("calling addnumbers:{} + {}", val1, val2);
+
+        ret[0] = val1 + val2;
+
+    }
+
+    public static void niladic() {
+        LOG.info("nilacid called");
+    }
+}

http://git-wip-us.apache.org/repos/asf/camel/blob/f0738bbf/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
----------------------------------------------------------------------
diff --git a/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
index 3f6ed74..807768e 100644
--- a/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
+++ b/components/camel-sql/src/test/resources/sql/storedProcedureTest.sql
@@ -19,4 +19,10 @@ CREATE PROCEDURE ADDNUMBERS(VALUE1 INTEGER, VALUE2 INTEGER,OUT RESULT INTEGER)
  PARAMETER STYLE JAVA
  LANGUAGE JAVA
  EXTERNAL NAME
-'org.apache.camel.component.sql.stored.SimpleStoredProcedureUdf.addnumbers';
\ No newline at end of file
+'org.apache.camel.component.sql.stored.TestStoredProcedure.addnumbers';
+
+CREATE PROCEDURE NILADIC()
+ PARAMETER STYLE JAVA
+ LANGUAGE JAVA
+ EXTERNAL NAME
+'org.apache.camel.component.sql.stored.TestStoredProcedure.niladic';
\ No newline at end of file