You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@olingo.apache.org by ch...@apache.org on 2013/09/20 15:33:47 UTC

[25/59] [abbrv] Cleanup of core

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/MethodExpressionImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/MethodExpressionImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/MethodExpressionImpl.java
index 506b03c..24ce1e6 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/MethodExpressionImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/MethodExpressionImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -77,7 +77,7 @@ public class MethodExpressionImpl implements MethodExpression {
 
   /**
    * @param expression
-   * @return A self reference for method chaining" 
+   * @return A self reference for method chaining"
    */
   public MethodExpressionImpl appendParameter(final CommonExpression expression) {
     actualParameters.add(expression);

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByExpressionImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByExpressionImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByExpressionImpl.java
index 870de1f..ad9b5d8 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByExpressionImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByExpressionImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParser.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParser.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParser.java
index 3c6544d..4c194db 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParser.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParser.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -25,33 +25,38 @@ import org.apache.olingo.odata2.api.uri.expression.OrderByExpression;
 /**
  * Interface which defines a method for parsing a $orderby expression to allow different parser implementations
  * <p>
- * The current expression parser supports expressions as defined in the OData specification 2.0 with the following restrictions
- *   - the methods "cast", "isof" and "replace" are not supported
- *   
+ * The current expression parser supports expressions as defined in the OData specification 2.0 with the following
+ * restrictions
+ * - the methods "cast", "isof" and "replace" are not supported
+ * 
  * The expression parser can be used with providing an Entity Data Model (EDM) an without providing it.
- *  <p>When a EDM is provided the expression parser will be as strict as possible. That means:
- *  <li>All properties used in the expression must be defined inside the EDM</li>
- *  <li>The types of EDM properties will be checked against the lists of allowed type per method, binary- and unary operator</li>
- *  </p>
- *  <p>If no EDM is provided the expression parser performs a lax validation
- *  <li>The properties used in the expression are not looked up inside the EDM and the type of the expression node representing the 
- *      property will be "null"</li>
- *  <li>Expression node with EDM-types which are "null" are not considered during the parameter type validation, to the return type of the parent expression node will
- *  also become "null"</li>
- *  
- *  
+ * <p>When a EDM is provided the expression parser will be as strict as possible. That means:
+ * <li>All properties used in the expression must be defined inside the EDM</li>
+ * <li>The types of EDM properties will be checked against the lists of allowed type per method, binary- and unary
+ * operator</li>
+ * </p>
+ * <p>If no EDM is provided the expression parser performs a lax validation
+ * <li>The properties used in the expression are not looked up inside the EDM and the type of the expression node
+ * representing the
+ * property will be "null"</li>
+ * <li>Expression node with EDM-types which are "null" are not considered during the parameter type validation, to the
+ * return type of the parent expression node will
+ * also become "null"</li>
+ * 
+ * 
  */
 public interface OrderByParser {
   /**
    * Parses a $orderby expression string and creates an $orderby expression tree
    * @param orderByExpression
-   *   The $orderby expression string ( for example "name asc" ) to be parsed
+   * The $orderby expression string ( for example "name asc" ) to be parsed
    * @return
-   *    The $orderby expression tree
+   * The $orderby expression tree
    * @throws ExpressionParserException
-   *   Exception thrown due to errors while parsing the $orderby expression string 
+   * Exception thrown due to errors while parsing the $orderby expression string
    * @throws ODataMessageException
-   *   Used for extensibility
+   * Used for extensibility
    */
-  abstract OrderByExpression parseOrderByString(String orderByExpression) throws ExpressionParserException, ODataMessageException;
+  abstract OrderByExpression parseOrderByString(String orderByExpression) throws ExpressionParserException,
+      ODataMessageException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParserImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParserImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParserImpl.java
index d81a412..6cda554 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParserImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderByParserImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -30,12 +30,13 @@ public class OrderByParserImpl extends FilterParserImpl implements OrderByParser
   }
 
   @Override
-  public OrderByExpression parseOrderByString(final String orderByExpression) throws ExpressionParserException, ExpressionParserInternalError {
+  public OrderByExpression parseOrderByString(final String orderByExpression) throws ExpressionParserException,
+      ExpressionParserInternalError {
     curExpression = orderByExpression;
     OrderByExpressionImpl orderCollection = new OrderByExpressionImpl(curExpression);
 
     try {
-      tokenList = new Tokenizer(orderByExpression).tokenize(); //throws TokenizerMessage
+      tokenList = new Tokenizer(orderByExpression).tokenize(); // throws TokenizerMessage
     } catch (TokenizerException tokenizerException) {
       throw FilterParserExceptionImpl.createERROR_IN_TOKENIZER(tokenizerException, curExpression);
     }
@@ -52,7 +53,7 @@ public class OrderByParserImpl extends FilterParserImpl implements OrderByParser
 
       OrderExpressionImpl orderNode = new OrderExpressionImpl(node);
 
-      //read the sort order
+      // read the sort order
       Token token = tokenList.lookToken();
       if (token == null) {
         orderNode.setSortOrder(SortOrder.asc);
@@ -73,7 +74,7 @@ public class OrderByParserImpl extends FilterParserImpl implements OrderByParser
 
       orderCollection.addOrder(orderNode);
 
-      //ls_token may be a ',' or  empty.
+      // ls_token may be a ',' or empty.
       if (token == null) {
         break;
       } else if (token.getKind() == TokenKind.COMMA) {
@@ -85,7 +86,7 @@ public class OrderByParserImpl extends FilterParserImpl implements OrderByParser
           // Tested with TestParserExceptions.TestOPMparseOrderByString CASE 2
           throw FilterParserExceptionImpl.createEXPRESSION_EXPECTED_AFTER_POS(oldToken, curExpression);
         }
-      } else { //e.g. in case $orderby=String asc a
+      } else { // e.g. in case $orderby=String asc a
 
         throw FilterParserExceptionImpl.createCOMMA_OR_END_EXPECTED_AT_POS(token, curExpression);
       }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderExpressionImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderExpressionImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderExpressionImpl.java
index 83e1fe3..796e5ff 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderExpressionImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/OrderExpressionImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSet.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSet.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSet.java
index d667020..b9ce742 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSet.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSet.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -26,12 +26,12 @@ import org.apache.olingo.odata2.api.edm.EdmType;
 import org.apache.olingo.odata2.api.edm.EdmTypeKind;
 
 /**
- * Parameter set is a vector of 1 or more EDM types, it is used to store the possible 
+ * Parameter set is a vector of 1 or more EDM types, it is used to store the possible
  * input and return types of a <i>OData filter operator</i> or <i>OData filter method</i>
- * @see InfoMethod 
- * @see InfoBinaryOperator 
+ * @see InfoMethod
+ * @see InfoBinaryOperator
  * @see InfoUnaryOperator
- *   
+ * 
  */
 @SuppressWarnings("javadoc")
 public class ParameterSet {
@@ -50,7 +50,8 @@ public class ParameterSet {
     types.add(type2);
   }
 
-  public ParameterSet(final EdmSimpleType returnType, final EdmSimpleType type1, final EdmSimpleType type2, final EdmSimpleType type3) {
+  public ParameterSet(final EdmSimpleType returnType, final EdmSimpleType type1, final EdmSimpleType type2,
+      final EdmSimpleType type3) {
     this.returnType = returnType;
     types.add(type1);
     types.add(type2);
@@ -73,27 +74,30 @@ public class ParameterSet {
   /**
    * Compares a list of EdmTypes with the EdmTypes stored in {@link #types}.
    * The lists are compared sequentially, e.g index N of actualParameterTypes with index N of {@link #types}.
-   * If the input list contains more elements than stored in {@link #types} (which is allowed  when validating the <i>concat</i> method
-   * which takes a variable number of input parameters), the actual parameter type is compared against the {@link #furtherType}.
+   * If the input list contains more elements than stored in {@link #types} (which is allowed when validating the
+   * <i>concat</i> method
+   * which takes a variable number of input parameters), the actual parameter type is compared against the
+   * {@link #furtherType}.
    * @param actualParameterTypes
    * @param allowPromotion
    * @return true if equals
    * @throws ExpressionParserInternalError
    */
-  public boolean equals(final List<EdmType> actualParameterTypes, final boolean allowPromotion) throws ExpressionParserInternalError {
+  public boolean equals(final List<EdmType> actualParameterTypes, final boolean allowPromotion)
+      throws ExpressionParserInternalError {
     int actSize = actualParameterTypes.size();
     int paramSize = types.size();
 
     if (actSize < paramSize) {
       return false;
-      //throw FilterParserInternalError.createINVALID_TYPE_COUNT(); //to few actual Parameters
+      // throw FilterParserInternalError.createINVALID_TYPE_COUNT(); //to few actual Parameters
     }
 
-    //This may happen if the number of supplied actual method parameters is higher then than the number
-    //of allowed method parameters but this should be checked before, hence this is an internal error in the parser
+    // This may happen if the number of supplied actual method parameters is higher then than the number
+    // of allowed method parameters but this should be checked before, hence this is an internal error in the parser
     if ((actSize > paramSize) && (furtherType == null)) {
       return false;
-      //throw FilterParserInternalError.createINVALID_TYPE_COUNT();
+      // throw FilterParserInternalError.createINVALID_TYPE_COUNT();
     }
 
     for (int i = 0; i < actSize; i++) {
@@ -106,24 +110,24 @@ public class ParameterSet {
       if (i < paramSize) {
         paramType = types.get(i);
       } else {
-        paramType = furtherType; // for methods with variable amount of method parameters  
+        paramType = furtherType; // for methods with variable amount of method parameters
       }
 
       if (!actType.equals(paramType)) {
-        //this the parameter type does not fit and if it is not allowed to promoted the actual parameter then
-        //this parameter combination does not fit
+        // this the parameter type does not fit and if it is not allowed to promoted the actual parameter then
+        // this parameter combination does not fit
         if (!allowPromotion) {
           return false;
         }
 
-        //Its allowed to promoted the actual parameter!!!
+        // Its allowed to promoted the actual parameter!!!
 
-        //Promotion only allowed for simple types
+        // Promotion only allowed for simple types
         if (actType.getKind() != EdmTypeKind.SIMPLE) {
-          return false; //Tested with TestParserExceptions.testAdditionalStuff CASE 8
+          return false; // Tested with TestParserExceptions.testAdditionalStuff CASE 8
         }
 
-        //The type simply don't match          
+        // The type simply don't match
         if (!paramType.isCompatible((EdmSimpleType) actType)) {
           return false;
         }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSetCombination.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSetCombination.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSetCombination.java
index a989055..ecc94b0 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSetCombination.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/ParameterSetCombination.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -52,7 +52,7 @@ public interface ParameterSetCombination {
         return combinations.get(0).getReturnType();
       }
 
-      //There are more than 1 possible return type, check if they are equal, if not return null.
+      // There are more than 1 possible return type, check if they are equal, if not return null.
       EdmType returnType = combinations.get(0).getReturnType();
       for (int i = 1; i < parameterCount; i++) {
         if (returnType != combinations.get(i)) {
@@ -81,7 +81,7 @@ public interface ParameterSetCombination {
         return new ParameterSet(null, null);
       }
 
-      //first check for exact parameter combination
+      // first check for exact parameter combination
       for (ParameterSet parameterSet : combinations) {
         boolean s = parameterSet.equals(actualParameterTypes, false);
         if (s) {
@@ -89,7 +89,7 @@ public interface ParameterSetCombination {
         }
       }
 
-      //first check for parameter combination with promotion
+      // first check for parameter combination with promotion
       for (ParameterSet parameterSet : combinations) {
         boolean s = parameterSet.equals(actualParameterTypes, true);
         if (s) {
@@ -117,13 +117,14 @@ public interface ParameterSetCombination {
     public ParameterSet validate(final List<EdmType> actualParameterTypes) throws ExpressionParserInternalError {
       EdmType xxx = actualParameterTypes.get(actualParameterTypes.size() - 1);
       return new ParameterSet(xxx, null);
-      //return actualParameterTypes.get(actualParameterTypes.size() - 1);
+      // return actualParameterTypes.get(actualParameterTypes.size() - 1);
     }
 
     @Override
     public EdmType getReturnType() {
-      //If the return type is always the type of the last parameter of the actual parameters ( e.g. when using the method operator) 
-      //then the return type can not predicted.
+      // If the return type is always the type of the last parameter of the actual parameters ( e.g. when using the
+      // method operator)
+      // then the return type can not predicted.
       return null;
     }
   }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/PropertyExpressionImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/PropertyExpressionImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/PropertyExpressionImpl.java
index 7e13237..ac19e47 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/PropertyExpressionImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/PropertyExpressionImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -43,7 +43,7 @@ public class PropertyExpressionImpl implements PropertyExpression {
   }
 
   public CommonExpression setEdmProperty(final EdmTyped edmProperty) {
-    //used EdmTyped because it may be a EdmProperty or a EdmNavigationProperty
+    // used EdmTyped because it may be a EdmProperty or a EdmNavigationProperty
     this.edmProperty = edmProperty;
     return this;
   }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Token.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Token.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Token.java
index e1f0354..e4a7dfb 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Token.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Token.java
@@ -1,24 +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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
-/*1*/
+/* 1 */
 
 import org.apache.olingo.odata2.api.edm.EdmLiteral;
 import org.apache.olingo.odata2.api.edm.EdmType;

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenKind.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenKind.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenKind.java
index fff6bb2..f8a93cd 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenKind.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenKind.java
@@ -1,28 +1,28 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
-/*1*/
+/* 1 */
 
 /**
  * The token kind is used to categorize a single {@link Token}.
- * The Expression parser ({@link FilterParserImpl}) uses this information 
+ * The Expression parser ({@link FilterParserImpl}) uses this information
  * to build the expression tree.
  */
 public enum TokenKind {
@@ -47,16 +47,16 @@ public enum TokenKind {
   COMMA,
 
   /**
-   * Indicates that the token is a typed literal. That may be a 
+   * Indicates that the token is a typed literal. That may be a
    * Edm.String like 'TEST'
-   * Edm.Double like '1.1D' 
+   * Edm.Double like '1.1D'
    * or any other Edm.Simple Type
    */
   SIMPLE_TYPE,
 
   /**
    * Indicates that the token is a single symbol. That may be a
-   * '-', '=', '/', '?', '.' or a '*' character  
+   * '-', '=', '/', '?', '.' or a '*' character
    */
   SYMBOL,
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenList.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenList.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenList.java
index e08ba17..4dbef4a 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenList.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenList.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -33,7 +33,7 @@ public class TokenList implements Iterator<Token> {
 
   /**
    * Append StringValue Token to tokens parameter
-   * @param position Position of parsed token 
+   * @param position Position of parsed token
    * @param kind Kind of parsed token
    * @param uriLiteral String value of parsed token
    */
@@ -45,7 +45,7 @@ public class TokenList implements Iterator<Token> {
 
   /**
    * Append CharValue Token to tokens parameter
-   * @param position Position of parsed token 
+   * @param position Position of parsed token
    * @param kind Kind of parsed token
    * @param charValue Char value of parsed token
    */
@@ -57,11 +57,12 @@ public class TokenList implements Iterator<Token> {
 
   /**
    * Append UriLiteral Token to tokens parameter
-   * @param position Position of parsed token 
+   * @param position Position of parsed token
    * @param kind Kind of parsed token
-   * @param javaLiteral EdmLiteral of parsed token containing type and value of UriLiteral 
+   * @param javaLiteral EdmLiteral of parsed token containing type and value of UriLiteral
    */
-  public void appendEdmTypedToken(final int position, final TokenKind kind, final String uriLiteral, final EdmLiteral javaLiteral) {
+  public void appendEdmTypedToken(final int position, final TokenKind kind, final String uriLiteral,
+      final EdmLiteral javaLiteral) {
     Token token = new Token(kind, position, uriLiteral, javaLiteral);
     tokens.add(token);
     return;
@@ -105,7 +106,8 @@ public class TokenList implements Iterator<Token> {
     return actual;
   }
 
-  public Token expectToken(final TokenKind comma, final boolean throwFilterExpression) throws ExpressionParserInternalError {
+  public Token expectToken(final TokenKind comma, final boolean throwFilterExpression)
+      throws ExpressionParserInternalError {
     Token actual = next();
     if (actual == null) {
       throw ExpressionParserInternalError.createNO_TOKEN_AVAILABLE(comma.toString());

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Tokenizer.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Tokenizer.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Tokenizer.java
index 6cbc165..519f493 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Tokenizer.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/Tokenizer.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -30,13 +30,16 @@ import org.apache.olingo.odata2.core.edm.EdmSimpleTypeFacadeImpl;
 
 /**
  * Expression tokenizer
- *  
+ * 
  */
 public class Tokenizer {
 
-  //Pattern OTHER_LIT = Pattern.compile("^([[A-Za-z0-9]._~%!$&*+;:@-]+)");
+  // Pattern OTHER_LIT = Pattern.compile("^([[A-Za-z0-9]._~%!$&*+;:@-]+)");
   private static final Pattern OTHER_LIT = Pattern.compile("(?:\\p{L}|\\p{Digit}|[-._~%!$&*+;:@])+");
-  private static final Pattern FUNK = Pattern.compile("^(startswith|endswith|substring|substring|substringof|indexof|replace|tolower|toupper|trim|concat|length|year|mounth|day|hour|minute|second|round|ceiling|floor)( *)\\(");
+  private static final Pattern FUNK =
+      Pattern
+          .compile("^(startswith|endswith|substring|substring|substringof|indexof|replace|tolower|toupper" +
+          		"|trim|concat|length|year|mounth|day|hour|minute|second|round|ceiling|floor)( *)\\(");
   private static final Pattern AND_SUB1 = Pattern.compile("^(add|sub|mul|div|mod|not) ");
   private static final Pattern AND_SUB = Pattern.compile("^(and|or|eq|ne|lt|gt|le|ge) ");
   private static final Pattern prefix = Pattern.compile("^(X|binary|guid|datetime|datetimeoffset|time)'");
@@ -66,8 +69,8 @@ public class Tokenizer {
   }
 
   /**
-   * Tokenizes an expression as defined per OData specification 
-   * @return Token list 
+   * Tokenizes an expression as defined per OData specification
+   * @return Token list
    */
   public TokenList tokenize() throws TokenizerException, ExpressionParserException {
     curPosition = 0;
@@ -81,7 +84,7 @@ public class Tokenizer {
       curCharacter = expression.charAt(curPosition);
       switch (curCharacter) {
       case ' ':
-        //count whitespace and move pointer to next non-whitespace char
+        // count whitespace and move pointer to next non-whitespace char
         eatWhiteSpaces(curPosition, curCharacter);
         break;
 
@@ -117,26 +120,26 @@ public class Tokenizer {
         break;
 
       default:
-        String rem_expr = expression.substring(curPosition); //remaining expression
+        String rem_expr = expression.substring(curPosition); // remaining expression
 
         boolean isBinary = checkForBinary(oldPosition, rem_expr);
         if (isBinary) {
           break;
         }
 
-        //check for prefixes like X, binary, guid, datetime
+        // check for prefixes like X, binary, guid, datetime
         boolean isPrefix = checkForPrefix(rem_expr);
         if (isPrefix) {
           break;
         }
 
-        //check for math
+        // check for math
         boolean isMath = checkForMath(oldPosition, rem_expr);
         if (isMath) {
           break;
         }
 
-        //check for function
+        // check for function
         boolean isFunction = checkForMethod(oldPosition, rem_expr);
         if (isFunction) {
           break;
@@ -171,7 +174,7 @@ public class Tokenizer {
         tokens.appendEdmTypedToken(oldPosition, TokenKind.SIMPLE_TYPE, token, edmLiteral);
         isLiteral = true;
       } catch (EdmLiteralException e) {
-        // We treat it as normal untyped literal. 
+        // We treat it as normal untyped literal.
 
         // The '-' is checked here (and not in the switch statement) because it may be
         // part of a negative number.
@@ -193,7 +196,8 @@ public class Tokenizer {
     boolean isBoolean = false;
     if (rem_expr.equals("true") || rem_expr.equals("false")) {
       curPosition = curPosition + rem_expr.length();
-      tokens.appendEdmTypedToken(oldPosition, TokenKind.SIMPLE_TYPE, rem_expr, new EdmLiteral(EdmSimpleTypeFacadeImpl.getEdmSimpleType(EdmSimpleTypeKind.Boolean), rem_expr));
+      tokens.appendEdmTypedToken(oldPosition, TokenKind.SIMPLE_TYPE, rem_expr, new EdmLiteral(EdmSimpleTypeFacadeImpl
+          .getEdmSimpleType(EdmSimpleTypeKind.Boolean), rem_expr));
       isBoolean = true;
     }
     return isBoolean;
@@ -262,7 +266,7 @@ public class Tokenizer {
     if (matcher.find()) {
       token = matcher.group(1);
       curPosition = curPosition + token.length();
-      curCharacter = expression.charAt(curPosition); //"should  be '
+      curCharacter = expression.charAt(curPosition); // "should be '
       readLiteral(curCharacter, token);
       isPrefix = true;
     }
@@ -286,7 +290,7 @@ public class Tokenizer {
     token = token + Character.toString(curCharacter);
     curPosition = curPosition + 1;
 
-    boolean wasApostroph = false; //leading ' does not count
+    boolean wasApostroph = false; // leading ' does not count
     while (curPosition < expressionLength) {
       curCharacter = expression.charAt(curPosition);
 
@@ -299,7 +303,7 @@ public class Tokenizer {
         wasApostroph = false;
       } else {
         if (wasApostroph) {
-          wasApostroph = false; //a double ' is a normal character '
+          wasApostroph = false; // a double ' is a normal character '
         } else {
           wasApostroph = true;
           token = token + curCharacter;
@@ -309,7 +313,7 @@ public class Tokenizer {
     }
 
     if (!wasApostroph) {
-      //Exception tested within TestPMparseFilterString
+      // Exception tested within TestPMparseFilterString
       throw FilterParserExceptionImpl.createTOKEN_UNDETERMINATED_STRING(oldPosition, expression);
     }
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerException.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerException.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerException.java
index a942ba5..cb02bbd 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerException.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerException.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -25,14 +25,16 @@ import org.apache.olingo.odata2.api.exception.ODataMessageException;
 /**
  * This exception is thrown if there is an error during tokenizing.<br>
  * <b>This exception in not in the public API</b>, but may be added as cause for
- * the {@link org.apache.olingo.odata2.api.uri.expression.ExpressionParserException} exception.  
- *  
+ * the {@link org.apache.olingo.odata2.api.uri.expression.ExpressionParserException} exception.
+ * 
  */
 public class TokenizerException extends ODataMessageException {
   private static final long serialVersionUID = 77L;
 
-  public static final MessageReference TYPEDECTECTION_FAILED_ON_STRING = createMessageReference(TokenizerException.class, "TYPEDECTECTION_FAILED_ON_STRING");
-  public static final MessageReference UNKNOWN_CHARACTER = createMessageReference(TokenizerException.class, "UNKNOWN_CHARACTER");
+  public static final MessageReference TYPEDECTECTION_FAILED_ON_STRING = createMessageReference(
+      TokenizerException.class, "TYPEDECTECTION_FAILED_ON_STRING");
+  public static final MessageReference UNKNOWN_CHARACTER = createMessageReference(TokenizerException.class,
+      "UNKNOWN_CHARACTER");
 
   private Token token;
   private int position;
@@ -62,7 +64,8 @@ public class TokenizerException extends ODataMessageException {
     super(messageReference, cause);
   }
 
-  static public TokenizerException createTYPEDECTECTION_FAILED_ON_STRING(final EdmLiteralException ex, final int position, final String uriLiteral) {
+  static public TokenizerException createTYPEDECTECTION_FAILED_ON_STRING(final EdmLiteralException ex,
+      final int position, final String uriLiteral) {
     MessageReference msgRef = TokenizerException.TYPEDECTECTION_FAILED_ON_STRING.create();
 
     msgRef.addContent(uriLiteral);
@@ -73,18 +76,20 @@ public class TokenizerException extends ODataMessageException {
   }
 
   /*
-  static public TokenizerException createTYPEDECTECTION_FAILED_ON_EDMTYPE(EdmLiteralException ex, int position, String uriLiteral)
-  {
-    MessageReference msgRef = TokenizerException.TYPEDECTECTION_FAILED_ON_EDMTYPE.create();
-
-    msgRef.addContent(uriLiteral);
-    msgRef.addContent(position);
-    Token token = new Token(TokenKind.UNKNOWN, position, uriLiteral);
-
-    return new TokenizerException(msgRef).setToken(token);
-  }
-  */
-  static public TokenizerException createUNKNOWN_CHARACTER(final int position, final String uriLiteral, final String expression) {
+   * static public TokenizerException createTYPEDECTECTION_FAILED_ON_EDMTYPE(EdmLiteralException ex, int position,
+   * String uriLiteral)
+   * {
+   * MessageReference msgRef = TokenizerException.TYPEDECTECTION_FAILED_ON_EDMTYPE.create();
+   * 
+   * msgRef.addContent(uriLiteral);
+   * msgRef.addContent(position);
+   * Token token = new Token(TokenKind.UNKNOWN, position, uriLiteral);
+   * 
+   * return new TokenizerException(msgRef).setToken(token);
+   * }
+   */
+  static public TokenizerException createUNKNOWN_CHARACTER(final int position, final String uriLiteral,
+      final String expression) {
     MessageReference msgRef = TokenizerException.UNKNOWN_CHARACTER.create();
 
     msgRef.addContent(uriLiteral);

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerExpectError.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerExpectError.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerExpectError.java
index 6b98f8a..64a9fba 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerExpectError.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerExpectError.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
@@ -23,24 +23,27 @@ import org.apache.olingo.odata2.api.exception.ODataMessageException;
 
 /**
  * This exception is thrown if a token should be read
- * from the top of the {@link TokenList} which does not match an 
- * expected token. The cause for using this exception <b>MUST</b> indicate an internal error 
+ * from the top of the {@link TokenList} which does not match an
+ * expected token. The cause for using this exception <b>MUST</b> indicate an internal error
  * in the {@link Tokenizer} or inside the {@link FilterParserImpl}.
  * <br><br>
  * <b>This exception in not in the public API</b>, but may be added as cause for
- * the {@link ExpressionParserInternalError} exception. 
- *  
-  */
+ * the {@link ExpressionParserInternalError} exception.
+ * 
+ */
 public class TokenizerExpectError extends ODataMessageException {
 
   private static final long serialVersionUID = 1L;
 
   public static final int parseStringpoken = 1;
 
-  //Invalid token detected at position &POSITION&
-  public static final MessageReference NO_TOKEN_AVAILABLE = createMessageReference(TokenizerExpectError.class, "NO_TOKEN_AVAILABLE");
-  public static final MessageReference INVALID_TOKEN_AT = createMessageReference(TokenizerExpectError.class, "INVALID_TOKEN_AT");
-  public static final MessageReference INVALID_TOKENKIND_AT = createMessageReference(TokenizerExpectError.class, "INVALID_TOKENKIND_AT");
+  // Invalid token detected at position &POSITION&
+  public static final MessageReference NO_TOKEN_AVAILABLE = createMessageReference(TokenizerExpectError.class,
+      "NO_TOKEN_AVAILABLE");
+  public static final MessageReference INVALID_TOKEN_AT = createMessageReference(TokenizerExpectError.class,
+      "INVALID_TOKEN_AT");
+  public static final MessageReference INVALID_TOKENKIND_AT = createMessageReference(TokenizerExpectError.class,
+      "INVALID_TOKENKIND_AT");
 
   private String token;
   private Exception previous;
@@ -84,7 +87,8 @@ public class TokenizerExpectError extends ODataMessageException {
     return new TokenizerExpectError(msgRef);
   }
 
-  public static TokenizerExpectError createINVALID_TOKENKIND_AT(final TokenKind expectedTokenKind, final Token actualToken) {
+  public static TokenizerExpectError createINVALID_TOKENKIND_AT(final TokenKind expectedTokenKind,
+      final Token actualToken) {
     MessageReference msgRef = TokenizerExpectError.INVALID_TOKEN_AT.create();
 
     msgRef.addContent(expectedTokenKind.toString());

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerRTException.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerRTException.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerRTException.java
index 05c5b79..3589b9d 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerRTException.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/TokenizerRTException.java
@@ -1,26 +1,26 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 
 /**
  * Internal error. If used(thrown) the thrower
- *   
+ * 
  */
 public class TokenizerRTException extends Exception {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/UnaryExpressionImpl.java
----------------------------------------------------------------------
diff --git a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/UnaryExpressionImpl.java b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/UnaryExpressionImpl.java
index 1d07681..a9faa84 100644
--- a/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/UnaryExpressionImpl.java
+++ b/odata-core/src/main/java/org/apache/olingo/odata2/core/uri/expression/UnaryExpressionImpl.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core.uri.expression;
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/test/java/org/apache/olingo/odata2/core/ContentNegotiatorTest.java
----------------------------------------------------------------------
diff --git a/odata-core/src/test/java/org/apache/olingo/odata2/core/ContentNegotiatorTest.java b/odata-core/src/test/java/org/apache/olingo/odata2/core/ContentNegotiatorTest.java
index 475ffb6..a45da48 100644
--- a/odata-core/src/test/java/org/apache/olingo/odata2/core/ContentNegotiatorTest.java
+++ b/odata-core/src/test/java/org/apache/olingo/odata2/core/ContentNegotiatorTest.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core;
 
@@ -40,33 +40,36 @@ import org.mockito.Mockito;
  *  
  */
 public class ContentNegotiatorTest {
-  
-  private void negotiateContentType(final List<ContentType> contentTypes, final List<ContentType> supportedTypes, final String expected) throws ODataException {
+
+  private void negotiateContentType(final List<ContentType> contentTypes, final List<ContentType> supportedTypes,
+      final String expected) throws ODataException {
     final ContentType contentType = new ContentNegotiator().contentNegotiation(contentTypes, supportedTypes);
     assertEquals(expected, contentType.toContentTypeString());
   }
 
-  @Test(expected=IllegalArgumentException.class)
+  @Test(expected = IllegalArgumentException.class)
   public void invalidContentNegotiatorCreation() throws ODataException {
     final ContentType contentType = new ContentNegotiator().doContentNegotiation(null, null, null);
     assertNull(contentType);
   }
 
-  @Test(expected=IllegalArgumentException.class)
+  @Test(expected = IllegalArgumentException.class)
   public void invalidContentNegotiatorCreationNullRequest() throws ODataException {
     UriInfoImpl uriInfo = Mockito.mock(UriInfoImpl.class);
-    final ContentType contentType = new ContentNegotiator().doContentNegotiation(null, uriInfo, new ArrayList<String>());
+    final ContentType contentType =
+        new ContentNegotiator().doContentNegotiation(null, uriInfo, new ArrayList<String>());
     assertNull(contentType);
   }
 
-  @Test(expected=IllegalArgumentException.class)
+  @Test(expected = IllegalArgumentException.class)
   public void invalidContentNegotiatorCreationNullUri() throws ODataException {
     ODataRequest request = Mockito.mock(ODataRequest.class);
-    final ContentType contentType = new ContentNegotiator().doContentNegotiation(request, null, new ArrayList<String>());
+    final ContentType contentType =
+        new ContentNegotiator().doContentNegotiation(request, null, new ArrayList<String>());
     assertNull(contentType);
   }
 
-  @Test(expected=IllegalArgumentException.class)
+  @Test(expected = IllegalArgumentException.class)
   public void invalidContentNegotiatorCreationNullSupported() throws ODataException {
     ODataRequest request = Mockito.mock(ODataRequest.class);
     UriInfoImpl uriInfo = Mockito.mock(UriInfoImpl.class);
@@ -184,7 +187,9 @@ public class ContentNegotiatorTest {
     negotiateContentTypeCharset("application/xml; charset=utf-8", "application/xml;charset=utf-8", true);
   }
 
-  private void negotiateContentTypeCharset(final String requestType, final String supportedType, final boolean asFormat) throws ODataException {
+  private void
+      negotiateContentTypeCharset(final String requestType, final String supportedType, final boolean asFormat)
+          throws ODataException {
     UriInfoImpl uriInfo = Mockito.mock(UriInfoImpl.class);
     Mockito.when(uriInfo.getUriType()).thenReturn(UriType.URI1);
     if (asFormat) {
@@ -198,11 +203,11 @@ public class ContentNegotiatorTest {
     Mockito.when(request.getMethod()).thenReturn(ODataHttpMethod.GET);
     Mockito.when(request.getRequestHeaderValue(HttpHeaders.ACCEPT)).thenReturn(requestType);
     Mockito.when(request.getAcceptHeaders()).thenReturn(acceptedContentTypes);
-    
-    
+
     // perform
     ContentNegotiator negotiator = new ContentNegotiator();
-    String negotiatedContentType = negotiator.doContentNegotiation(request, uriInfo, supportedContentTypes).toContentTypeString();
+    String negotiatedContentType =
+        negotiator.doContentNegotiation(request, uriInfo, supportedContentTypes).toContentTypeString();
 
     // verify
     assertEquals(supportedType, negotiatedContentType);

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/test/java/org/apache/olingo/odata2/core/DispatcherTest.java
----------------------------------------------------------------------
diff --git a/odata-core/src/test/java/org/apache/olingo/odata2/core/DispatcherTest.java b/odata-core/src/test/java/org/apache/olingo/odata2/core/DispatcherTest.java
index 040d628..717f031 100644
--- a/odata-core/src/test/java/org/apache/olingo/odata2/core/DispatcherTest.java
+++ b/odata-core/src/test/java/org/apache/olingo/odata2/core/DispatcherTest.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core;
 
@@ -65,7 +65,7 @@ import org.mockito.stubbing.Answer;
 
 /**
  * Tests for request dispatching according to URI type and HTTP method.
- *  
+ * 
  */
 public class DispatcherTest extends BaseTest {
 
@@ -76,37 +76,49 @@ public class DispatcherTest extends BaseTest {
     EntitySetProcessor entitySet = mock(EntitySetProcessor.class);
     when(entitySet.readEntitySet(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entitySet.countEntitySet(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entitySet.createEntity(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(entitySet.createEntity(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(
+        getAnswer());
 
     EntityProcessor entity = mock(EntityProcessor.class);
     when(entity.readEntity(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entity.existsEntity(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entity.deleteEntity(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entity.updateEntity(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyBoolean(), anyString())).thenAnswer(getAnswer());
+    when(entity.updateEntity(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyBoolean(), anyString()))
+        .thenAnswer(getAnswer());
 
     EntityComplexPropertyProcessor entityComplexProperty = mock(EntityComplexPropertyProcessor.class);
     when(entityComplexProperty.readEntityComplexProperty(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entityComplexProperty.updateEntityComplexProperty(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyBoolean(), anyString())).thenAnswer(getAnswer());
+    when(
+        entityComplexProperty.updateEntityComplexProperty(any(UriInfoImpl.class), any(InputStream.class), anyString(),
+            anyBoolean(), anyString())).thenAnswer(getAnswer());
 
     EntitySimplePropertyProcessor entitySimpleProperty = mock(EntitySimplePropertyProcessor.class);
     when(entitySimpleProperty.readEntitySimpleProperty(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entitySimpleProperty.updateEntitySimpleProperty(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(
+        entitySimpleProperty.updateEntitySimpleProperty(any(UriInfoImpl.class), any(InputStream.class), anyString(),
+            anyString())).thenAnswer(getAnswer());
 
     EntitySimplePropertyValueProcessor entitySimplePropertyValue = mock(EntitySimplePropertyValueProcessor.class);
-    when(entitySimplePropertyValue.readEntitySimplePropertyValue(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entitySimplePropertyValue.deleteEntitySimplePropertyValue(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entitySimplePropertyValue.updateEntitySimplePropertyValue(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(entitySimplePropertyValue.readEntitySimplePropertyValue(any(UriInfoImpl.class), anyString())).thenAnswer(
+        getAnswer());
+    when(entitySimplePropertyValue.deleteEntitySimplePropertyValue(any(UriInfoImpl.class), anyString())).thenAnswer(
+        getAnswer());
+    when(
+        entitySimplePropertyValue.updateEntitySimplePropertyValue(any(UriInfoImpl.class), any(InputStream.class),
+            anyString(), anyString())).thenAnswer(getAnswer());
 
     EntityLinkProcessor entityLink = mock(EntityLinkProcessor.class);
     when(entityLink.readEntityLink(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entityLink.existsEntityLink(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entityLink.deleteEntityLink(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entityLink.updateEntityLink(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(entityLink.updateEntityLink(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString()))
+        .thenAnswer(getAnswer());
 
     EntityLinksProcessor entityLinks = mock(EntityLinksProcessor.class);
     when(entityLinks.readEntityLinks(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entityLinks.countEntityLinks(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entityLinks.createEntityLink(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(entityLinks.createEntityLink(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString()))
+        .thenAnswer(getAnswer());
 
     MetadataProcessor metadata = mock(MetadataProcessor.class);
     when(metadata.readMetadata(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
@@ -123,7 +135,8 @@ public class DispatcherTest extends BaseTest {
     EntityMediaProcessor entityMedia = mock(EntityMediaProcessor.class);
     when(entityMedia.readEntityMedia(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
     when(entityMedia.deleteEntityMedia(any(UriInfoImpl.class), anyString())).thenAnswer(getAnswer());
-    when(entityMedia.updateEntityMedia(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString())).thenAnswer(getAnswer());
+    when(entityMedia.updateEntityMedia(any(UriInfoImpl.class), any(InputStream.class), anyString(), anyString()))
+        .thenAnswer(getAnswer());
 
     ODataService service = mock(ODataService.class);
     when(service.getServiceDocumentProcessor()).thenReturn(serviceDocument);
@@ -167,7 +180,8 @@ public class DispatcherTest extends BaseTest {
     return uriInfo;
   }
 
-  private static void checkDispatch(final ODataHttpMethod method, final UriType uriType, final boolean isValue, final String expectedMethodName) throws ODataException {
+  private static void checkDispatch(final ODataHttpMethod method, final UriType uriType, final boolean isValue,
+      final String expectedMethodName) throws ODataException {
     ODataServiceFactory factory = mock(ODataServiceFactory.class);
 
     final ODataResponse response = new Dispatcher(factory, getMockService())
@@ -175,7 +189,9 @@ public class DispatcherTest extends BaseTest {
     assertEquals(expectedMethodName, response.getEntity());
   }
 
-  private static void checkDispatch(final ODataHttpMethod method, final UriType uriType, final String expectedMethodName) throws ODataException {
+  private static void
+      checkDispatch(final ODataHttpMethod method, final UriType uriType, final String expectedMethodName)
+          throws ODataException {
     checkDispatch(method, uriType, false, expectedMethodName);
   }
 
@@ -366,7 +382,8 @@ public class DispatcherTest extends BaseTest {
     notSupportedDispatch(ODataHttpMethod.MERGE, UriType.URI6A);
   }
 
-  private static void checkFeature(final UriType uriType, final boolean isValue, final Class<? extends ODataProcessor> feature) throws ODataException {
+  private static void checkFeature(final UriType uriType, final boolean isValue,
+      final Class<? extends ODataProcessor> feature) throws ODataException {
     ODataServiceFactory factory = mock(ODataServiceFactory.class);
     new Dispatcher(factory, getMockService());
     assertEquals(feature, Dispatcher.mapUriTypeToProcessorFeature(mockUriInfo(uriType, isValue)));
@@ -423,15 +440,17 @@ public class DispatcherTest extends BaseTest {
   }
 
   @SuppressWarnings("unchecked")
-  private void negotiateContentTypeCharset(final String requestType, final String supportedType, final boolean asFormat)
-      throws SecurityException, IllegalArgumentException, NoSuchFieldException, IllegalAccessException, ODataException {
+  private void
+      negotiateContentTypeCharset(final String requestType, final String supportedType, final boolean asFormat)
+          throws SecurityException, IllegalArgumentException, NoSuchFieldException, IllegalAccessException,
+          ODataException {
 
     ODataServiceFactory factory = mock(ODataServiceFactory.class);
     ODataService service = Mockito.mock(ODataService.class);
     Dispatcher dispatcher = new Dispatcher(factory, service);
 
     UriInfoImpl uriInfo = new UriInfoImpl();
-    uriInfo.setUriType(UriType.URI1); // 
+    uriInfo.setUriType(UriType.URI1); //
     if (asFormat) {
       uriInfo.setFormat(requestType);
     }
@@ -444,7 +463,8 @@ public class DispatcherTest extends BaseTest {
     Mockito.when(service.getEntitySetProcessor()).thenReturn(processor);
 
     InputStream content = null;
-    ODataResponse odataResponse = dispatcher.dispatch(ODataHttpMethod.GET, uriInfo, content, requestType, supportedType);
+    ODataResponse odataResponse =
+        dispatcher.dispatch(ODataHttpMethod.GET, uriInfo, content, requestType, supportedType);
     assertEquals(supportedType, odataResponse.getContentHeader());
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/a030e42b/odata-core/src/test/java/org/apache/olingo/odata2/core/ODataContextImplTest.java
----------------------------------------------------------------------
diff --git a/odata-core/src/test/java/org/apache/olingo/odata2/core/ODataContextImplTest.java b/odata-core/src/test/java/org/apache/olingo/odata2/core/ODataContextImplTest.java
index 35211de..571d6b1 100644
--- a/odata-core/src/test/java/org/apache/olingo/odata2/core/ODataContextImplTest.java
+++ b/odata-core/src/test/java/org/apache/olingo/odata2/core/ODataContextImplTest.java
@@ -1,20 +1,20 @@
 /*******************************************************************************
  * 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
+ * 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
+ * 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.
+ * 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.olingo.odata2.core;