You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@chemistry.apache.org by fm...@apache.org on 2013/08/21 20:36:17 UTC

svn commit: r1516250 [4/4] - in /chemistry/opencmis/trunk: chemistry-opencmis-client/chemistry-opencmis-client-api/src/main/java/org/apache/chemistry/opencmis/client/api/ chemistry-opencmis-client/chemistry-opencmis-client-bindings/src/main/java/org/ap...

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/ParseTreeWalker.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/ParseTreeWalker.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/ParseTreeWalker.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/ParseTreeWalker.java Wed Aug 21 18:36:15 2013
@@ -31,16 +31,18 @@ import org.apache.chemistry.opencmis.ser
 import org.apache.chemistry.opencmis.server.support.query.TextSearchLexer;
 
 /**
- * This implementation of {@link PredicateWalkerBase} traverses the parse tree of a CMIS query.
- * It uses an {@link Evaluator} to accumulate the result of the traversal. <code>Evaluator</code>
- * has a corresponding method for each {@link Tree#getType() node type} in the parse tree.
- * <code>ParseTreeWalker</code> calls these methods while traversing the parse tree passing an
- * <code>Evaluator</code> for each of the corresponding operation's arguments.
- * </br>
- * The {@link #walkPredicate(Tree)} serves as entry point for traversing a parse tree. After
- * successful traversal, the result is obtained from the {@link #getResult()} method.
- *
- * @param <T>  type of the result determined by the <code>Evaluator</code> used.
+ * This implementation of {@link PredicateWalkerBase} traverses the parse tree
+ * of a CMIS query. It uses an {@link Evaluator} to accumulate the result of the
+ * traversal. <code>Evaluator</code> has a corresponding method for each
+ * {@link Tree#getType() node type} in the parse tree.
+ * <code>ParseTreeWalker</code> calls these methods while traversing the parse
+ * tree passing an <code>Evaluator</code> for each of the corresponding
+ * operation's arguments. </br> The {@link #walkPredicate(Tree)} serves as entry
+ * point for traversing a parse tree. After successful traversal, the result is
+ * obtained from the {@link #getResult()} method.
+ * 
+ * @param <T>
+ *            type of the result determined by the <code>Evaluator</code> used.
  */
 public class ParseTreeWalker<T> implements PredicateWalkerBase {
 
@@ -49,8 +51,10 @@ public class ParseTreeWalker<T> implemen
 
     /**
      * Create a new instance for traversing CMIS query parse trees.
-     *
-     * @param evaluator  <code>Evaluator</code> for evaluating the nodes of the parse tree
+     * 
+     * @param evaluator
+     *            <code>Evaluator</code> for evaluating the nodes of the parse
+     *            tree
      */
     public ParseTreeWalker(Evaluator<T> evaluator) {
         this.evaluator = evaluator;
@@ -58,23 +62,24 @@ public class ParseTreeWalker<T> implemen
 
     /**
      * Retrieve the result of a successful traversal.
-     *
-     * @return  result of traversal or <code>null</code> if either not yet traversed, an error occurred
-     *      on traversal or the query has an empty where clause. 
+     * 
+     * @return result of traversal or <code>null</code> if either not yet
+     *         traversed, an error occurred on traversal or the query has an
+     *         empty where clause.
      */
     public T getResult() {
         return result;
     }
 
-    //------------------------------------------< PredicateWalkerBase >---
-    
+    // ------------------------------------------< PredicateWalkerBase >---
+
     public Boolean walkPredicate(Tree node) {
         result = null;
         result = walkPredicate(evaluator, node);
         return false; // Return value is ignored by caller
     }
 
-    //------------------------------------------< protected >---
+    // ------------------------------------------< protected >---
 
     /** For extensibility. */
     protected T walkOtherExpr(Evaluator<?> evaluator, Tree node) {
@@ -86,147 +91,116 @@ public class ParseTreeWalker<T> implemen
         throw new CmisRuntimeException("Unknown node type: " + node.getType() + " (" + node.getText() + ")");
     }
 
-    //------------------------------------------< private >---
+    // ------------------------------------------< private >---
 
     private T walkPredicate(Evaluator<T> evaluator, Tree node) {
         switch (node.getType()) {
-            case CmisQlStrictLexer.NOT:
-                return evaluator.not(walkPredicate(evaluator.op(), node.getChild(0)));
-            case CmisQlStrictLexer.AND:
-                return evaluator.and(
-                        walkPredicate(evaluator.op(), node.getChild(0)),
-                        walkPredicate(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.OR:
-                return evaluator.or(
-                        walkPredicate(evaluator.op(), node.getChild(0)),
-                        walkPredicate(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.EQ:
-                return evaluator.eq(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.NEQ:
-                return evaluator.neq(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.GT:
-                return evaluator.gt(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.GTEQ:
-                return evaluator.gteq(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.LT:
-                return evaluator.lt(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.LTEQ:
-                return evaluator.lteq(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.IN:
-                return evaluator.in(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.NOT_IN:
-                return evaluator.notIn(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.IN_ANY:
-                return evaluator.inAny(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.NOT_IN_ANY:
-                return evaluator.notInAny(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.EQ_ANY:
-                return evaluator.eqAny(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.IS_NULL:
-                return evaluator.isNull(walkExpr(evaluator.op(), node.getChild(0)));
-            case CmisQlStrictLexer.IS_NOT_NULL:
-                return evaluator.notIsNull(walkExpr(evaluator.op(), node.getChild(0)));
-            case CmisQlStrictLexer.LIKE:
-                return evaluator.like(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.NOT_LIKE:
-                return evaluator.notLike(
-                        walkExpr(evaluator.op(), node.getChild(0)),
-                        walkExpr(evaluator.op(), node.getChild(1)));
-            case CmisQlStrictLexer.CONTAINS:
-                if (node.getChildCount() == 1) {
-                    return evaluator.contains(
-                            null,
-                            walkExprTextSearch(evaluator.op(), node.getChild(0)));
-                }
-                else {
-                    return evaluator.contains(
-                            walkExpr(evaluator.op(), node.getChild(0)),
-                            walkExpr(evaluator.op(), node.getChild(1)));
-                }
-            case CmisQlStrictLexer.IN_FOLDER:
-                if (node.getChildCount() == 1) {
-                    return evaluator.inFolder(
-                            null,
-                            walkExpr(evaluator.op(), node.getChild(0)));
-                }
-                else {
-                    return evaluator.inFolder(
-                            walkExpr(evaluator.op(), node.getChild(0)),
-                            walkExpr(evaluator.op(), node.getChild(1)));
-                }
-            case CmisQlStrictLexer.IN_TREE:
-                if (node.getChildCount() == 1) {
-                    return evaluator.inTree(
-                            null,
-                            walkExpr(evaluator.op(), node.getChild(0)));
-                }
-                else {
-                    return evaluator.inTree(
-                            walkExpr(evaluator.op(), node.getChild(0)),
-                            walkExpr(evaluator.op(), node.getChild(1)));
-                }
-            default:
-                return walkOtherPredicate(evaluator, node);
+        case CmisQlStrictLexer.NOT:
+            return evaluator.not(walkPredicate(evaluator.op(), node.getChild(0)));
+        case CmisQlStrictLexer.AND:
+            return evaluator.and(walkPredicate(evaluator.op(), node.getChild(0)),
+                    walkPredicate(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.OR:
+            return evaluator.or(walkPredicate(evaluator.op(), node.getChild(0)),
+                    walkPredicate(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.EQ:
+            return evaluator.eq(walkExpr(evaluator.op(), node.getChild(0)), walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.NEQ:
+            return evaluator
+                    .neq(walkExpr(evaluator.op(), node.getChild(0)), walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.GT:
+            return evaluator.gt(walkExpr(evaluator.op(), node.getChild(0)), walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.GTEQ:
+            return evaluator.gteq(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.LT:
+            return evaluator.lt(walkExpr(evaluator.op(), node.getChild(0)), walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.LTEQ:
+            return evaluator.lteq(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.IN:
+            return evaluator.in(walkExpr(evaluator.op(), node.getChild(0)), walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.NOT_IN:
+            return evaluator.notIn(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.IN_ANY:
+            return evaluator.inAny(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.NOT_IN_ANY:
+            return evaluator.notInAny(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.EQ_ANY:
+            return evaluator.eqAny(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.IS_NULL:
+            return evaluator.isNull(walkExpr(evaluator.op(), node.getChild(0)));
+        case CmisQlStrictLexer.IS_NOT_NULL:
+            return evaluator.notIsNull(walkExpr(evaluator.op(), node.getChild(0)));
+        case CmisQlStrictLexer.LIKE:
+            return evaluator.like(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.NOT_LIKE:
+            return evaluator.notLike(walkExpr(evaluator.op(), node.getChild(0)),
+                    walkExpr(evaluator.op(), node.getChild(1)));
+        case CmisQlStrictLexer.CONTAINS:
+            if (node.getChildCount() == 1) {
+                return evaluator.contains(null, walkExprTextSearch(evaluator.op(), node.getChild(0)));
+            } else {
+                return evaluator.contains(walkExpr(evaluator.op(), node.getChild(0)),
+                        walkExpr(evaluator.op(), node.getChild(1)));
+            }
+        case CmisQlStrictLexer.IN_FOLDER:
+            if (node.getChildCount() == 1) {
+                return evaluator.inFolder(null, walkExpr(evaluator.op(), node.getChild(0)));
+            } else {
+                return evaluator.inFolder(walkExpr(evaluator.op(), node.getChild(0)),
+                        walkExpr(evaluator.op(), node.getChild(1)));
+            }
+        case CmisQlStrictLexer.IN_TREE:
+            if (node.getChildCount() == 1) {
+                return evaluator.inTree(null, walkExpr(evaluator.op(), node.getChild(0)));
+            } else {
+                return evaluator.inTree(walkExpr(evaluator.op(), node.getChild(0)),
+                        walkExpr(evaluator.op(), node.getChild(1)));
+            }
+        default:
+            return walkOtherPredicate(evaluator, node);
         }
     }
 
     private T walkExpr(Evaluator<T> evaluator, Tree node) {
         switch (node.getType()) {
-            case CmisQlStrictLexer.BOOL_LIT:
-                return walkBoolean(evaluator, node);
-            case CmisQlStrictLexer.NUM_LIT:
-                return walkNumber(evaluator, node);
-            case CmisQlStrictLexer.STRING_LIT:
-                return walkString(evaluator, node);
-            case CmisQlStrictLexer.TIME_LIT:
-                return walkTimestamp(evaluator, node);
-            case CmisQlStrictLexer.IN_LIST:
-                return evaluator.list(walkList(evaluator, node));
-            case CmisQlStrictLexer.COL:
-                return walkCol(evaluator, node);
-            default:
-                return walkOtherExpr(evaluator, node);
+        case CmisQlStrictLexer.BOOL_LIT:
+            return walkBoolean(evaluator, node);
+        case CmisQlStrictLexer.NUM_LIT:
+            return walkNumber(evaluator, node);
+        case CmisQlStrictLexer.STRING_LIT:
+            return walkString(evaluator, node);
+        case CmisQlStrictLexer.TIME_LIT:
+            return walkTimestamp(evaluator, node);
+        case CmisQlStrictLexer.IN_LIST:
+            return evaluator.list(walkList(evaluator, node));
+        case CmisQlStrictLexer.COL:
+            return walkCol(evaluator, node);
+        default:
+            return walkOtherExpr(evaluator, node);
         }
     }
-    
+
     private T walkExprTextSearch(Evaluator<T> evaluator, Tree node) {
         switch (node.getType()) {
-            case TextSearchLexer.TEXT_AND:
-                return walkTextAnd(evaluator, node);
-            case TextSearchLexer.TEXT_OR:
-                return walkTextOr(evaluator, node);
-            case TextSearchLexer.TEXT_MINUS:
-                return walkTextMinus(evaluator, node);
-            case TextSearchLexer.TEXT_SEARCH_WORD_LIT:
-                return walkTextWord(evaluator, node);
-            case TextSearchLexer.TEXT_SEARCH_PHRASE_STRING_LIT:
-                return walkTextPhrase(evaluator, node);
-            default:
-                return walkOtherExpr(evaluator, node);
+        case TextSearchLexer.TEXT_AND:
+            return walkTextAnd(evaluator, node);
+        case TextSearchLexer.TEXT_OR:
+            return walkTextOr(evaluator, node);
+        case TextSearchLexer.TEXT_MINUS:
+            return walkTextMinus(evaluator, node);
+        case TextSearchLexer.TEXT_SEARCH_WORD_LIT:
+            return walkTextWord(evaluator, node);
+        case TextSearchLexer.TEXT_SEARCH_PHRASE_STRING_LIT:
+            return walkTextPhrase(evaluator, node);
+        default:
+            return walkOtherExpr(evaluator, node);
         }
     }
 
@@ -244,11 +218,9 @@ public class ParseTreeWalker<T> implemen
 
         if ("true".equalsIgnoreCase(s)) {
             return evaluator.value(true);
-        }
-        else if ("false".equalsIgnoreCase(s)) {
+        } else if ("false".equalsIgnoreCase(s)) {
             return evaluator.value(false);
-        }
-        else {
+        } else {
             throw new CmisInvalidArgumentException("Not a boolean: " + s);
         }
     }
@@ -256,11 +228,9 @@ public class ParseTreeWalker<T> implemen
     private T walkNumber(Evaluator<T> evaluator, Tree node) {
         String s = node.getText();
         try {
-            return s.contains(".") || s.contains("e") || s.contains("E")
-                    ? evaluator.value(Double.valueOf(s))
+            return s.contains(".") || s.contains("e") || s.contains("E") ? evaluator.value(Double.valueOf(s))
                     : evaluator.value(Long.valueOf(s));
-        }
-        catch (NumberFormatException e) {
+        } catch (NumberFormatException e) {
             throw new CmisInvalidArgumentException("Not a number: " + s);
         }
     }
@@ -268,7 +238,7 @@ public class ParseTreeWalker<T> implemen
     private T walkString(Evaluator<T> evaluator, Tree node) {
         String s = node.getText();
         s = s.substring(1, s.length() - 1);
-        return evaluator.value(s.replace("''", "'"));  // un-escape quotes
+        return evaluator.value(s.replace("''", "'")); // un-escape quotes
     }
 
     private T walkTimestamp(Evaluator<T> evaluator, Tree node) {
@@ -276,8 +246,7 @@ public class ParseTreeWalker<T> implemen
         s = s.substring(s.indexOf('\'') + 1, s.length() - 1);
         try {
             return evaluator.value(CalendarHelper.fromString(s));
-        }
-        catch (IllegalArgumentException e) {
+        } catch (IllegalArgumentException e) {
             throw new CmisInvalidArgumentException("Not a date time value: " + s);
         }
     }
@@ -288,38 +257,38 @@ public class ParseTreeWalker<T> implemen
 
     private T walkTextAnd(Evaluator<T> evaluator, Tree node) {
         List<T> terms = new ArrayList<T>();
-        for (Tree term: getChildrenAsList(node)) {
+        for (Tree term : getChildrenAsList(node)) {
             terms.add(walkExprTextSearch(evaluator, term));
         }
 
         return evaluator.textAnd(terms);
     }
-    
+
     private T walkTextOr(Evaluator<T> evaluator, Tree node) {
         List<T> terms = new ArrayList<T>();
-        for (Tree term: getChildrenAsList(node)) {
+        for (Tree term : getChildrenAsList(node)) {
             terms.add(walkExprTextSearch(evaluator, term));
         }
 
         return evaluator.textOr(terms);
     }
-    
+
     private T walkTextMinus(Evaluator<T> evaluator, Tree node) {
         return evaluator.textMinus(node.getChild(0).getText());
     }
-    
+
     private T walkTextWord(Evaluator<T> evaluator, Tree node) {
         return evaluator.textWord(node.getText());
     }
-    
+
     private T walkTextPhrase(Evaluator<T> evaluator, Tree node) {
         return evaluator.textPhrase(node.getText());
     }
 
     private static List<Tree> getChildrenAsList(Tree node) {
         List<Tree> res = new ArrayList<Tree>(node.getChildCount());
-        for (int i=0; i<node.getChildCount(); i++) {
-            Tree childNode =  node.getChild(i);
+        for (int i = 0; i < node.getChildCount(); i++) {
+            Tree childNode = node.getChild(i);
             res.add(childNode);
         }
         return res;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/QueryTranslator.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/QueryTranslator.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/QueryTranslator.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/QueryTranslator.java Wed Aug 21 18:36:15 2013
@@ -31,11 +31,10 @@ import org.apache.chemistry.opencmis.ser
 
 /**
  * Abstract base class for translating a CMIS query statement to a JCR XPath
- * query statement.
- * Overriding class need to implement methods for mapping CMIS ids to JCR paths,
- * CMIS property names to JCR property names, CMIS type names to JCR type name and
- * in addition a method for adding further constraints to a query based on a CMIS
- * type. 
+ * query statement. Overriding class need to implement methods for mapping CMIS
+ * ids to JCR paths, CMIS property names to JCR property names, CMIS type names
+ * to JCR type name and in addition a method for adding further constraints to a
+ * query based on a CMIS type.
  */
 public abstract class QueryTranslator {
     private final JcrTypeManager typeManager;
@@ -43,8 +42,8 @@ public abstract class QueryTranslator {
     private QueryObject queryObject;
 
     /**
-     * Create a new query translator which uses the provided <code>typeManager</code>
-     * to resolve CMIS type names to CMIS types.
+     * Create a new query translator which uses the provided
+     * <code>typeManager</code> to resolve CMIS type names to CMIS types.
      * 
      * @param typeManager
      */
@@ -65,8 +64,8 @@ public abstract class QueryTranslator {
     }
 
     /**
-     * @return  the {@link QueryObject} from the last translation performed through
-     *      {@link QueryTranslator#translateToXPath(String)}.
+     * @return the {@link QueryObject} from the last translation performed
+     *         through {@link QueryTranslator#translateToXPath(String)}.
      */
     public QueryObject getQueryObject() {
         return queryObject;
@@ -94,63 +93,73 @@ public abstract class QueryTranslator {
         return "/jcr:root" + pathExpression + elementTest + predicates + orderByClause;
     }
 
-    //------------------------------------------< protected >---
+    // ------------------------------------------< protected >---
 
     /**
      * Map a CMIS objectId to an absolute JCR path. This method is called to
      * resolve the folder if of folder predicates (i.e. IN_FOLDER, IN_TREE).
-     *
-     * @param id  objectId
-     * @return  absolute JCR path corresponding to <code>id</code>.
+     * 
+     * @param id
+     *            objectId
+     * @return absolute JCR path corresponding to <code>id</code>.
      */
     protected abstract String jcrPathFromId(String id);
 
     /**
-     * Map a column name in the CMIS query to the corresponding relative JCR path.
-     * The path must be relative to the context node.
-     *
-     * @param fromType  Type on which the CMIS query is performed
-     * @param name  column name
-     * @return  relative JCR path 
+     * Map a column name in the CMIS query to the corresponding relative JCR
+     * path. The path must be relative to the context node.
+     * 
+     * @param fromType
+     *            Type on which the CMIS query is performed
+     * @param name
+     *            column name
+     * @return relative JCR path
      */
     protected abstract String jcrPathFromCol(TypeDefinition fromType, String name);
 
     /**
      * Map a CMIS type to the corresponding JCR type name.
+     * 
      * @see #jcrTypeCondition(TypeDefinition)
-     *
-     * @param fromType  CMIS type
-     * @return  name of the JCR type corresponding to <code>fromType</code>
+     * 
+     * @param fromType
+     *            CMIS type
+     * @return name of the JCR type corresponding to <code>fromType</code>
      */
     protected abstract String jcrTypeName(TypeDefinition fromType);
 
     /**
-     * Create and additional condition in order for the query to only return nodes
-     * of the right type. This condition and-ed to the condition determined by the
-     * CMIS query's where clause.
+     * Create and additional condition in order for the query to only return
+     * nodes of the right type. This condition and-ed to the condition
+     * determined by the CMIS query's where clause.
      * <p/>
-     * A CMIS query for non versionable documents should for example result in the
-     * following XPath query:
+     * A CMIS query for non versionable documents should for example result in
+     * the following XPath query:
      * <p/>
+     * 
      * <pre>
      *   element(*, nt:file)[not(@jcr:mixinTypes = 'mix:simpleVersionable')]
      * </pre>
+     * 
      * Here the element test is covered by {@link #jcrTypeName(TypeDefinition)}
-     * while the predicate is covered by this method.  
-     *
+     * while the predicate is covered by this method.
+     * 
      * @see #jcrTypeName(TypeDefinition)
-     *
+     * 
      * @param fromType
-     * @return  Additional condition or <code>null</code> if none. 
+     * @return Additional condition or <code>null</code> if none.
      */
-    protected abstract String jcrTypeCondition(TypeDefinition fromType);  
+    protected abstract String jcrTypeCondition(TypeDefinition fromType);
 
     /**
-     * Build a XPath path expression for the CMIS type queried for and a folder predicate.
-     *
-     * @param fromType  CMIS type queried for
-     * @param folderPredicate  folder predicate
-     * @return  a valid XPath path expression or <code>null</code> if none.
+     * Build a XPath path expression for the CMIS type queried for and a folder
+     * predicate.
+     * 
+     * @param fromType
+     *            CMIS type queried for
+     * @param folderPredicate
+     *            folder predicate
+     * @return a valid XPath path expression or <code>null</code> if none.
      */
     protected String buildPathExpression(TypeDefinition fromType, String folderPredicate) {
         return folderPredicate == null ? "//" : folderPredicate;
@@ -158,86 +167,88 @@ public abstract class QueryTranslator {
 
     /**
      * Build a XPath element test for the given CMIS type.
-     *
-     * @param fromType  CMIS type queried for
-     * @return  a valid XPath element test. 
+     * 
+     * @param fromType
+     *            CMIS type queried for
+     * @return a valid XPath element test.
      */
     protected String buildElementTest(TypeDefinition fromType) {
         return "element(*," + jcrTypeName(fromType) + ")";
     }
 
     /**
-     * Build a XPath predicate for the given CMIS type and an additional condition.
-     * The additional condition should be and-ed to the condition resulting from
-     * evaluating <code>fromType</code>.
-     *
-     * @param fromType  CMIS type queried for
-     * @param condition  additional condition.
-     * @return  a valid XPath predicate or <code>null</code> if none. 
+     * Build a XPath predicate for the given CMIS type and an additional
+     * condition. The additional condition should be and-ed to the condition
+     * resulting from evaluating <code>fromType</code>.
+     * 
+     * @param fromType
+     *            CMIS type queried for
+     * @param condition
+     *            additional condition.
+     * @return a valid XPath predicate or <code>null</code> if none.
      */
     protected String buildPredicates(TypeDefinition fromType, String condition) {
         String typeCondition = jcrTypeCondition(fromType);
 
         if (typeCondition == null) {
             return condition == null ? "" : "[" + condition + "]";
-        }
-        else if (condition == null) {
+        } else if (condition == null) {
             return "[" + typeCondition + "]";
-        }
-        else {
-            return "[" + typeCondition + " and " + condition + "]"; 
+        } else {
+            return "[" + typeCondition + " and " + condition + "]";
         }
     }
 
     /**
-     * Build a XPath order by clause for the given CMIS type and a list of {@link SortSpec}s.
-     *
-     * @param fromType  CMIS type queried for
-     * @param orderBys  <code>SortSpec</code>s
-     * @return  a valid XPath order by clause 
+     * Build a XPath order by clause for the given CMIS type and a list of
+     * {@link SortSpec}s.
+     * 
+     * @param fromType
+     *            CMIS type queried for
+     * @param orderBys
+     *            <code>SortSpec</code>s
+     * @return a valid XPath order by clause
      */
     protected String buildOrderByClause(TypeDefinition fromType, List<SortSpec> orderBys) {
         StringBuilder orderSpecs = new StringBuilder();
 
         for (SortSpec orderBy : orderBys) {
-            String selector = jcrPathFromCol(fromType, orderBy.getSelector().getName());  
+            String selector = jcrPathFromCol(fromType, orderBy.getSelector().getName());
             boolean ascending = orderBy.isAscending();
 
             if (orderSpecs.length() > 0) {
                 orderSpecs.append(',');
             }
 
-            orderSpecs
-                .append(selector)
-                .append(' ')
-                .append(ascending ? "ascending" : "descending");
+            orderSpecs.append(selector).append(' ').append(ascending ? "ascending" : "descending");
         }
 
-        return orderSpecs.length() > 0
-                ? "order by " + orderSpecs
-                : "";
+        return orderSpecs.length() > 0 ? "order by " + orderSpecs : "";
     }
 
-    //------------------------------------------< private >---
+    // ------------------------------------------< private >---
 
     private static String getFolderPredicate(XPathBuilder parseResult) {
         if (parseResult == null) {
             return null;
         }
-        
+
         String folderPredicate = null;
         for (XPathBuilder p : parseResult.folderPredicates()) {
             if (folderPredicate == null) {
                 folderPredicate = p.xPath();
-            }
-            else {
+            } else {
                 throw new CmisInvalidArgumentException("Query may only contain a single folder predicate");
             }
         }
 
-        // See the class comment on XPathBuilder for details on affirmative literals
-        if (folderPredicate != null &&                             // IF has single folder predicate
-            !Boolean.FALSE.equals(parseResult.eval(false))) {      // AND folder predicate is not affirmative
+        // See the class comment on XPathBuilder for details on affirmative
+        // literals
+        if (folderPredicate != null && // IF has single folder predicate
+                !Boolean.FALSE.equals(parseResult.eval(false))) { // AND folder
+                                                                  // predicate
+                                                                  // is not
+                                                                  // affirmative
             throw new CmisInvalidArgumentException("Folder predicate " + folderPredicate + " is not affirmative.");
         }
 
@@ -252,9 +263,10 @@ public abstract class QueryTranslator {
     }
 
     private static String getCondition(XPathBuilder parseResult) {
-        // No condition if either parseResult is null or when it evaluates to true under
+        // No condition if either parseResult is null or when it evaluates to
+        // true under
         // the valuation which assigns true to the folder predicate.
         return parseResult == null || Boolean.TRUE.equals(parseResult.eval(true)) ? null : parseResult.xPath();
     }
-    
+
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/XPathBuilder.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/XPathBuilder.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/XPathBuilder.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/query/XPathBuilder.java Wed Aug 21 18:36:15 2013
@@ -20,37 +20,40 @@
 package org.apache.chemistry.opencmis.jcr.query;
 
 /**
- * This result type of {@link EvaluatorXPath} provides means for partially evaluating
- * the underlying query's condition. This allows to determine whether there is a semantically
- * equivalent translation from the CMIS query's where clause to an XPath condition.
- * <br/>
- * Specifically <code>EvaluatorXPath</code> only supports a single folder predicate. That
- * is the original CMIS query must not contain more than one IN_TREE or IN_FOLDER
- * predicate respectively. Furthermore that single folder predicate must be affirmative.
- * A literal <code>p</code> in a boolean expression <code>X</code> is affirmative if there
- * exists a boolean expression <code>Y</code> such that <code>p &and; Y = X</code>.
- * <em>Note</em>: a single folder predicate is affirmative if any only if
- * {@link #eval(Boolean) <code>eval(false)</code>} return <code>false</code>.  
- * <br/>
- * Only if both conditions hold will the XPath translation provided the {@link #xPath()}
- * method be valid.
+ * This result type of {@link EvaluatorXPath} provides means for partially
+ * evaluating the underlying query's condition. This allows to determine whether
+ * there is a semantically equivalent translation from the CMIS query's where
+ * clause to an XPath condition. <br/>
+ * Specifically <code>EvaluatorXPath</code> only supports a single folder
+ * predicate. That is the original CMIS query must not contain more than one
+ * IN_TREE or IN_FOLDER predicate respectively. Furthermore that single folder
+ * predicate must be affirmative. A literal <code>p</code> in a boolean
+ * expression <code>X</code> is affirmative if there exists a boolean expression
+ * <code>Y</code> such that <code>p &and; Y = X</code>. <em>Note</em>: a single
+ * folder predicate is affirmative if any only if {@link #eval(Boolean)
+ * <code>eval(false)</code>} return <code>false</code>. <br/>
+ * Only if both conditions hold will the XPath translation provided the
+ * {@link #xPath()} method be valid.
  */
 public interface XPathBuilder {
 
     /**
-     * Translation of the underlying CMIS query's where clause to a XPath condition.
-     * The string is only valid if there is no more than one folder predicate and
-     * the folder predicate is in affirmative position.
+     * Translation of the underlying CMIS query's where clause to a XPath
+     * condition. The string is only valid if there is no more than one folder
+     * predicate and the folder predicate is in affirmative position.
      */
     String xPath();
 
     /**
-     * Evaluate the query condition for a given valuation of the folder predicate terms.
-     *
-     * @param folderPredicateValuation  valuation for the folder predicate terms. Use <code>null</code>
-     *      for none.
-     * @return  result of the partial evaluation. <code>null</code> means that the value of the
-     *      query condition is not determined the value passed for <code>folderPredicateValuation</code>.
+     * Evaluate the query condition for a given valuation of the folder
+     * predicate terms.
+     * 
+     * @param folderPredicateValuation
+     *            valuation for the folder predicate terms. Use
+     *            <code>null</code> for none.
+     * @return result of the partial evaluation. <code>null</code> means that
+     *         the value of the query condition is not determined the value
+     *         passed for <code>folderPredicateValuation</code>.
      */
     Boolean eval(Boolean folderPredicateValuation);
 

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrDocumentTypeHandler.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrDocumentTypeHandler.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrDocumentTypeHandler.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrDocumentTypeHandler.java Wed Aug 21 18:36:15 2013
@@ -29,7 +29,8 @@ import org.apache.chemistry.opencmis.jcr
 import org.apache.chemistry.opencmis.jcr.JcrNode;
 
 /**
- * Implemented by type handlers that provides a type that is or inherits from cmis:document.
+ * Implemented by type handlers that provides a type that is or inherits from
+ * cmis:document.
  */
 public interface JcrDocumentTypeHandler extends JcrTypeHandler {
 
@@ -37,9 +38,10 @@ public interface JcrDocumentTypeHandler 
 
     /**
      * See CMIS 1.0 section 2.2.4.1 createDocument
-     *
+     * 
      * @throws org.apache.chemistry.opencmis.commons.exceptions.CmisStorageException
-     *
+     * 
      */
-    JcrNode createDocument(JcrFolder parentFolder, String name, Properties properties, ContentStream contentStream, VersioningState versioningState);
+    JcrNode createDocument(JcrFolder parentFolder, String name, Properties properties, ContentStream contentStream,
+            VersioningState versioningState);
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrFolderTypeHandler.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrFolderTypeHandler.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrFolderTypeHandler.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrFolderTypeHandler.java Wed Aug 21 18:36:15 2013
@@ -24,7 +24,8 @@ import org.apache.chemistry.opencmis.com
 import org.apache.chemistry.opencmis.jcr.JcrFolder;
 
 /**
- * Implemented by type handlers that provides a type that is or inherits from cmis:folder.
+ * Implemented by type handlers that provides a type that is or inherits from
+ * cmis:folder.
  */
 public interface JcrFolderTypeHandler extends JcrTypeHandler {
 
@@ -32,9 +33,9 @@ public interface JcrFolderTypeHandler ex
 
     /**
      * See CMIS 1.0 section 2.2.4.3 createFolder
-     *
+     * 
      * @throws org.apache.chemistry.opencmis.commons.exceptions.CmisStorageException
-     *
+     * 
      */
     JcrFolder createFolder(JcrFolder parentFolder, String name, Properties properties);
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandler.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandler.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandler.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandler.java Wed Aug 21 18:36:15 2013
@@ -29,7 +29,7 @@ import org.apache.chemistry.opencmis.jcr
 
 /**
  * Provides operations for a specific CMIS object type.
- *
+ * 
  * @see JcrTypeHandlerManager
  */
 public interface JcrTypeHandler {
@@ -49,9 +49,11 @@ public interface JcrTypeHandler {
 
     /**
      * Used by QueryTranslator to translate CMIS queries to JCR queries.
-     *
+     * 
      * @see org.apache.chemistry.opencmis.jcr.query.QueryTranslator
-     * @see org.apache.chemistry.opencmis.jcr.JcrRepository#query(javax.jcr.Session, java.lang.String, java.lang.Boolean, java.lang.Boolean, java.math.BigInteger, java.math.BigInteger)
+     * @see org.apache.chemistry.opencmis.jcr.JcrRepository#query(javax.jcr.Session,
+     *      java.lang.String, java.lang.Boolean, java.lang.Boolean,
+     *      java.math.BigInteger, java.math.BigInteger)
      */
     IdentifierMap getIdentifierMap();
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandlerManager.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandlerManager.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandlerManager.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/type/JcrTypeHandlerManager.java Wed Aug 21 18:36:15 2013
@@ -39,7 +39,7 @@ import org.slf4j.LoggerFactory;
  */
 public class JcrTypeHandlerManager {
 
-    private static final Logger log = LoggerFactory.getLogger(JcrTypeHandlerManager.class);
+    private static final Logger LOG = LoggerFactory.getLogger(JcrTypeHandlerManager.class);
 
     private final PathManager pathManager;
     private final JcrTypeManager typeManager;
@@ -91,9 +91,8 @@ public class JcrTypeHandlerManager {
                         }
                     }
                     return false;
-                }
-                catch (RepositoryException e) {
-                    log.debug(e.getMessage(), e);
+                } catch (RepositoryException e) {
+                    LOG.debug(e.getMessage(), e);
                     throw new CmisRuntimeException(e.getMessage(), e);
                 }
             }
@@ -117,9 +116,8 @@ public class JcrTypeHandlerManager {
                 }
             }
             throw new CmisObjectNotFoundException("No object type for object '" + node.getIdentifier() + "'");
-        }
-        catch (RepositoryException e) {
-            log.debug(e.getMessage(), e);
+        } catch (RepositoryException e) {
+            LOG.debug(e.getMessage(), e);
             throw new CmisObjectNotFoundException(e.getMessage(), e);
         }
     }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/FilterIterator.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/FilterIterator.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/FilterIterator.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/FilterIterator.java Wed Aug 21 18:36:15 2013
@@ -24,6 +24,7 @@ import java.util.NoSuchElementException;
 
 /**
  * Iterator filtering out items which do not match a given predicate.
+ * 
  * @param <T>
  */
 public class FilterIterator<T> implements Iterator<T> {
@@ -34,9 +35,11 @@ public class FilterIterator<T> implement
 
     /**
      * Create a new filtered iterator based on the given <code>iterator</code>.
-     *
-     * @param iterator  iterator to filter
-     * @param predicate  only item matching this predicate are included
+     * 
+     * @param iterator
+     *            iterator to filter
+     * @param predicate
+     *            only item matching this predicate are included
      */
     public FilterIterator(Iterator<T> iterator, Predicate<T> predicate) {
         this.iterator = iterator;
@@ -59,8 +62,7 @@ public class FilterIterator<T> implement
             T e = next;
             next = null;
             return e;
-        }
-        else {
+        } else {
             throw new NoSuchElementException();
         }
     }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/ISO8601.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/ISO8601.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/ISO8601.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/ISO8601.java Wed Aug 21 18:36:15 2013
@@ -21,15 +21,18 @@ import java.util.GregorianCalendar;
 import java.util.TimeZone;
 
 /**
- * The <code>ISO8601</code> utility class provides helper methods
- * to deal with date/time formatting using a specific ISO8601-compliant
- * format (see <a href="http://www.w3.org/TR/NOTE-datetime">ISO 8601</a>).
+ * The <code>ISO8601</code> utility class provides helper methods to deal with
+ * date/time formatting using a specific ISO8601-compliant format (see <a
+ * href="http://www.w3.org/TR/NOTE-datetime">ISO 8601</a>).
  * <p/>
  * The currently supported format is:
+ * 
  * <pre>
  *   &plusmn;YYYY-MM-DDThh:mm:ss.SSSTZD
  * </pre>
+ * 
  * where:
+ * 
  * <pre>
  *   &plusmn;YYYY = four-digit year with optional sign where values <= 0 are
  *           denoting years BCE and values > 0 are denoting years CE,
@@ -48,15 +51,18 @@ import java.util.TimeZone;
  * <em>Note:</em> This class is copied from org.apache.jackrabbit.util.ISO8601
  */
 public final class ISO8601 {
-    private ISO8601() { }
+    private ISO8601() {
+    }
 
     /**
      * Parses an ISO8601-compliant date/time string.
-     *
-     * @param text the date/time string to be parsed
+     * 
+     * @param text
+     *            the date/time string to be parsed
      * @return a <code>Calendar</code>, or <code>null</code> if the input could
      *         not be parsed
-     * @throws IllegalArgumentException if a <code>null</code> argument is passed
+     * @throws IllegalArgumentException
+     *             if a <code>null</code> argument is passed
      */
     public static Calendar parse(String text) {
         if (text == null) {
@@ -80,9 +86,9 @@ public final class ISO8601 {
         /**
          * the expected format of the remainder of the string is:
          * YYYY-MM-DDThh:mm:ss.SSSTZD
-         *
-         * note that we cannot use java.text.SimpleDateFormat for
-         * parsing because it can't handle years <= 0 and TZD's
+         * 
+         * note that we cannot use java.text.SimpleDateFormat for parsing
+         * because it can't handle years <= 0 and TZD's
          */
 
         int year, month, day, hour, min, sec, ms;
@@ -189,8 +195,8 @@ public final class ISO8601 {
 
         try {
             /**
-             * the following call will trigger an IllegalArgumentException
-             * if any of the set values are illegal or out of range
+             * the following call will trigger an IllegalArgumentException if
+             * any of the set values are illegal or out of range
              */
             cal.getTime();
             /**
@@ -205,14 +211,16 @@ public final class ISO8601 {
     }
 
     /**
-     * Formats a <code>Calendar</code> value into an ISO8601-compliant
-     * date/time string.
-     *
-     * @param cal the time value to be formatted into a date/time string.
+     * Formats a <code>Calendar</code> value into an ISO8601-compliant date/time
+     * string.
+     * 
+     * @param cal
+     *            the time value to be formatted into a date/time string.
      * @return the formatted date/time string.
-     * @throws IllegalArgumentException if a <code>null</code> argument is passed
-     * or the calendar cannot be represented as defined by ISO 8601 (i.e. year
-     * with more than four digits).
+     * @throws IllegalArgumentException
+     *             if a <code>null</code> argument is passed or the calendar
+     *             cannot be represented as defined by ISO 8601 (i.e. year with
+     *             more than four digits).
      */
     public static String format(Calendar cal) throws IllegalArgumentException {
         if (cal == null) {
@@ -220,11 +228,10 @@ public final class ISO8601 {
         }
 
         /**
-         * the format of the date/time string is:
-         * YYYY-MM-DDThh:mm:ss.SSSTZD
-         *
-         * note that we cannot use java.text.SimpleDateFormat for
-         * formatting because it can't handle years <= 0 and TZD's
+         * the format of the date/time string is: YYYY-MM-DDThh:mm:ss.SSSTZD
+         * 
+         * note that we cannot use java.text.SimpleDateFormat for formatting
+         * because it can't handle years <= 0 and TZD's
          */
         StringBuffer buf = new StringBuffer();
         // year ([-]YYYY)
@@ -253,8 +260,7 @@ public final class ISO8601 {
         int offset = tz.getOffset(cal.getTimeInMillis());
         if (offset == 0) {
             buf.append('Z');
-        } 
-        else {
+        } else {
             int hours = Math.abs(offset / (60 * 1000) / 60);
             int minutes = Math.abs(offset / (60 * 1000) % 60);
             buf.append(offset < 0 ? '-' : '+');
@@ -267,18 +273,18 @@ public final class ISO8601 {
 
     /**
      * Returns the astronomical year of the given calendar.
-     *
-     * @param cal a calendar instance.
+     * 
+     * @param cal
+     *            a calendar instance.
      * @return the astronomical year.
-     * @throws IllegalArgumentException if calendar cannot be represented as
-     *                                  defined by ISO 8601 (i.e. year with more
-     *                                  than four digits).
+     * @throws IllegalArgumentException
+     *             if calendar cannot be represented as defined by ISO 8601
+     *             (i.e. year with more than four digits).
      */
     public static int getYear(Calendar cal) throws IllegalArgumentException {
         // determine era and adjust year if necessary
         int year = cal.get(Calendar.YEAR);
-        if (cal.isSet(Calendar.ERA)
-                && cal.get(Calendar.ERA) == GregorianCalendar.BC) {
+        if (cal.isSet(Calendar.ERA) && cal.get(Calendar.ERA) == GregorianCalendar.BC) {
 
             // calculate year using astronomical system:
             // year n BCE => astronomical year -n + 1
@@ -286,8 +292,8 @@ public final class ISO8601 {
         }
 
         if (year > 9999 || year < -9999) {
-            throw new IllegalArgumentException("Calendar has more than four " +
-                    "year digits, cannot be formatted as ISO8601: " + year);
+            throw new IllegalArgumentException("Calendar has more than four "
+                    + "year digits, cannot be formatted as ISO8601: " + year);
         }
         return year;
     }
@@ -295,12 +301,15 @@ public final class ISO8601 {
     /**
      * Appends a zero-padded number to the given string buffer.
      * <p/>
-     * This is an internal helper method which doesn't perform any
-     * validation on the given arguments.
-     *
-     * @param buf String buffer to append to
-     * @param n number to append
-     * @param precision number of digits to append
+     * This is an internal helper method which doesn't perform any validation on
+     * the given arguments.
+     * 
+     * @param buf
+     *            String buffer to append to
+     * @param n
+     *            number to append
+     * @param precision
+     *            number of digits to append
      */
     private static void appendZeroPaddedInt(StringBuffer buf, int n, int precision) {
         if (n < 0) {

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Iterables.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Iterables.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Iterables.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Iterables.java Wed Aug 21 18:36:15 2013
@@ -26,7 +26,8 @@ import org.apache.commons.collections.it
 import org.apache.commons.collections.iterators.SingletonIterator;
 
 public class Iterables {
-    private Iterables() {}
+    private Iterables() {
+    }
 
     public static <T> Iterable<T> concat(final Iterable<T> it1, final Iterable<T> it2) {
         return new Iterable<T>() {

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Predicate.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Predicate.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Predicate.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Predicate.java Wed Aug 21 18:36:15 2013
@@ -20,15 +20,16 @@
 package org.apache.chemistry.opencmis.jcr.util;
 
 /**
- * Interface for predicates of type <code>T</code>, i.e. functions from <code>T</code>
- * to <code>boolean</code>.
+ * Interface for predicates of type <code>T</code>, i.e. functions from
+ * <code>T</code> to <code>boolean</code>.
  */
 public interface Predicate<T> {
 
     /**
      * Evaluates the predicate for the given object.
-     *
-     * @param t some object
+     * 
+     * @param t
+     *            some object
      * @return predicate result
      */
     boolean evaluate(T t);

Modified: chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Util.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Util.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Util.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-server/chemistry-opencmis-server-jcr/src/main/java/org/apache/chemistry/opencmis/jcr/util/Util.java Wed Aug 21 18:36:15 2013
@@ -28,20 +28,21 @@ import javax.jcr.RepositoryException;
  * Miscellaneous utility functions
  */
 public final class Util {
-    private Util() {}
+    private Util() {
+    }
 
     /**
      * Convert from <code>Calendar</code> to a <code>GregorianCalendar</code>.
      * 
      * @param date
-     * @return  <code>date</code> if it is an instance of <code>GregorianCalendar</code>.
-     *   Otherwise a new <code>GregorianCalendar</code> instance for <code>date</code>.
+     * @return <code>date</code> if it is an instance of
+     *         <code>GregorianCalendar</code>. Otherwise a new
+     *         <code>GregorianCalendar</code> instance for <code>date</code>.
      */
     public static GregorianCalendar toCalendar(Calendar date) {
         if (date instanceof GregorianCalendar) {
             return (GregorianCalendar) date;
-        }
-        else {
+        } else {
             GregorianCalendar calendar = new GregorianCalendar();
             calendar.setTimeZone(date.getTimeZone());
             calendar.setTimeInMillis(date.getTimeInMillis());
@@ -50,13 +51,16 @@ public final class Util {
     }
 
     /**
-     * Replace every occurrence of <code>target</code> in <code>string</code> with
-     * <code>replacement</code>.
-     *
-     * @param string  string to do replacement on
-     * @param target  string to search for
-     * @param replacement  string to replace with
-     * @return  string with replacing done
+     * Replace every occurrence of <code>target</code> in <code>string</code>
+     * with <code>replacement</code>.
+     * 
+     * @param string
+     *            string to do replacement on
+     * @param target
+     *            string to search for
+     * @param replacement
+     *            string to replace with
+     * @return string with replacing done
      */
     public static String replace(String string, String target, String replacement) {
         if ("".equals(target)) {
@@ -74,8 +78,7 @@ public final class Util {
             j = string.indexOf(target, k);
             if (j < 0) {
                 result.append(string.substring(k));
-            }
-            else {
+            } else {
                 result.append(string.substring(k, j)).append(replacement);
             }
 
@@ -87,22 +90,28 @@ public final class Util {
 
     /**
      * Escapes a JCR path such that it can be used in a XPath query
+     * 
      * @param path
-     * @return  escaped path
+     * @return escaped path
      */
     public static String escape(String path) {
-        return replace(path, " ", "_x0020_"); // fixme do more thorough escaping of path
+        return replace(path, " ", "_x0020_"); // fixme do more thorough escaping
+                                              // of path
     }
-    
+
     /**
      * The repository's support option definition.
-     * @param node JCR node
-     * @param option requested repository's option
+     * 
+     * @param node
+     *            JCR node
+     * @param option
+     *            requested repository's option
      * @return true if repository supports option, otherwise false.
-     * @throws RepositoryException thrown when any error with repository was occurred.
+     * @throws RepositoryException
+     *             thrown when any error with repository was occurred.
      */
     public static boolean supportOption(Node node, String option) throws RepositoryException {
-    	return Boolean.valueOf(node.getSession().getRepository().getDescriptor(option));
+        return Boolean.valueOf(node.getSession().getRepository().getDescriptor(option));
     }
 
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/impl/TestParameters.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/impl/TestParameters.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/impl/TestParameters.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/impl/TestParameters.java Wed Aug 21 18:36:15 2013
@@ -18,7 +18,7 @@
  */
 package org.apache.chemistry.opencmis.tck.impl;
 
-public class TestParameters {
+public final class TestParameters {
 
     public static final String DEFAULT_FOLDER_TYPE = "org.apache.chemistry.opencmis.tck.default.folderType";
     public static final String DEFAULT_FOLDER_TYPE_VALUE = "cmis:folder";
@@ -40,4 +40,7 @@ public class TestParameters {
 
     public static final String DEFAULT_ACL_PRINCIPAL = "org.apache.chemistry.opencmis.tck.default.principal";
     public static final String DEFAULT_ACL_PRINCIPAL_VALUE = "cmis:user";
+
+    private TestParameters() {
+    }
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/runner/AbstractRunner.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/runner/AbstractRunner.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/runner/AbstractRunner.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-tck/src/main/java/org/apache/chemistry/opencmis/tck/runner/AbstractRunner.java Wed Aug 21 18:36:15 2013
@@ -97,6 +97,7 @@ public abstract class AbstractRunner {
 
     private String loadTCKTimestamp() {
         InputStream stream = getClass().getResourceAsStream(TCK_BUILD_TIMESTAMP);
+
         if (stream != null) {
             try {
                 return IOUtils.readAllLines(stream);

Modified: chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/content/loremipsum/LoremIpsum.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/content/loremipsum/LoremIpsum.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/content/loremipsum/LoremIpsum.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/content/loremipsum/LoremIpsum.java Wed Aug 21 18:36:15 2013
@@ -243,8 +243,8 @@ public class LoremIpsum {
     /**
      * Generates a single lorem ipsum paragraph, of random length.
      * 
-     * @param {boolean} optStartWithLorem Whether to start the sentence with
-     *        the standard "Lorem ipsum..." first sentence.
+     * @param {boolean} optStartWithLorem Whether to start the sentence with the
+     *        standard "Lorem ipsum..." first sentence.
      * @return {string} The generated sentence.
      */
     public String generateParagraph(boolean optStartWithLorem) {
@@ -274,8 +274,8 @@ public class LoremIpsum {
     /**
      * Generates a single sentence, of random length.
      * 
-     * @param {boolean} optStartWithLorem Whether to start the setnence with
-     *        the standard "Lorem ipsum..." first sentence.
+     * @param {boolean} optStartWithLorem Whether to start the setnence with the
+     *        standard "Lorem ipsum..." first sentence.
      * @return {string} The generated sentence.
      */
     public String generateSentence(boolean optStartWithLorem) {

Modified: chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjectGenerator.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjectGenerator.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjectGenerator.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-test/chemistry-opencmis-test-util/src/main/java/org/apache/chemistry/opencmis/util/repository/ObjectGenerator.java Wed Aug 21 18:36:15 2013
@@ -58,9 +58,9 @@ import org.slf4j.LoggerFactory;
 /**
  * A simple helper class for the tests that generates a sample folder hierarchy
  * and optionally documents in it.
- *
+ * 
  * @author Jens
- *
+ * 
  */
 public class ObjectGenerator {
 
@@ -81,9 +81,11 @@ public class ObjectGenerator {
 
     /**
      * supported kinds of content
-     *
+     * 
      */
-    public enum ContentKind {STATIC_TEXT, LOREM_IPSUM_TEXT, LOREM_IPSUM_HTML, IMAGE_FRACTAL_JPEG};
+    public enum ContentKind {
+        STATIC_TEXT, LOREM_IPSUM_TEXT, LOREM_IPSUM_HTML, IMAGE_FRACTAL_JPEG
+    };
 
     /**
      * Indicates if / how many documents are created in each folder
@@ -128,12 +130,11 @@ public class ObjectGenerator {
      * size of content in KB, if 0 create documents without content
      */
     private int fContentSizeInK = 0;
-    
+
     /**
      * Kind of content to create
      */
     private ContentKind fContentKind;
-    
 
     private static final String NAMEPROPVALPREFIXDOC = "My_Document-";
     private static final String NAMEPROPVALPREFIXFOLDER = "My_Folder-";
@@ -145,7 +146,7 @@ public class ObjectGenerator {
      * use UUIDs to generate folder and document names
      */
     private boolean fUseUuids;
-    
+
     /**
      * generator for images
      */
@@ -198,11 +199,11 @@ public class ObjectGenerator {
     public void setContentSizeInKB(int sizeInK) {
         fContentSizeInK = sizeInK;
     }
-    
+
     public ContentKind getContentKind() {
         return fContentKind;
     }
-    
+
     public void setLoreIpsumGenerator(ContentKind contentKind) {
         fContentKind = contentKind;
     }
@@ -245,7 +246,7 @@ public class ObjectGenerator {
     /**
      * retrieve the index-th folder from given level of the hierarchy starting
      * at rootId
-     *
+     * 
      * @param rootId
      * @param level
      * @param index
@@ -269,7 +270,7 @@ public class ObjectGenerator {
 
     /**
      * retrieve the index-th document from given folder
-     *
+     * 
      * @param folderId
      *            folder to retrieve document from
      * @param index
@@ -301,7 +302,7 @@ public class ObjectGenerator {
 
     /**
      * return the total number of documents created
-     *
+     * 
      * @return
      */
     public int getDocumentsInTotal() {
@@ -310,7 +311,7 @@ public class ObjectGenerator {
 
     /**
      * return the total number of folders created
-     *
+     * 
      * @return
      */
     public int getFoldersInTotal() {
@@ -453,7 +454,7 @@ public class ObjectGenerator {
         LOG.debug("create document in folder " + folderId);
         Properties props = createDocumentProperties(no, level);
         String id = null;
-        
+
         if (fContentSizeInK > 0) {
             switch (fContentKind) {
             case STATIC_TEXT:
@@ -518,7 +519,7 @@ public class ObjectGenerator {
         content.setFileName("data.html");
         content.setMimeType("text/html");
         int len = fContentSizeInK * KILO; // size of document in K
-        
+
         LoremIpsum ipsum = new LoremIpsum();
         String text = ipsum.generateParagraphsFullHtml(len, true);
         try {
@@ -534,7 +535,7 @@ public class ObjectGenerator {
         content.setFileName("data.txt");
         content.setMimeType("text/plain");
         int len = fContentSizeInK * 1024; // size of document in K
-        
+
         LoremIpsum ipsum = new LoremIpsum();
         String text = ipsum.generateParagraphsPlainText(len, 80, true);
         content.setStream(new ByteArrayInputStream(text.getBytes()));
@@ -577,7 +578,7 @@ public class ObjectGenerator {
             content.setFileName("image.jpg");
             content.setMimeType("image/jpeg");
             content.setStream(new ByteArrayInputStream(bos.toByteArray()));
-            bos.close();            
+            bos.close();
         } catch (IOException e) {
             System.err.println("Error when generating fractal image: " + e);
             e.printStackTrace();
@@ -732,11 +733,11 @@ public class ObjectGenerator {
     }
 
     public void createTypes(TypeDefinitionList typeDefList) {
-        
-        fTimeLoggerCreateType.reset();         
+
+        fTimeLoggerCreateType.reset();
         for (TypeDefinition td : typeDefList.getList()) {
             // TODO: enable this if available!
-//            fRepSvc.createTypeDefinition(fRepositoryId, td);
+            // fRepSvc.createTypeDefinition(fRepositoryId, td);
         }
     }
 }

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/AclEditorFrame.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/AclEditorFrame.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/AclEditorFrame.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/AclEditorFrame.java Wed Aug 21 18:36:15 2013
@@ -191,7 +191,7 @@ public class AclEditorFrame extends JFra
                 propagationPropagteButton.setEnabled(false);
             }
         } catch (Exception e) {
-            // ignore
+            propagationPropagteButton.setEnabled(true);
         }
 
         ButtonGroup propagtionGroup = new ButtonGroup();

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/ChangeLogFrame.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/ChangeLogFrame.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/ChangeLogFrame.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/ChangeLogFrame.java Wed Aug 21 18:36:15 2013
@@ -77,7 +77,8 @@ public class ChangeLogFrame extends JFra
         changeLogTokenField = new JTextField();
         try {
             changeLogTokenField.setText(model.getRepositoryInfo().getLatestChangeLogToken());
-        } catch (Exception e1) {
+        } catch (Exception e) {
+            changeLogTokenField.setText("");
         }
         inputPanel.add(changeLogTokenField, BorderLayout.CENTER);
 
@@ -196,6 +197,7 @@ public class ChangeLogFrame extends JFra
                     return event.getChangeTime();
                 case 3:
                     return event.getProperties().entrySet();
+                default:
                 }
 
                 return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/FolderTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/FolderTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/FolderTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/FolderTable.java Wed Aug 21 18:36:15 2013
@@ -270,6 +270,7 @@ public class FolderTable extends JTable 
                 return obj.getLastModifiedBy();
             case ID_COLUMN:
                 return obj.getId();
+            default:
             }
 
             return "";
@@ -285,6 +286,7 @@ public class FolderTable extends JTable 
             case 5:
             case 7:
                 return GregorianCalendar.class;
+            default:
             }
 
             return String.class;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/TypeSplitPane.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/TypeSplitPane.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/TypeSplitPane.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/TypeSplitPane.java Wed Aug 21 18:36:15 2013
@@ -384,6 +384,7 @@ public class TypeSplitPane extends JSpli
                     return propDef.isOpenChoice();
                 case 15:
                     return propDef.getChoices();
+                default:
                 }
 
                 return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/ACLTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/ACLTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/ACLTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/ACLTable.java Wed Aug 21 18:36:15 2013
@@ -79,6 +79,7 @@ public class ACLTable extends AbstractDe
             return ace.getPermissions();
         case 2:
             return ace.isDirect();
+        default:
         }
 
         return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PolicyTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PolicyTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PolicyTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PolicyTable.java Wed Aug 21 18:36:15 2013
@@ -68,6 +68,7 @@ public class PolicyTable extends Abstrac
             return policy.getName();
         case 1:
             return policy;
+        default:
         }
 
         return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PropertyTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PropertyTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PropertyTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/PropertyTable.java Wed Aug 21 18:36:15 2013
@@ -65,6 +65,7 @@ public class PropertyTable extends Abstr
             return property.getDefinition().getPropertyType().value();
         case 3:
             return property.getValues();
+        default:
         }
 
         return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RelationshipTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RelationshipTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RelationshipTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RelationshipTable.java Wed Aug 21 18:36:15 2013
@@ -80,6 +80,7 @@ public class RelationshipTable extends A
             return relationship.getSourceId();
         case 4:
             return relationship.getTarget();
+        default:
         }
 
         return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RenditionTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RenditionTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RenditionTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/RenditionTable.java Wed Aug 21 18:36:15 2013
@@ -38,7 +38,8 @@ public class RenditionTable extends Abst
 
     @Override
     public void doubleClickAction(MouseEvent e, int rowIndex) {
-        String streamId = getObject().getRenditions().get(getRowSorter().convertRowIndexToModel(rowIndex)).getStreamId();
+        String streamId = getObject().getRenditions().get(getRowSorter().convertRowIndexToModel(rowIndex))
+                .getStreamId();
 
         if (e.isShiftDown()) {
             ClientHelper.download(this.getParent(), getObject(), streamId);
@@ -71,6 +72,7 @@ public class RenditionTable extends Abst
             return rendition.getLength();
         case 4:
             return rendition.getStreamId();
+        default:
         }
 
         return null;

Modified: chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/VersionTable.java
URL: http://svn.apache.org/viewvc/chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/VersionTable.java?rev=1516250&r1=1516249&r2=1516250&view=diff
==============================================================================
--- chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/VersionTable.java (original)
+++ chemistry/opencmis/trunk/chemistry-opencmis-workbench/chemistry-opencmis-workbench/src/main/java/org/apache/chemistry/opencmis/workbench/details/VersionTable.java Wed Aug 21 18:36:15 2013
@@ -177,6 +177,7 @@ public class VersionTable extends Abstra
             return version.getContentStreamMimeType();
         case 8:
             return version.getContentStreamLength() == -1 ? null : version.getContentStreamLength();
+        default:
         }
 
         return null;