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:27 UTC

[05/59] [abbrv] Clean up of odata api

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/OnWriteFeedContent.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/OnWriteFeedContent.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/OnWriteFeedContent.java
index 1111d54..3f7e88a 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/OnWriteFeedContent.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/OnWriteFeedContent.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -22,17 +22,18 @@ import org.apache.olingo.odata2.api.ODataCallback;
 import org.apache.olingo.odata2.api.exception.ODataApplicationException;
 
 /**
- * Callback interface for the $expand query option. 
+ * Callback interface for the $expand query option.
  * <p>If an expand clause for a navigation property which points to a feed is found this callback will be called.
  * <br>Pointing to an feed means the navigation property has a multiplicity of 0..* or 1..*.
  * 
- *  
- *
+ * 
+ * 
  */
 public interface OnWriteFeedContent extends ODataCallback {
 
   /**
-   * Retrieves the data for a feed. See {@link WriteFeedCallbackContext} for details on the context and {@link WriteFeedCallbackResult} for details on the result of this method.
+   * Retrieves the data for a feed. See {@link WriteFeedCallbackContext} for details on the context and
+   * {@link WriteFeedCallbackResult} for details on the result of this method.
    * @param context of this entry
    * @return result - must not be null.
    * @throws ODataApplicationException

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadEntryResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadEntryResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadEntryResult.java
index cbeee19..e6b8d8c 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadEntryResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadEntryResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -24,13 +24,13 @@ import org.apache.olingo.odata2.api.ep.entry.ODataEntry;
 
 /**
  * A {@link ReadEntryResult} represents an inlined navigation property which points to an entry.
- * The {@link ReadEntryResult} contains the {@link EntityProviderReadProperties} which were used for read, 
+ * The {@link ReadEntryResult} contains the {@link EntityProviderReadProperties} which were used for read,
  * the <code>navigationPropertyName</code> and the read/de-serialized inlined entity.
- * If inlined navigation property is <code>nullable</code> the {@link ReadEntryResult} has the 
+ * If inlined navigation property is <code>nullable</code> the {@link ReadEntryResult} has the
  * <code>navigationPropertyName</code> and a <code>NULL</code> entry set.
  * 
- *  
- *
+ * 
+ * 
  */
 public class ReadEntryResult extends ReadResult {
 
@@ -44,7 +44,8 @@ public class ReadEntryResult extends ReadResult {
    * @param navigationProperty emd navigation property information of found inline navigation property
    * @param entry read entity as {@link ODataEntry}
    */
-  public ReadEntryResult(final EntityProviderReadProperties properties, final EdmNavigationProperty navigationProperty, final ODataEntry entry) {
+  public ReadEntryResult(final EntityProviderReadProperties properties, final EdmNavigationProperty navigationProperty,
+      final ODataEntry entry) {
     super(properties, navigationProperty);
     this.entry = entry;
   }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadFeedResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadFeedResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadFeedResult.java
index edfbad4..3e58609 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadFeedResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadFeedResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -25,12 +25,12 @@ import org.apache.olingo.odata2.api.ep.feed.ODataFeed;
 /**
  * A {@link ReadFeedResult} represents an inlined navigation property which points to a feed (in the form of a list of
  * {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry} instances).
- * The {@link ReadFeedResult} contains the {@link EntityProviderReadProperties} which were used for read, 
+ * The {@link ReadFeedResult} contains the {@link EntityProviderReadProperties} which were used for read,
  * the <code>navigationPropertyName</code> and the read/de-serialized inlined entities.
- * If inlined navigation property is <code>nullable</code> the {@link ReadFeedResult} has the 
+ * If inlined navigation property is <code>nullable</code> the {@link ReadFeedResult} has the
  * <code>navigationPropertyName</code> and a <code>NULL</code> entry set.
  * 
- *  
+ * 
  */
 public class ReadFeedResult extends ReadResult {
 
@@ -44,7 +44,8 @@ public class ReadFeedResult extends ReadResult {
    * @param navigationProperty emd navigation property information of found inline navigation property
    * @param entry read entities as list of {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry}
    */
-  public ReadFeedResult(final EntityProviderReadProperties properties, final EdmNavigationProperty navigationProperty, final ODataFeed entry) {
+  public ReadFeedResult(final EntityProviderReadProperties properties, final EdmNavigationProperty navigationProperty,
+      final ODataFeed entry) {
     super(properties, navigationProperty);
     feed = entry;
   }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadResult.java
index 9d05b54..d890ac8 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/ReadResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,13 +23,15 @@ import org.apache.olingo.odata2.api.ep.EntityProviderReadProperties;
 
 /**
  * A {@link ReadResult} represents an inlined navigation property which points to an entry or feed.
- * The {@link ReadResult} contains the {@link EntityProviderReadProperties} which were used for read, 
- * the <code>navigationPropertyName</code>, the read/de-serialized inlined entity and information whether the inlined content
- * is a <code>feed</code> (multiplicity of <code>1..m</code>) or a single <code>entry</code> (multiplicity of <code>0..1</code> or <code>1..1</code>).
- * If inlined navigation property is <code>nullable</code> the {@link ReadResult} has the 
+ * The {@link ReadResult} contains the {@link EntityProviderReadProperties} which were used for read,
+ * the <code>navigationPropertyName</code>, the read/de-serialized inlined entity and information whether the inlined
+ * content
+ * is a <code>feed</code> (multiplicity of <code>1..m</code>) or a single <code>entry</code> (multiplicity of
+ * <code>0..1</code> or <code>1..1</code>).
+ * If inlined navigation property is <code>nullable</code> the {@link ReadResult} has the
  * <code>navigationPropertyName</code> and a <code>NULL</code> entry set.
  * 
- *  
+ * 
  */
 public abstract class ReadResult {
 
@@ -65,20 +67,19 @@ public abstract class ReadResult {
   /**
    * Common access method to read result.
    * 
-   * @return an {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry}
-   *         for the case of an single read entry or a list of
-   *         {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry}
-   *         in the case of an read feed.
+   * @return an {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry} for the case of an single read entry
+   * or a list of {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry ODataEntry} in the case of an read feed.
    */
   public abstract Object getResult();
 
   @Override
   public String toString() {
-    return this.getClass().getSimpleName() + " [readProperties=" + readProperties + ", navigationProperty=" + navigationProperty + "]";
+    return this.getClass().getSimpleName() + " [readProperties=" + readProperties + ", navigationProperty="
+        + navigationProperty + "]";
   }
 
   /**
-   * Return whether this entry is a <code>feed</code> (multiplicity of <code>1..m</code>) 
+   * Return whether this entry is a <code>feed</code> (multiplicity of <code>1..m</code>)
    * or a single <code>entry</code> (multiplicity of <code>0..1</code> or <code>1..1</code>).
    * 
    * @return <code>true</code> for a feed and <code>false</code> for an entry

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallback.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallback.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallback.java
index 7c91690..deb2b5d 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallback.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallback.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,9 +23,9 @@ import org.apache.olingo.odata2.api.ODataCallback;
 /**
  * <p>Interface that must be implemented in order to provide tombstone support.</p>
  * <p>The callback implementing this interface is registered at the
- * {@link org.apache.olingo.odata2.api.ep.EntityProviderWriteProperties EntityProviderWriteProperties}
- * using the callback key of this class.</p>
- *  
+ * {@link org.apache.olingo.odata2.api.ep.EntityProviderWriteProperties EntityProviderWriteProperties} using the
+ * callback key of this class.</p>
+ * 
  */
 public interface TombstoneCallback extends ODataCallback {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallbackResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallbackResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallbackResult.java
index ad9f1af..fb635ab 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallbackResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/TombstoneCallbackResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,8 +23,8 @@ import java.util.Map;
 
 /**
  * Objects of this class are a container for the result of the {@link TombstoneCallback}.
- *  
- *
+ * 
+ * 
  */
 public class TombstoneCallbackResult {
 
@@ -33,8 +33,10 @@ public class TombstoneCallbackResult {
 
   /**
    * A map representing a deleted entry <b>MUST</b> contain all properties which are part of the key for this entry.
-   * <br>A map representing a deleted entry <b>MAY</b> contain the property which is mapped on SyndicationUpdated. The provided value here will result in the value of the "when" attribute of the deleted entry. 
-   * @return deleted entries in the form of List{@literal <}Map{@literal <}property name, property value{@literal >}{@literal >}
+   * <br>A map representing a deleted entry <b>MAY</b> contain the property which is mapped on SyndicationUpdated. The
+   * provided value here will result in the value of the "when" attribute of the deleted entry.
+   * @return deleted entries in the form of List{@literal <}Map{@literal <}property name, property value{@literal >}
+   * {@literal >}
    */
   public List<Map<String, Object>> getDeletedEntriesData() {
     return deletedEntriesData;
@@ -56,7 +58,7 @@ public class TombstoneCallbackResult {
   }
 
   /**
-   * Sets the delta link to retrieve a delta. 
+   * Sets the delta link to retrieve a delta.
    * @param deltaLink
    */
   public void setDeltaLink(final String deltaLink) {

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteCallbackContext.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteCallbackContext.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteCallbackContext.java
index d834447..7659765 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteCallbackContext.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteCallbackContext.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -29,8 +29,8 @@ import org.apache.olingo.odata2.api.uri.ExpandSelectTreeNode;
 
 /**
  * Wrapper for {@link WriteEntryCallbackContext} and {@link WriteFeedCallbackContext}.
- * @org.apache.olingo.odata2.DoNotImplement 
- *  
+ * @org.apache.olingo.odata2.DoNotImplement
+ * 
  */
 public abstract class WriteCallbackContext {
   private EdmEntitySet sourceEntitySet;
@@ -113,7 +113,8 @@ public abstract class WriteCallbackContext {
         key.put(keyPropertyName, entryData.get(keyPropertyName));
       }
     } catch (EdmException e) {
-      throw new EntityProviderException(EntityProviderException.EXCEPTION_OCCURRED.addContent(e.getClass().getSimpleName()), e);
+      throw new EntityProviderException(EntityProviderException.EXCEPTION_OCCURRED.addContent(e.getClass()
+          .getSimpleName()), e);
     }
     return key;
   }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackContext.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackContext.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackContext.java
index 8b47630..ad8f521 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackContext.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackContext.java
@@ -1,26 +1,27 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
 package org.apache.olingo.odata2.api.ep.callback;
 
 /**
- * Context given if the target of an expand is an entry. It contains the source entity set, the navigation property pointing to the entry which has to be expanded, the current expand select tree node and the data of the source entry.
- *  
- *
+ * Context given if the target of an expand is an entry. It contains the source entity set, the navigation property
+ * pointing to the entry which has to be expanded, the current expand select tree node and the data of the source entry.
+ * 
+ * 
  */
 public class WriteEntryCallbackContext extends WriteCallbackContext {}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackResult.java
index c632045..be4d635 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteEntryCallbackResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,8 +23,9 @@ import java.util.Map;
 import org.apache.olingo.odata2.api.ep.EntityProviderWriteProperties;
 
 /**
- * Result of a callback. It contains the data of the entry which is to be expanded as well as the properties of this entry.
- *  
+ * Result of a callback. It contains the data of the entry which is to be expanded as well as the properties of this
+ * entry.
+ * 
  */
 public class WriteEntryCallbackResult {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackContext.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackContext.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackContext.java
index f806bb6..ce7a753 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackContext.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackContext.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -21,9 +21,10 @@ package org.apache.olingo.odata2.api.ep.callback;
 import java.net.URI;
 
 /**
- * Context given if the target of an expand is a feed. It contains the source entity set, the navigation property pointing to the entry which has to be expanded, the current expand select tree node and the data of the source entry.
- *  
- *
+ * Context given if the target of an expand is a feed. It contains the source entity set, the navigation property
+ * pointing to the entry which has to be expanded, the current expand select tree node and the data of the source entry.
+ * 
+ * 
  */
 public class WriteFeedCallbackContext extends WriteCallbackContext {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackResult.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackResult.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackResult.java
index 6e37fc3..cce8662 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackResult.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/WriteFeedCallbackResult.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -24,9 +24,10 @@ import java.util.Map;
 import org.apache.olingo.odata2.api.ep.EntityProviderWriteProperties;
 
 /**
- * Result of a callback. It contains the data of the feed which is to be expanded as well as the BaseUri of the feed. Further callbacks for this feed can also be set.
- *  
- *
+ * Result of a callback. It contains the data of the feed which is to be expanded as well as the BaseUri of the feed.
+ * Further callbacks for this feed can also be set.
+ * 
+ * 
  */
 public class WriteFeedCallbackResult {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/package-info.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/package-info.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/package-info.java
index 6762b24..039a5d5 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/package-info.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/callback/package-info.java
@@ -1,28 +1,32 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
 /**
  * Entity Provider Callbacks<p>
- * These callbacks will be used to support the $expand query option. Callbacks have to implement the {@link org.apache.olingo.odata2.api.ODataCallback} as a marker. 
- * <br>To support an expanded entry the {@link org.apache.olingo.odata2.api.ep.callback.OnWriteEntryContent} interface has to be implemented.
- * <br>To support an expanded feed the {@link org.apache.olingo.odata2.api.ep.callback.OnWriteFeedContent} interface has to be implemented.
+ * These callbacks will be used to support the $expand query option. Callbacks have to implement the
+ * {@link org.apache.olingo.odata2.api.ODataCallback} as a marker.
+ * <br>To support an expanded entry the {@link org.apache.olingo.odata2.api.ep.callback.OnWriteEntryContent} interface
+ * has to be implemented.
+ * <br>To support an expanded feed the {@link org.apache.olingo.odata2.api.ep.callback.OnWriteFeedContent} interface has
+ * to be implemented.
  * 
- * <p>All callbacks are registered for a navigation property in a HashMap<String as navigation property name, callback for this navigation property> and will only be called if a matching $expand clause is found.
+ * <p>All callbacks are registered for a navigation property in a HashMap<String as navigation property name, callback
+ * for this navigation property> and will only be called if a matching $expand clause is found.
  */
 package org.apache.olingo.odata2.api.ep.callback;
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/EntryMetadata.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/EntryMetadata.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/EntryMetadata.java
index a253665..2707832 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/EntryMetadata.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/EntryMetadata.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/MediaMetadata.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/MediaMetadata.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/MediaMetadata.java
index 28b5f19..f5c3bba 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/MediaMetadata.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/MediaMetadata.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -31,7 +31,7 @@ public interface MediaMetadata {
   public abstract String getEditLink();
 
   /**
-   * Get <code>content type</code> in as specified in 
+   * Get <code>content type</code> in as specified in
    * <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html">RFC 2616 Section 14</a>.
    * 
    * @return <code>content type</code>.

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/ODataEntry.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/ODataEntry.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/ODataEntry.java
index ef2d307..68bb184 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/ODataEntry.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/ODataEntry.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,7 +23,7 @@ import java.util.Map;
 import org.apache.olingo.odata2.api.uri.ExpandSelectTreeNode;
 
 /**
- * An {@link ODataEntry} contains all <b>properties</b> (in form of a {@link Map}) and possible <b>metadata</b> 
+ * An {@link ODataEntry} contains all <b>properties</b> (in form of a {@link Map}) and possible <b>metadata</b>
  * (in form of {@link MediaMetadata} and/or {@link EntryMetadata}) for an entry.
  * 
  */
@@ -52,7 +52,7 @@ public interface ODataEntry {
 
   /**
    * If this {@link ODataEntry} contains properties of an inline navigation property this method
-   * returns <code>true</code>. 
+   * returns <code>true</code>.
    * Otherwise if this {@link ODataEntry} only contains it own properties this method
    * returns <code>false</code>.
    * 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/package-info.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/package-info.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/package-info.java
index f2be764..b02e7bc 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/package-info.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/entry/package-info.java
@@ -1,25 +1,26 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
 /**
  * Entity Provider Entries<p>
  * 
- * The <b>org.apache.olingo.odata2.api.ep.entry</b> package contains all classes related and necessary for an {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry}.
+ * The <b>org.apache.olingo.odata2.api.ep.entry</b> package contains all classes related and necessary for an
+ * {@link org.apache.olingo.odata2.api.ep.entry.ODataEntry}.
  * <p>
  */
 package org.apache.olingo.odata2.api.ep.entry;

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/FeedMetadata.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/FeedMetadata.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/FeedMetadata.java
index f17a8df..441ffbe 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/FeedMetadata.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/FeedMetadata.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -20,8 +20,8 @@ package org.apache.olingo.odata2.api.ep.feed;
 
 /**
  * {@link FeedMetadata} objects contain metadata information about one feed.
- *  
- *
+ * 
+ * 
  */
 public interface FeedMetadata {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/ODataFeed.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/ODataFeed.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/ODataFeed.java
index c6ebd4b..9b98ec9 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/ODataFeed.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/ODataFeed.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -24,8 +24,8 @@ import org.apache.olingo.odata2.api.ep.entry.ODataEntry;
 
 /**
  * An {@link ODataFeed} object contains a list of {@link ODataEntry}s and the metadata associated with this feed.
- *  
- *
+ * 
+ * 
  */
 public interface ODataFeed {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/package-info.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/package-info.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/package-info.java
index 574e5be..8ff355a 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/package-info.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/feed/package-info.java
@@ -1,25 +1,26 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
 /**
  * Entity Provider Feed<p>
  * 
- * The <b>org.apache.olingo.odata2.api.ep.feed</b> package contains all classes related and necessary for an {@link org.apache.olingo.odata2.api.ep.feed.ODataFeed}.
+ * The <b>org.apache.olingo.odata2.api.ep.feed</b> package contains all classes related and necessary for an
+ * {@link org.apache.olingo.odata2.api.ep.feed.ODataFeed}.
  * <p>
  */
 package org.apache.olingo.odata2.api.ep.feed;

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/package-info.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/package-info.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/package-info.java
index 8d61f84..caba6ef 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/package-info.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/ep/package-info.java
@@ -1,33 +1,36 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
 /**
  * Entity Provider<p>
  * 
- * The <b>org.apache.olingo.odata2.api.ep</b> package contains all classes related and necessary to provide an {@link org.apache.olingo.odata2.api.ep.EntityProvider}.
+ * The <b>org.apache.olingo.odata2.api.ep</b> package contains all classes related and necessary to provide an
+ * {@link org.apache.olingo.odata2.api.ep.EntityProvider}.
  * <p>
- * An {@link org.apache.olingo.odata2.api.ep.EntityProvider} provides all necessary <b>read</b> and <b>write</b> methods for accessing 
+ * An {@link org.apache.olingo.odata2.api.ep.EntityProvider} provides all necessary <b>read</b> and <b>write</b> methods
+ * for accessing
  * the entities defined in an <code>Entity Data Model</code>.
- * Therefore this library provides (in its <code>core</code> packages) as convenience basic {@link org.apache.olingo.odata2.api.ep.EntityProvider} 
- * for accessing entities in the <b>XML</b> and <b>JSON</b> format.
+ * Therefore this library provides (in its <code>core</code> packages) as convenience basic
+ * {@link org.apache.olingo.odata2.api.ep.EntityProvider} for accessing entities in the <b>XML</b> and <b>JSON</b>
+ * format.
  * <p>
- * For support of additional formats it is recommended to handle those directly within an implementation of a 
- * <code>ODataProcessor</code> (it is possible but <b>not recommended</b> to implement an own 
+ * For support of additional formats it is recommended to handle those directly within an implementation of a
+ * <code>ODataProcessor</code> (it is possible but <b>not recommended</b> to implement an own
  * {@link org.apache.olingo.odata2.api.ep.EntityProvider} for support of additional formats).
  */
 package org.apache.olingo.odata2.api.ep;

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/MessageReference.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/MessageReference.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/MessageReference.java
index d1bb948..4f0f5be 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/MessageReference.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/MessageReference.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -24,13 +24,14 @@ import java.util.Collections;
 import java.util.List;
 
 /**
- * APPLICATION DEVELOPERS: Please use {@link ODataApplicationException} to throw custom exceptions. This class is used inside the library only. 
- * <p>A {@link MessageReference} references to the used message for an
- * {@link ODataMessageException} and its sub classes. It supports
+ * APPLICATION DEVELOPERS: Please use {@link ODataApplicationException} to throw custom exceptions. This class is used
+ * inside the library only.
+ * <p>A {@link MessageReference} references to the used message for an {@link ODataMessageException} and its sub
+ * classes. It supports
  * internationalization and translation of exception messages.
- * <br>Theses classes  contain a {@link MessageReference} object which
+ * <br>Theses classes contain a {@link MessageReference} object which
  * can be mapped to a related key and message text in the resource bundles.
- *  
+ * 
  */
 public abstract class MessageReference {
 
@@ -50,10 +51,9 @@ public abstract class MessageReference {
    * Creates a {@link MessageReference} for given <code>class</code> and <code>key</code>.
    * This combination of <code>class</code> and <code>key</code> has to be provided
    * by a resource bundle.
-   * @param clazz {@link ODataMessageException} for which this {@link MessageReference}
-   *              should be used
-   * @param key   unique key (in context of {@link ODataMessageException}) for reference
-   *              to message text in resource bundle
+   * @param clazz {@link ODataMessageException} for which this {@link MessageReference} should be used
+   * @param key unique key (in context of {@link ODataMessageException}) for reference
+   * to message text in resource bundle
    * @return created {@link MessageReference}
    */
   public static MessageReference create(final Class<? extends ODataException> clazz, final String key) {

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataApplicationException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataApplicationException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataApplicationException.java
index d4be8ec..f862eba 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataApplicationException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataApplicationException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -23,10 +23,12 @@ import java.util.Locale;
 import org.apache.olingo.odata2.api.commons.HttpStatusCodes;
 
 /**
- * This class represents a translated application exception. Use this exception class to display custom exception messages. 
- * <br>If a HTTP status is given this exception will result in the set status code like an HTTP exception. 
- * <br>A set status code can be used to show a substatus to a HTTP status as described in the OData protocol specification. 
- *  
+ * This class represents a translated application exception. Use this exception class to display custom exception
+ * messages.
+ * <br>If a HTTP status is given this exception will result in the set status code like an HTTP exception.
+ * <br>A set status code can be used to show a substatus to a HTTP status as described in the OData protocol
+ * specification.
+ * 
  */
 public class ODataApplicationException extends ODataException {
 
@@ -46,8 +48,8 @@ public class ODataApplicationException extends ODataException {
   }
 
   /**
-   * Since this is a translated application exception locale must not be null. 
-   * <br>The status code given will be  displayed at the client.
+   * Since this is a translated application exception locale must not be null.
+   * <br>The status code given will be displayed at the client.
    * @param message
    * @param locale
    * @param status
@@ -60,28 +62,32 @@ public class ODataApplicationException extends ODataException {
   /**
    * Since this is a translated application exception locale must not be null.
    * <br>The status code given will be displayed at the client.
-   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol specification.
+   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol
+   * specification.
    * @param message
    * @param locale
    * @param status
    * @param errorCode
    */
-  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status, final String errorCode) {
+  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status,
+      final String errorCode) {
     this(message, locale, status);
     this.errorCode = errorCode;
   }
 
-  /**   
-   * Since this is a translated application exception locale must not be null.  
+  /**
+   * Since this is a translated application exception locale must not be null.
    * <br>The status code given will be displayed at the client.
-   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol specification.
+   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol
+   * specification.
    * @param message
    * @param locale
    * @param status
    * @param errorCode
    * @param e
    */
-  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status, final String errorCode, final Throwable e) {
+  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status,
+      final String errorCode, final Throwable e) {
     super(message, e);
     this.errorCode = errorCode;
     httpStatus = status;
@@ -107,20 +113,23 @@ public class ODataApplicationException extends ODataException {
    * @param status
    * @param e
    */
-  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status, final Throwable e) {
+  public ODataApplicationException(final String message, final Locale locale, final HttpStatusCodes status,
+      final Throwable e) {
     this(message, locale, e);
     httpStatus = status;
   }
 
   /**
    * Since this is a translated application exception locale must not be null.
-   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol specification.
+   * <br>The error code may be used as a substatus for the HTTP status code as described in the OData protocol
+   * specification.
    * @param message
    * @param locale
    * @param errorCode
    * @param e
    */
-  public ODataApplicationException(final String message, final Locale locale, final String errorCode, final Throwable e) {
+  public ODataApplicationException(final String message, final Locale locale, final String errorCode,
+      final Throwable e) {
     this(message, locale, e);
     this.errorCode = errorCode;
 
@@ -135,7 +144,7 @@ public class ODataApplicationException extends ODataException {
 
   /**
    * Default HttpStatusCodes.INTERNAL_SERVER_ERROR
-   * @return {@link HttpStatusCodes} the status code 
+   * @return {@link HttpStatusCodes} the status code
    */
   public HttpStatusCodes getHttpStatus() {
     return httpStatus;

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataBadRequestException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataBadRequestException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataBadRequestException.java
index 52afb4f..9cb0503 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataBadRequestException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataBadRequestException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -22,23 +22,30 @@ import org.apache.olingo.odata2.api.commons.HttpStatusCodes;
 
 /**
  * Exceptions of this class will result in a HTTP status 400 bad request
- *  
+ * 
  */
 public class ODataBadRequestException extends ODataHttpException {
 
   private static final long serialVersionUID = 1L;
 
   public static final MessageReference COMMON = createMessageReference(ODataBadRequestException.class, "COMMON");
-  public static final MessageReference NOTSUPPORTED = createMessageReference(ODataBadRequestException.class, "NOTSUPPORTED");
-  public static final MessageReference URLTOOSHORT = createMessageReference(ODataBadRequestException.class, "URLTOOSHORT");
-  public static final MessageReference VERSIONERROR = createMessageReference(ODataBadRequestException.class, "VERSIONERROR");
-  public static final MessageReference PARSEVERSIONERROR = createMessageReference(ODataBadRequestException.class, "PARSEVERSIONERROR");
+  public static final MessageReference NOTSUPPORTED = createMessageReference(ODataBadRequestException.class,
+      "NOTSUPPORTED");
+  public static final MessageReference URLTOOSHORT = createMessageReference(ODataBadRequestException.class,
+      "URLTOOSHORT");
+  public static final MessageReference VERSIONERROR = createMessageReference(ODataBadRequestException.class,
+      "VERSIONERROR");
+  public static final MessageReference PARSEVERSIONERROR = createMessageReference(ODataBadRequestException.class,
+      "PARSEVERSIONERROR");
   public static final MessageReference BODY = createMessageReference(ODataBadRequestException.class, "BODY");
-  public static final MessageReference AMBIGUOUS_XMETHOD = createMessageReference(ODataBadRequestException.class, "AMBIGUOUS_XMETHOD");
+  public static final MessageReference AMBIGUOUS_XMETHOD = createMessageReference(ODataBadRequestException.class,
+      "AMBIGUOUS_XMETHOD");
   /** INVALID_HEADER requires 2 content values ('header key' and 'header value') */
-  public static final MessageReference INVALID_HEADER = createMessageReference(ODataBadRequestException.class, "INVALID_HEADER");
+  public static final MessageReference INVALID_HEADER = createMessageReference(ODataBadRequestException.class,
+      "INVALID_HEADER");
   /** INVALID_SYNTAX requires NO content values */
-  public static final MessageReference INVALID_SYNTAX = createMessageReference(ODataBadRequestException.class, "INVALID_SYNTAX");;
+  public static final MessageReference INVALID_SYNTAX = createMessageReference(ODataBadRequestException.class,
+      "INVALID_SYNTAX");;
 
   public ODataBadRequestException(final MessageReference messageReference) {
     super(messageReference, HttpStatusCodes.BAD_REQUEST);
@@ -52,7 +59,8 @@ public class ODataBadRequestException extends ODataHttpException {
     super(messageReference, cause, HttpStatusCodes.BAD_REQUEST);
   }
 
-  public ODataBadRequestException(final MessageReference messageReference, final Throwable cause, final String errorCode) {
+  public ODataBadRequestException(final MessageReference messageReference, final Throwable cause,
+      final String errorCode) {
     super(messageReference, cause, HttpStatusCodes.BAD_REQUEST, errorCode);
   }
 }

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataConflictException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataConflictException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataConflictException.java
index 12ff78e..5534a58 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataConflictException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataConflictException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -22,7 +22,7 @@ import org.apache.olingo.odata2.api.commons.HttpStatusCodes;
 
 /**
  * Exceptions of this class will result in a HTTP status 409 Conflict
- *  
+ * 
  */
 public class ODataConflictException extends ODataHttpException {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataException.java
index 21c72db..30ffe19 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -20,7 +20,7 @@ package org.apache.olingo.odata2.api.exception;
 
 /**
  * Base exception for all <code>OData</code>-related exceptions.
- *  
+ * 
  */
 public class ODataException extends Exception {
 
@@ -44,8 +44,9 @@ public class ODataException extends Exception {
 
   /**
    * Checks whether this exception is an or was caused by an {@link ODataHttpException} exception.
-   *
-   * @return <code>true</code> if this is an or was caused by an {@link ODataHttpException}, otherwise <code>false</code>
+   * 
+   * @return <code>true</code> if this is an or was caused by an {@link ODataHttpException}, otherwise
+   * <code>false</code>
    */
   public boolean isCausedByHttpException() {
     return getHttpExceptionCause() != null;
@@ -56,7 +57,7 @@ public class ODataException extends Exception {
    * If there is no {@link ODataHttpException} in the cause hierarchy, <code>NULL</code> is returned.
    * 
    * @return the first found {@link ODataHttpException} in the cause exception hierarchy
-   *         or <code>NULL</code> if no {@link ODataHttpException} is found in the cause hierarchy
+   * or <code>NULL</code> if no {@link ODataHttpException} is found in the cause hierarchy
    */
   public ODataHttpException getHttpExceptionCause() {
     return getSpecificCause(ODataHttpException.class);
@@ -64,8 +65,9 @@ public class ODataException extends Exception {
 
   /**
    * Checks whether this exception is an or was caused by an {@link ODataApplicationException} exception.
-   *
-   * @return <code>true</code> if this is an or was caused by an {@link ODataApplicationException}, otherwise <code>false</code>
+   * 
+   * @return <code>true</code> if this is an or was caused by an {@link ODataApplicationException}, otherwise
+   * <code>false</code>
    */
   public boolean isCausedByApplicationException() {
     return getApplicationExceptionCause() != null;
@@ -74,7 +76,8 @@ public class ODataException extends Exception {
   /**
    * Checks whether this exception is an or was caused by an {@link ODataMessageException} exception.
    * 
-   * @return <code>true</code> if this is an or was caused by an {@link ODataMessageException}, otherwise <code>false</code>
+   * @return <code>true</code> if this is an or was caused by an {@link ODataMessageException}, otherwise
+   * <code>false</code>
    */
   public boolean isCausedByMessageException() {
     return getMessageExceptionCause() != null;
@@ -83,9 +86,9 @@ public class ODataException extends Exception {
   /**
    * Search for and return first (from top) {@link ODataMessageException} in the cause hierarchy.
    * If there is no {@link ODataMessageException} in the cause hierarchy <code>NULL</code> is returned.
-   *
-   * @return the first found {@link ODataMessageException} in the cause exception hierarchy 
-   *         or <code>NULL</code> if no {@link ODataMessageException} is found in the cause hierarchy
+   * 
+   * @return the first found {@link ODataMessageException} in the cause exception hierarchy
+   * or <code>NULL</code> if no {@link ODataMessageException} is found in the cause hierarchy
    */
   public ODataMessageException getMessageExceptionCause() {
     return getSpecificCause(ODataMessageException.class);
@@ -94,9 +97,9 @@ public class ODataException extends Exception {
   /**
    * Search for and return first (from top) {@link ODataApplicationException} in the cause hierarchy.
    * If there is no {@link ODataApplicationException} in the cause hierarchy <code>NULL</code> is returned.
-   *
+   * 
    * @return the first found {@link ODataApplicationException} in the cause exception hierarchy
-   *         or <code>NULL</code> if no {@link ODataApplicationException} is found in the cause hierarchy
+   * or <code>NULL</code> if no {@link ODataApplicationException} is found in the cause hierarchy
    */
   public ODataApplicationException getApplicationExceptionCause() {
     return getSpecificCause(ODataApplicationException.class);

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataForbiddenException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataForbiddenException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataForbiddenException.java
index 92e0dbb..622771d 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataForbiddenException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataForbiddenException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -22,7 +22,7 @@ import org.apache.olingo.odata2.api.commons.HttpStatusCodes;
 
 /**
  * Exceptions of this class will result in a HTTP status 403 forbidden
- *  
+ * 
  */
 public class ODataForbiddenException extends ODataHttpException {
 

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/cf4caabf/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataHttpException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataHttpException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataHttpException.java
index f412de1..bdf6125 100644
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataHttpException.java
+++ b/odata-api/src/main/java/org/apache/olingo/odata2/api/exception/ODataHttpException.java
@@ -1,18 +1,18 @@
 /*******************************************************************************
  * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
+ * or more contributor license agreements. See the NOTICE file
  * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
+ * 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
+ * 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
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  ******************************************************************************/
@@ -22,7 +22,7 @@ import org.apache.olingo.odata2.api.commons.HttpStatusCodes;
 
 /**
  * {@link ODataMessageException} with a HTTP status code.
- *  
+ * 
  */
 public abstract class ODataHttpException extends ODataMessageException {
 
@@ -36,15 +36,18 @@ public abstract class ODataHttpException extends ODataMessageException {
     this(messageReference, null, httpStatus);
   }
 
-  public ODataHttpException(final MessageReference messageReference, final HttpStatusCodes httpStatus, final String errorCode) {
+  public ODataHttpException(final MessageReference messageReference, final HttpStatusCodes httpStatus,
+      final String errorCode) {
     this(messageReference, null, httpStatus, errorCode);
   }
 
-  public ODataHttpException(final MessageReference messageReference, final Throwable cause, final HttpStatusCodes httpStatus) {
+  public ODataHttpException(final MessageReference messageReference, final Throwable cause,
+      final HttpStatusCodes httpStatus) {
     this(messageReference, cause, httpStatus, null);
   }
 
-  public ODataHttpException(final MessageReference messageReference, final Throwable cause, final HttpStatusCodes httpStatus, final String errorCode) {
+  public ODataHttpException(final MessageReference messageReference, final Throwable cause,
+      final HttpStatusCodes httpStatus, final String errorCode) {
     super(messageReference, cause, errorCode);
     this.httpStatus = httpStatus;
   }