You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@olingo.apache.org by sk...@apache.org on 2014/06/30 16:57:35 UTC

[05/51] [abbrv] [partial] [OLINGO-328] code cleanup and checkstyle issues

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/ErrorTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/ErrorTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/ErrorTestITCase.java
index 3781734..2d22d23 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/ErrorTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/ErrorTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -146,9 +146,9 @@ public class ErrorTestITCase extends AbstractTestITCase {
 
   private void instreamError(final ODataFormat format) {
     final URIBuilder builder = client.newURIBuilder(testStaticServiceRootURL).
-            appendOperationCallSegment("InStreamErrorGetCustomer");
+        appendOperationCallSegment("InStreamErrorGetCustomer");
     final ODataInvokeRequest<ODataEntitySet> req =
-            client.getInvokeRequestFactory().getFunctionInvokeRequest(builder.build(), ODataEntitySet.class);
+        client.getInvokeRequestFactory().getFunctionInvokeRequest(builder.build(), ODataEntitySet.class);
     req.setFormat(format);
 
     final ODataInvokeResponse<ODataEntitySet> res = req.execute();

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/FilterFactoryTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/FilterFactoryTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/FilterFactoryTestITCase.java
index 3f00d2c..beb5b41 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/FilterFactoryTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/FilterFactoryTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -21,11 +21,11 @@ package org.apache.olingo.fit.v3;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNotNull;
 
-import org.apache.olingo.commons.api.domain.CommonODataEntitySet;
 import org.apache.olingo.client.api.uri.URIFilter;
 import org.apache.olingo.client.api.uri.v3.FilterArgFactory;
 import org.apache.olingo.client.api.uri.v3.FilterFactory;
 import org.apache.olingo.client.api.uri.v3.URIBuilder;
+import org.apache.olingo.commons.api.domain.CommonODataEntitySet;
 import org.junit.Test;
 
 public class FilterFactoryTestITCase extends AbstractTestITCase {
@@ -40,10 +40,10 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
 
   private void match(final String entitySet, final URIFilter filter, final int expected) {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment(entitySet).filter(filter);
+        appendEntitySetSegment(entitySet).filter(filter);
 
     final CommonODataEntitySet feed = client.getRetrieveRequestFactory().getEntitySetRequest(uriBuilder.build()).
-            execute().getBody();
+        execute().getBody();
     assertNotNull(feed);
     assertEquals(expected, feed.getEntities().size());
   }
@@ -56,7 +56,7 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void and() {
     final URIFilter filter =
-            getFilterFactory().and(
+        getFilterFactory().and(
             getFilterFactory().lt("VIN", 16),
             getFilterFactory().gt("VIN", 12));
 
@@ -66,10 +66,10 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void not() {
     final URIFilter filter =
-            getFilterFactory().not(
+        getFilterFactory().not(
             getFilterFactory().or(
-            getFilterFactory().ge("VIN", 16),
-            getFilterFactory().le("VIN", 12)));
+                getFilterFactory().ge("VIN", 16),
+                getFilterFactory().le("VIN", 12)));
 
     match("Car", filter, 3);
   }
@@ -77,26 +77,26 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void operator() {
     URIFilter filter =
-            getFilterFactory().eq(
+        getFilterFactory().eq(
             getFilterArgFactory().add(getFilterArgFactory().property("VIN"), getFilterArgFactory().
-            literal(1)),
+                literal(1)),
             getFilterArgFactory().literal(16));
 
     match("Car", filter, 1);
 
     filter =
-            getFilterFactory().eq(
+        getFilterFactory().eq(
             getFilterArgFactory().add(getFilterArgFactory().literal(1), getFilterArgFactory().
-            property("VIN")),
+                property("VIN")),
             getFilterArgFactory().literal(16));
 
     match("Car", filter, 1);
 
     filter =
-            getFilterFactory().eq(
+        getFilterFactory().eq(
             getFilterArgFactory().literal(16),
             getFilterArgFactory().add(getFilterArgFactory().literal(1), getFilterArgFactory().
-            property("VIN")));
+                property("VIN")));
 
     match("Car", filter, 1);
   }
@@ -104,9 +104,9 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void function() {
     final URIFilter filter =
-            getFilterFactory().match(
+        getFilterFactory().match(
             getFilterArgFactory().startswith(
-            getFilterArgFactory().property("Description"), getFilterArgFactory().literal("cen")));
+                getFilterArgFactory().property("Description"), getFilterArgFactory().literal("cen")));
 
     match("Car", filter, 1);
   }
@@ -114,10 +114,10 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void composed() {
     final URIFilter filter =
-            getFilterFactory().gt(
+        getFilterFactory().gt(
             getFilterArgFactory().length(getFilterArgFactory().property("Description")),
             getFilterArgFactory().add(getFilterArgFactory().property("VIN"), getFilterArgFactory().literal(
-            10)));
+                10)));
 
     match("Car", filter, 5);
   }
@@ -125,19 +125,19 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void propertyPath() {
     URIFilter filter =
-            getFilterFactory().eq(
+        getFilterFactory().eq(
             getFilterArgFactory().indexof(
-            getFilterArgFactory().property("PrimaryContactInfo/HomePhone/PhoneNumber"),
-            getFilterArgFactory().literal("ODataJClient")),
+                getFilterArgFactory().property("PrimaryContactInfo/HomePhone/PhoneNumber"),
+                getFilterArgFactory().literal("ODataJClient")),
             getFilterArgFactory().literal(1));
 
     match("Customer", filter, 0);
 
     filter =
-            getFilterFactory().ne(
+        getFilterFactory().ne(
             getFilterArgFactory().indexof(
-            getFilterArgFactory().property("PrimaryContactInfo/HomePhone/PhoneNumber"),
-            getFilterArgFactory().literal("lccvussrv")),
+                getFilterArgFactory().property("PrimaryContactInfo/HomePhone/PhoneNumber"),
+                getFilterArgFactory().literal("lccvussrv")),
             getFilterArgFactory().literal(-1));
 
     match("Customer", filter, 2);
@@ -146,9 +146,9 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void datetime() {
     final URIFilter filter =
-            getFilterFactory().eq(
+        getFilterFactory().eq(
             getFilterArgFactory().month(
-            getFilterArgFactory().property("PurchaseDate")),
+                getFilterArgFactory().property("PurchaseDate")),
             getFilterArgFactory().literal(12));
 
     match("ComputerDetail", filter, 1);
@@ -157,10 +157,10 @@ public class FilterFactoryTestITCase extends AbstractTestITCase {
   @Test
   public void isof() {
     final URIFilter filter =
-            getFilterFactory().match(
+        getFilterFactory().match(
             getFilterArgFactory().isof(
-            getFilterArgFactory().literal(
-            "Microsoft.Test.OData.Services.AstoriaDefaultService.SpecialEmployee")));
+                getFilterArgFactory().literal(
+                    "Microsoft.Test.OData.Services.AstoriaDefaultService.SpecialEmployee")));
 
     match("Person", filter, 4);
   }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/FilterTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/FilterTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/FilterTestITCase.java
index d14f9e4..eaa3a47 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/FilterTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/FilterTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -29,9 +29,9 @@ public class FilterTestITCase extends AbstractTestITCase {
 
   private void filterQueryTest(final String entity, final String filter, final int expected) {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment(entity).filter(filter);
+        appendEntitySetSegment(entity).filter(filter);
     final ODataEntitySet entitySet = client.getRetrieveRequestFactory().getEntitySetRequest(uriBuilder.build()).
-            execute().getBody();
+        execute().getBody();
     assertNotNull(entitySet);
     assertEquals(expected, entitySet.getEntities().size());
   }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/InvokeTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/InvokeTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/InvokeTestITCase.java
index d2edbbe..2a1ad02 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/InvokeTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/InvokeTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -55,10 +55,10 @@ public class InvokeTestITCase extends AbstractTestITCase {
   private void getWithNoParams(final ODataFormat format) {
     // 1. get primitive value property
     URIBuilder builder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendOperationCallSegment("GetPrimitiveString");
+        appendOperationCallSegment("GetPrimitiveString");
 
     ODataInvokeRequest<ODataProperty> req = getClient().getInvokeRequestFactory().
-            getFunctionInvokeRequest(builder.build(), ODataProperty.class);
+        getFunctionInvokeRequest(builder.build(), ODataProperty.class);
     req.setFormat(format);
     ODataInvokeResponse<ODataProperty> res = req.execute();
     assertNotNull(res);
@@ -69,7 +69,7 @@ public class InvokeTestITCase extends AbstractTestITCase {
 
     // 2. get collection of complex type property
     builder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendOperationCallSegment("EntityProjectionReturnsCollectionOfComplexTypes");
+        appendOperationCallSegment("EntityProjectionReturnsCollectionOfComplexTypes");
 
     req = getClient().getInvokeRequestFactory().getFunctionInvokeRequest(builder.build(), ODataProperty.class);
     req.setFormat(format);
@@ -95,12 +95,12 @@ public class InvokeTestITCase extends AbstractTestITCase {
   private void getWithParams(final ODataFormat format) throws EdmPrimitiveTypeException {
     // 1. primitive result
     URIBuilder builder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendOperationCallSegment("GetArgumentPlusOne");
+        appendOperationCallSegment("GetArgumentPlusOne");
 
     ODataValue param = getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(154);
     final ODataInvokeRequest<ODataProperty> primitiveReq = getClient().getInvokeRequestFactory().
-            getFunctionInvokeRequest(builder.build(), ODataProperty.class,
-                    Collections.<String, ODataValue>singletonMap("arg1", param));
+        getFunctionInvokeRequest(builder.build(), ODataProperty.class,
+            Collections.<String, ODataValue> singletonMap("arg1", param));
     primitiveReq.setFormat(format);
 
     final ODataInvokeResponse<ODataProperty> primitiveRes = primitiveReq.execute();
@@ -115,8 +115,8 @@ public class InvokeTestITCase extends AbstractTestITCase {
 
     param = getClient().getObjectFactory().newPrimitiveValueBuilder().buildString(StringUtils.EMPTY);
     final ODataInvokeRequest<ODataEntitySet> feedReq = getClient().getInvokeRequestFactory().
-            getFunctionInvokeRequest(builder.build(), ODataEntitySet.class,
-                    Collections.<String, ODataValue>singletonMap("Name", param));
+        getFunctionInvokeRequest(builder.build(), ODataEntitySet.class,
+            Collections.<String, ODataValue> singletonMap("Name", param));
     feedReq.setFormat(format);
 
     final ODataInvokeResponse<ODataEntitySet> feedRes = feedReq.execute();
@@ -144,35 +144,35 @@ public class InvokeTestITCase extends AbstractTestITCase {
 
   private ODataEntity createEmployee(final ODataFormat format) {
     final ODataEntity employee = getClient().getObjectFactory().newEntity(new FullQualifiedName(
-            "Microsoft.Test.OData.Services.AstoriaDefaultService.Employee"));
+        "Microsoft.Test.OData.Services.AstoriaDefaultService.Employee"));
 
     employee.getProperties().add(getClient().getObjectFactory().newPrimitiveProperty("PersonId",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(1244)));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(1244)));
     employee.getProperties().add(getClient().getObjectFactory().newPrimitiveProperty("Name",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("Test employee")));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("Test employee")));
     employee.getProperties().add(getClient().getObjectFactory().newPrimitiveProperty(
-            "ManagersPersonId", getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(3777)));
+        "ManagersPersonId", getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(3777)));
     employee.getProperties().add(getClient().getObjectFactory().newPrimitiveProperty(
-            "Salary", getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(1000)));
+        "Salary", getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(1000)));
     employee.getProperties().add(getClient().getObjectFactory().newPrimitiveProperty(
-            "Title", getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("CEO")));
+        "Title", getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("CEO")));
 
     final URIBuilder uriBuilder = getClient().newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Person");
 
     final ODataEntityCreateRequest<ODataEntity> createReq =
-            getClient().getCUDRequestFactory().getEntityCreateRequest(uriBuilder.build(), employee);
+        getClient().getCUDRequestFactory().getEntityCreateRequest(uriBuilder.build(), employee);
     createReq.setFormat(format);
     final ODataEntityCreateResponse<ODataEntity> createRes = createReq.execute();
     assertEquals(201, createRes.getStatusCode());
 
     final ODataEntityRequest<ODataEntity> req =
-            getClient().getRetrieveRequestFactory().getEntityRequest(uriBuilder.appendKeySegment(1244).build());
+        getClient().getRetrieveRequestFactory().getEntityRequest(uriBuilder.appendKeySegment(1244).build());
     return req.execute().getBody();
   }
 
   private void deleteEmployee(final ODataFormat format, final Integer id) {
     final URIBuilder uriBuilder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment("Person").appendKeySegment(id);
+        appendEntitySetSegment("Person").appendKeySegment(id);
 
     final ODataDeleteRequest deleteReq = getClient().getCUDRequestFactory().getDeleteRequest(uriBuilder.build());
     deleteReq.setFormat(format);
@@ -192,7 +192,7 @@ public class InvokeTestITCase extends AbstractTestITCase {
     final ODataOperation operation = created.getOperations().get(0);
 
     final ODataInvokeRequest<ODataNoContent> req = getClient().getInvokeRequestFactory().
-            getActionInvokeRequest(operation.getTarget(), ODataNoContent.class);
+        getActionInvokeRequest(operation.getTarget(), ODataNoContent.class);
     req.setFormat(ODataFormat.JSON_FULL_METADATA);
     final ODataInvokeResponse<ODataNoContent> res = req.execute();
     assertNotNull(res);
@@ -200,9 +200,9 @@ public class InvokeTestITCase extends AbstractTestITCase {
 
     // 2. check that invoked action has effectively run
     final URIBuilder uriBuilder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment("Person").appendKeySegment(createdId);
+        appendEntitySetSegment("Person").appendKeySegment(createdId);
     final ODataEntityRequest<ODataEntity> retrieveRes =
-            getClient().getRetrieveRequestFactory().getEntityRequest(uriBuilder.build());
+        getClient().getRetrieveRequestFactory().getEntityRequest(uriBuilder.build());
     retrieveRes.setFormat(ODataFormat.JSON_FULL_METADATA);
     final ODataEntity read = retrieveRes.execute().getBody();
     assertEquals("0", read.getProperty("Salary").getPrimitiveValue().toString());
@@ -216,25 +216,25 @@ public class InvokeTestITCase extends AbstractTestITCase {
   public void boundPostWithParams() throws EdmPrimitiveTypeException {
     // 1. read employees and store their current salary
     final URIBuilder builder = getClient().newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment("Person").
-            appendEntitySetSegment("Microsoft.Test.OData.Services.AstoriaDefaultService.Employee");
+        appendEntitySetSegment("Person").
+        appendEntitySetSegment("Microsoft.Test.OData.Services.AstoriaDefaultService.Employee");
     final URI employeesURI = builder.build();
     ODataEntitySet employees = getClient().getRetrieveRequestFactory().
-            getEntitySetRequest(employeesURI).execute().getBody();
+        getEntitySetRequest(employeesURI).execute().getBody();
     assertFalse(employees.getEntities().isEmpty());
     final Map<Integer, Integer> preSalaries = new HashMap<Integer, Integer>(employees.getCount());
     for (ODataEntity employee : employees.getEntities()) {
       preSalaries.put(employee.getProperty("PersonId").getPrimitiveValue().toCastValue(Integer.class),
-              employee.getProperty("Salary").getPrimitiveValue().toCastValue(Integer.class));
+          employee.getProperty("Salary").getPrimitiveValue().toCastValue(Integer.class));
     }
     assertFalse(preSalaries.isEmpty());
 
     // 2. invoke action bound, with additional parameter
     final ODataValue param = getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(1);
     final ODataInvokeRequest<ODataNoContent> req = getClient().getInvokeRequestFactory().
-            getActionInvokeRequest(
-                    builder.appendOperationCallSegment("IncreaseSalaries").build(), ODataNoContent.class,
-                    Collections.<String, ODataValue>singletonMap("n", param));
+        getActionInvokeRequest(
+            builder.appendOperationCallSegment("IncreaseSalaries").build(), ODataNoContent.class,
+            Collections.<String, ODataValue> singletonMap("n", param));
     final ODataInvokeResponse<ODataNoContent> res = req.execute();
     assertNotNull(res);
     assertEquals(204, res.getStatusCode());
@@ -243,9 +243,8 @@ public class InvokeTestITCase extends AbstractTestITCase {
     employees = getClient().getRetrieveRequestFactory().getEntitySetRequest(employeesURI).execute().getBody();
     assertFalse(employees.getEntities().isEmpty());
     for (ODataEntity employee : employees.getEntities()) {
-      assertTrue(
-              preSalaries.get(employee.getProperty("PersonId").getPrimitiveValue().toCastValue(Integer.class))
-              < employee.getProperty("Salary").getPrimitiveValue().toCastValue(Integer.class));
+      assertTrue(preSalaries.get(employee.getProperty("PersonId").getPrimitiveValue().toCastValue(Integer.class))
+      < employee.getProperty("Salary").getPrimitiveValue().toCastValue(Integer.class));
     }
   }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/KeyAsSegmentTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/KeyAsSegmentTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/KeyAsSegmentTestITCase.java
index 569ea4f..18ebcd9 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/KeyAsSegmentTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/KeyAsSegmentTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -40,7 +40,7 @@ public class KeyAsSegmentTestITCase extends AbstractTestITCase {
 
   private void read(final ODataFormat format) {
     final URIBuilder uriBuilder = client.newURIBuilder(testKeyAsSegmentServiceRootURL).
-            appendEntitySetSegment("Customer").appendKeySegment(-10);
+        appendEntitySetSegment("Customer").appendKeySegment(-10);
 
     final ODataEntityRequest<ODataEntity> req = client.getRetrieveRequestFactory().getEntityRequest(uriBuilder.build());
     req.setFormat(format);
@@ -91,7 +91,7 @@ public class KeyAsSegmentTestITCase extends AbstractTestITCase {
   public void replaceODataEntityAsAtom() {
     final ODataFormat format = ODataFormat.ATOM;
     final ODataEntity changes = read(format, client.newURIBuilder(testKeyAsSegmentServiceRootURL).
-            appendEntitySetSegment("Car").appendKeySegment(14).build());
+        appendEntitySetSegment("Car").appendKeySegment(14).build());
     updateEntityDescription(format, changes, UpdateType.REPLACE);
   }
 
@@ -99,7 +99,7 @@ public class KeyAsSegmentTestITCase extends AbstractTestITCase {
   public void replaceODataEntityAsJSON() {
     final ODataFormat format = ODataFormat.JSON_FULL_METADATA;
     final ODataEntity changes = read(format, client.newURIBuilder(testKeyAsSegmentServiceRootURL).
-            appendEntitySetSegment("Car").appendKeySegment(14).build());
+        appendEntitySetSegment("Car").appendKeySegment(14).build());
     updateEntityDescription(format, changes, UpdateType.REPLACE);
   }
 

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/LinkTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/LinkTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/LinkTestITCase.java
index 54b0774..fd42cda 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/LinkTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/LinkTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -20,23 +20,24 @@ package org.apache.olingo.fit.v3;
 
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNotEquals;
-import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertTrue;
 
 import java.io.IOException;
 import java.net.URI;
 import java.util.Collections;
 import java.util.List;
+
 import org.apache.olingo.client.api.communication.request.cud.v3.ODataLinkCreateRequest;
 import org.apache.olingo.client.api.communication.request.cud.v3.ODataLinkUpdateRequest;
 import org.apache.olingo.client.api.communication.request.cud.v3.UpdateType;
 import org.apache.olingo.client.api.communication.request.retrieve.v3.ODataLinkCollectionRequest;
 import org.apache.olingo.client.api.communication.response.ODataLinkOperationResponse;
 import org.apache.olingo.client.api.communication.response.ODataRetrieveResponse;
-import org.apache.olingo.commons.api.domain.ODataLink;
 import org.apache.olingo.client.api.domain.v3.ODataLinkCollection;
-import org.apache.olingo.commons.api.format.ODataFormat;
 import org.apache.olingo.client.api.uri.v3.URIBuilder;
+import org.apache.olingo.commons.api.domain.ODataLink;
+import org.apache.olingo.commons.api.format.ODataFormat;
 import org.junit.Test;
 
 /**
@@ -50,10 +51,10 @@ public class LinkTestITCase extends AbstractTestITCase {
 
   private ODataLinkCollection doRetrieveLinkURIs(final ODataFormat format, final String linkname) throws IOException {
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Customer").appendKeySegment(-10);
+        appendEntitySetSegment("Customer").appendKeySegment(-10);
 
     final ODataLinkCollectionRequest req =
-            client.getRetrieveRequestFactory().getLinkCollectionRequest(uriBuilder.build(), linkname);
+        client.getRetrieveRequestFactory().getLinkCollectionRequest(uriBuilder.build(), linkname);
     req.setFormat(format);
 
     final ODataRetrieveResponse<ODataLinkCollection> res = req.execute();
@@ -93,13 +94,13 @@ public class LinkTestITCase extends AbstractTestITCase {
 
     // 2. create new link
     final ODataLink newLink = client.getObjectFactory().
-            newAssociationLink(URI.create(getServiceRoot() + "/Login('3')"));
+        newAssociationLink(URI.create(getServiceRoot() + "/Login('3')"));
 
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Customer").appendKeySegment(-10).appendLinksSegment("Logins");
+        appendEntitySetSegment("Customer").appendKeySegment(-10).appendLinksSegment("Logins");
 
     final ODataLinkCreateRequest req =
-            client.getCUDRequestFactory().getLinkCreateRequest(uriBuilder.build(), newLink);
+        client.getCUDRequestFactory().getLinkCreateRequest(uriBuilder.build(), newLink);
     req.setFormat(format);
 
     final ODataLinkOperationResponse res = req.execute();
@@ -113,7 +114,7 @@ public class LinkTestITCase extends AbstractTestITCase {
     assertEquals(Collections.singletonList(newLink.getLink()), after);
 
     assertEquals(204, client.getCUDRequestFactory().getDeleteRequest(
-            client.newURIBuilder(getServiceRoot()).appendEntitySetSegment("Customer").
+        client.newURIBuilder(getServiceRoot()).appendEntitySetSegment("Customer").
             appendKeySegment(-10).appendLinksSegment("Logins('3')").build()).execute().getStatusCode());
   }
 
@@ -133,13 +134,13 @@ public class LinkTestITCase extends AbstractTestITCase {
 
     // 2. update the link
     ODataLink newLink = client.getObjectFactory().
-            newAssociationLink(URI.create(getServiceRoot() + "/CustomerInfo(12)"));
+        newAssociationLink(URI.create(getServiceRoot() + "/CustomerInfo(12)"));
 
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot());
     uriBuilder.appendEntitySetSegment("Customer").appendKeySegment(-10).appendLinksSegment("Info");
 
     ODataLinkUpdateRequest req =
-            client.getCUDRequestFactory().getLinkUpdateRequest(uriBuilder.build(), updateType, newLink);
+        client.getCUDRequestFactory().getLinkUpdateRequest(uriBuilder.build(), updateType, newLink);
     req.setFormat(format);
 
     ODataLinkOperationResponse res = req.execute();

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/MediaEntityTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/MediaEntityTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/MediaEntityTestITCase.java
index 26f1b29..8628130 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/MediaEntityTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/MediaEntityTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -48,7 +48,7 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
   @Test
   public void read() throws Exception {
     final URIBuilder builder = client.newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment("Car").appendKeySegment(12);
+        appendEntitySetSegment("Car").appendKeySegment(12);
 
     final ODataMediaRequest retrieveReq = client.getRetrieveRequestFactory().getMediaEntityRequest(builder.build());
     retrieveReq.setAccept("*/*");
@@ -63,7 +63,7 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
   @Test(expected = ODataClientErrorException.class)
   public void readWithXmlError() throws Exception {
     final URIBuilder builder =
-            client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(12);
+        client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(12);
 
     final ODataMediaRequest retrieveReq = client.getRetrieveRequestFactory().getMediaEntityRequest(builder.build());
     retrieveReq.setFormat(ODataFormat.APPLICATION_XML);
@@ -74,7 +74,7 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
   @Test(expected = ODataClientErrorException.class)
   public void readWithJsonError() throws Exception {
     final URIBuilder builder =
-            client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(12);
+        client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(12);
 
     final ODataMediaRequest retrieveReq = client.getRetrieveRequestFactory().getMediaEntityRequest(builder.build());
     retrieveReq.setFormat(ODataFormat.APPLICATION_JSON);
@@ -84,13 +84,13 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
 
   private void updateMediaEntity(final ODataFormat format, final int id) throws Exception {
     final URIBuilder builder =
-            client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(id);
+        client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car").appendKeySegment(id);
 
     final String TO_BE_UPDATED = "new buffered stream sample";
     final InputStream input = IOUtils.toInputStream(TO_BE_UPDATED);
 
     final ODataMediaEntityUpdateRequest<ODataEntity> updateReq =
-            client.getCUDRequestFactory().getMediaEntityUpdateRequest(builder.build(), input);
+        client.getCUDRequestFactory().getMediaEntityUpdateRequest(builder.build(), input);
     updateReq.setFormat(format);
 
     final MediaEntityUpdateStreamManager<ODataEntity> streamManager = updateReq.payloadManager();
@@ -118,7 +118,7 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
     final URIBuilder builder = client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment("Car");
 
     final ODataMediaEntityCreateRequest<ODataEntity> createReq =
-            client.getCUDRequestFactory().getMediaEntityCreateRequest(builder.build(), input);
+        client.getCUDRequestFactory().getMediaEntityCreateRequest(builder.build(), input);
     createReq.setFormat(format);
 
     final MediaEntityCreateStreamManager<ODataEntity> streamManager = createReq.payloadManager();
@@ -164,13 +164,13 @@ public class MediaEntityTestITCase extends AbstractTestITCase {
   @Test
   public void updateNamedStream() throws Exception {
     URIBuilder builder = client.newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment("Car").appendKeySegment(16).appendNavigationSegment("Photo");
+        appendEntitySetSegment("Car").appendKeySegment(16).appendNavigationSegment("Photo");
 
     final String TO_BE_UPDATED = "buffered stream sample";
     final InputStream input = new ByteArrayInputStream(TO_BE_UPDATED.getBytes());
 
     final ODataStreamUpdateRequest updateReq =
-            client.getCUDRequestFactory().getStreamUpdateRequest(builder.build(), input);
+        client.getCUDRequestFactory().getStreamUpdateRequest(builder.build(), input);
 
     final StreamUpdateStreamManager streamManager = updateReq.payloadManager();
     final ODataStreamUpdateResponse updateRes = streamManager.getResponse();

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/MetadataTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/MetadataTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/MetadataTestITCase.java
index 3ead8d6..7ee68a8 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/MetadataTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/MetadataTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
 package org.apache.olingo.fit.v3;
 
-import org.apache.olingo.commons.api.edm.Edm;
 import static org.junit.Assert.assertNotNull;
+
+import org.apache.olingo.commons.api.edm.Edm;
 import org.junit.Test;
 
 public class MetadataTestITCase extends AbstractTestITCase {
@@ -27,7 +28,7 @@ public class MetadataTestITCase extends AbstractTestITCase {
   @Test
   public void retrieve() {
     final Edm metadata = getClient().getRetrieveRequestFactory().
-            getMetadataRequest(testStaticServiceRootURL).execute().getBody();
+        getMetadataRequest(testStaticServiceRootURL).execute().getBody();
     assertNotNull(metadata);
   }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/OpenTypeTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/OpenTypeTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/OpenTypeTestITCase.java
index 98e5b94..f9fa045 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/OpenTypeTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/OpenTypeTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -44,7 +44,7 @@ public class OpenTypeTestITCase extends AbstractTestITCase {
   @Test
   public void checkOpenTypeEntityTypesExist() {
     final Edm metadata = getClient().getRetrieveRequestFactory().
-            getMetadataRequest(testOpenTypeServiceRootURL).execute().getBody();
+        getMetadataRequest(testOpenTypeServiceRootURL).execute().getBody();
 
     final EdmSchema schema = metadata.getSchemas().get(0);
 
@@ -55,7 +55,7 @@ public class OpenTypeTestITCase extends AbstractTestITCase {
 
   private ODataEntity readRow(final ODataFormat format, final String uuid) {
     final URIBuilder builder = getClient().newURIBuilder(testOpenTypeServiceRootURL).
-            appendEntitySetSegment("Row").appendKeySegment(UUID.fromString(uuid));
+        appendEntitySetSegment("Row").appendKeySegment(UUID.fromString(uuid));
     return read(format, builder.build());
   }
 
@@ -82,92 +82,92 @@ public class OpenTypeTestITCase extends AbstractTestITCase {
     final Integer id = 1426;
 
     ODataEntity rowIndex = getClient().getObjectFactory().newEntity(
-            new FullQualifiedName("Microsoft.Test.OData.Services.OpenTypesServiceV3.RowIndex"));
+        new FullQualifiedName("Microsoft.Test.OData.Services.OpenTypesServiceV3.RowIndex"));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("Id",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(id)));
+        getClient().getObjectFactory().newPrimitiveProperty("Id",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(id)));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("aString",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("string")));
+        getClient().getObjectFactory().newPrimitiveProperty("aString",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().buildString("string")));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("aBoolean",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().buildBoolean(true)));
+        getClient().getObjectFactory().newPrimitiveProperty("aBoolean",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().buildBoolean(true)));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("aDouble",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().buildDouble(1.5D)));
+        getClient().getObjectFactory().newPrimitiveProperty("aDouble",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().buildDouble(1.5D)));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("aByte",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().
-                    setType(EdmPrimitiveTypeKind.SByte).setValue(Byte.MAX_VALUE).
-                    build()));
+        getClient().getObjectFactory().newPrimitiveProperty("aByte",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().
+                setType(EdmPrimitiveTypeKind.SByte).setValue(Byte.MAX_VALUE).
+                build()));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newPrimitiveProperty("aDate",
-                    getClient().getObjectFactory().newPrimitiveValueBuilder().
-                    setType(EdmPrimitiveTypeKind.DateTime).setValue(Calendar.getInstance()).
-                    build()));
+        getClient().getObjectFactory().newPrimitiveProperty("aDate",
+            getClient().getObjectFactory().newPrimitiveValueBuilder().
+                setType(EdmPrimitiveTypeKind.DateTime).setValue(Calendar.getInstance()).
+                build()));
 
     final ODataComplexValue<ODataProperty> contactDetails = getClient().getObjectFactory().newComplexValue(
-            "Microsoft.Test.OData.Services.OpenTypesServiceV3.ContactDetails");
+        "Microsoft.Test.OData.Services.OpenTypesServiceV3.ContactDetails");
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("FirstContacted",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildBinary("text".getBytes())));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildBinary("text".getBytes())));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("LastContacted",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.DateTimeOffset).setValue(null).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Contacted",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.DateTime).setValue(null).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("GUID",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildGuid(UUID.randomUUID())));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildGuid(UUID.randomUUID())));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("PreferedContactTime",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.Time).setValue(null).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Byte",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.Byte).setValue(24).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("SignedByte",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.SByte).setValue(Byte.MAX_VALUE).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Double",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildDouble(Double.MAX_VALUE)));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildDouble(Double.MAX_VALUE)));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Single",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildSingle(Float.MAX_VALUE)));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildSingle(Float.MAX_VALUE)));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Short",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().
+        getClient().getObjectFactory().newPrimitiveValueBuilder().
             setType(EdmPrimitiveTypeKind.Int16).setValue(Short.MAX_VALUE).build()));
     contactDetails.add(getClient().getObjectFactory().newPrimitiveProperty("Int",
-            getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(Integer.MAX_VALUE)));
+        getClient().getObjectFactory().newPrimitiveValueBuilder().buildInt32(Integer.MAX_VALUE)));
     getClient().getBinder().add(rowIndex,
-            getClient().getObjectFactory().newComplexProperty("aContact", contactDetails));
+        getClient().getObjectFactory().newComplexProperty("aContact", contactDetails));
 
     final ODataEntityCreateRequest<ODataEntity> createReq = getClient().getCUDRequestFactory().
-            getEntityCreateRequest(getClient().newURIBuilder(testOpenTypeServiceRootURL).
-                    appendEntitySetSegment("RowIndex").build(), rowIndex);
+        getEntityCreateRequest(getClient().newURIBuilder(testOpenTypeServiceRootURL).
+            appendEntitySetSegment("RowIndex").build(), rowIndex);
     createReq.setFormat(format);
     final ODataEntityCreateResponse<ODataEntity> createRes = createReq.execute();
     assertEquals(201, createRes.getStatusCode());
 
     final URIBuilder builder = getClient().newURIBuilder(testOpenTypeServiceRootURL).
-            appendEntitySetSegment("RowIndex").appendKeySegment(id);
+        appendEntitySetSegment("RowIndex").appendKeySegment(id);
     rowIndex = read(format, builder.build());
     assertNotNull(rowIndex);
     assertEquals(EdmPrimitiveTypeKind.Int32,
-            rowIndex.getProperty("Id").getPrimitiveValue().getTypeKind());
+        rowIndex.getProperty("Id").getPrimitiveValue().getTypeKind());
     assertEquals(EdmPrimitiveTypeKind.String,
-            rowIndex.getProperty("aString").getPrimitiveValue().getTypeKind());
+        rowIndex.getProperty("aString").getPrimitiveValue().getTypeKind());
     assertEquals(EdmPrimitiveTypeKind.Boolean,
-            rowIndex.getProperty("aBoolean").getPrimitiveValue().getTypeKind());
+        rowIndex.getProperty("aBoolean").getPrimitiveValue().getTypeKind());
     assertTrue(rowIndex.getProperty("aDouble").hasPrimitiveValue());
     assertTrue(rowIndex.getProperty("aByte").hasPrimitiveValue());
     assertEquals(EdmPrimitiveTypeKind.SByte, rowIndex.getProperty("aByte").getPrimitiveValue().getTypeKind());
     assertTrue(rowIndex.getProperty("aDate").hasPrimitiveValue());
     assertEquals(EdmPrimitiveTypeKind.DateTime, rowIndex.getProperty("aDate").getPrimitiveValue().getTypeKind());
     assertTrue(rowIndex.getProperty("aContact").hasComplexValue());
-    assertEquals("Microsoft.Test.OData.Services.OpenTypesServiceV3.ContactDetails", 
-            rowIndex.getProperty("aContact").getValue().getTypeName());
+    assertEquals("Microsoft.Test.OData.Services.OpenTypesServiceV3.ContactDetails",
+        rowIndex.getProperty("aContact").getValue().getTypeName());
     assertTrue(rowIndex.getProperty("aContact").getComplexValue().get("SignedByte").hasPrimitiveValue());
 
     final ODataDeleteResponse deleteRes = getClient().getCUDRequestFactory().
-            getDeleteRequest(rowIndex.getEditLink()).execute();
+        getDeleteRequest(rowIndex.getEditLink()).execute();
     assertEquals(204, deleteRes.getStatusCode());
   }
 

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/PrimitiveKeysTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/PrimitiveKeysTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/PrimitiveKeysTestITCase.java
index 2b2ec75..831b9e0 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/PrimitiveKeysTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/PrimitiveKeysTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -34,7 +34,7 @@ public class PrimitiveKeysTestITCase extends AbstractTestITCase {
 
   private void readEntity(final String entityType, final Object key, final ODataFormat format) {
     final ODataEntityRequest<ODataEntity> req = client.getRetrieveRequestFactory().getEntityRequest(
-            client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment(entityType).
+        client.newURIBuilder(testStaticServiceRootURL).appendEntitySetSegment(entityType).
             appendKeySegment(key).
             build());
     req.setFormat(format);

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/PropertyRetrieveTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/PropertyRetrieveTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/PropertyRetrieveTestITCase.java
index 2a0bf65..36761a7 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/PropertyRetrieveTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/PropertyRetrieveTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -42,11 +42,12 @@ import org.junit.Test;
 
 public class PropertyRetrieveTestITCase extends AbstractTestITCase {
 
-  private void retrievePropertyTest(final ODataFormat format, String entitySegment, String structuralSegment) {
+  private void
+      retrievePropertyTest(final ODataFormat format, final String entitySegment, final String structuralSegment) {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendEntitySetSegment(entitySegment).appendPropertySegment(structuralSegment);
+        appendEntitySetSegment(entitySegment).appendPropertySegment(structuralSegment);
     final ODataPropertyRequest<ODataProperty> req = client.getRetrieveRequestFactory().
-            getPropertyRequest(uriBuilder.build());
+        getPropertyRequest(uriBuilder.build());
     req.setFormat(format);
     try {
       final ODataProperty property = req.execute().getBody();
@@ -70,127 +71,137 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
       }
     }
   }
-  //test with json header
+
+  // test with json header
 
   @Test
   public void jsonRetrieveProperty() {
-    //Primitive types
+    // Primitive types
     retrievePropertyTest(ODataFormat.JSON, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.JSON, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.JSON, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.JSON, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of Complex types
+    // Collection of Complex types
     retrievePropertyTest(ODataFormat.JSON, "Customer(-10)", "BackupContactInfo");
-    //Collection of primitives
+    // Collection of primitives
     retrievePropertyTest(ODataFormat.JSON, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //complex types
+    // complex types
     retrievePropertyTest(ODataFormat.JSON, "Order(-9)", "Concurrency");
   }
-  //test with json full metadata
+
+  // test with json full metadata
 
   @Test
   public void jsonFullMetadataRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of Complex types
+    // Collection of Complex types
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Customer(-10)", "BackupContactInfo");
-    //Collection of primitives		
+    // Collection of primitives
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //Complex types
+    // Complex types
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Order(-9)", "Concurrency");
   }
+
   // json with no metadata
 
   @Test
   public void jsonNoMetadataRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of Complex types
+    // Collection of Complex types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "BackupContactInfo");
-    //Collection of Primitives
+    // Collection of Primitives
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //Complex types
+    // Complex types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Order(-9)", "Concurrency");
 
   }
+
   // json with minimla metadata
 
   @Test
   public void jsonmininalRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of complex types
+    // Collection of complex types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)", "BackupContactInfo");
-    //Collection of primitives
+    // Collection of primitives
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //Complex types
+    // Complex types
     retrievePropertyTest(ODataFormat.JSON_NO_METADATA, "Order(-9)", "Concurrency");
   }
+
   // with xml header
 
   @Test
   public void xmlRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.XML, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.XML, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of Complex types
+    // Collection of Complex types
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "BackupContactInfo");
-    //Collection of primitives
+    // Collection of primitives
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //Complex types
+    // Complex types
     retrievePropertyTest(ODataFormat.XML, "Order(-9)", "Concurrency");
   }
+
   // with atom header
 
   @Test
   public void atomRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "Name");
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "CustomerId");
     retrievePropertyTest(ODataFormat.XML, "Message(FromUsername='1',MessageId=-10)", "Sent");
     retrievePropertyTest(ODataFormat.XML, "Message(FromUsername='1',MessageId=-10)", "IsRead");
-    //Collection of Complex types 
+    // Collection of Complex types
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)", "BackupContactInfo");
-    //Collection of primitives
+    // Collection of primitives
     retrievePropertyTest(ODataFormat.XML, "Customer(-10)/PrimaryContactInfo", "EmailBag");
-    //complex types
+    // complex types
     retrievePropertyTest(ODataFormat.XML, "Order(-9)", "Concurrency");
   }
+
   // with invalid structural segment
 
   @Test
   public void invalidSegmentRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.XML, "Customers(-10)", "Name");
 
   }
+
   // with null pub format
 
   @Test
   public void nullSegmentRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(null, "Customers(-10)", "Name");
 
   }
+
   // with null accept header format
 
   @Test
   public void nullAcceptRetrieveProperty() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.XML, "Customers(-10)", "Name");
 
   }
+
   // with json pub format and atom accept format
 
   @Test
@@ -199,21 +210,23 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Customers(-10)", "Name");
 
   }
-  //bad request 400 error. Message takes two keys
+
+  // bad request 400 error. Message takes two keys
 
   @Test
   public void badRequestTest() {
-    //primitive types
+    // primitive types
     retrievePropertyTest(ODataFormat.JSON_FULL_METADATA, "Message(FromUsername='1')", "Sent");
   }
-  //navigation link of stream
+
+  // navigation link of stream
 
   @Test
   public void navigationMediaLink() {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photos");
+        appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photos");
     final ODataEntitySetRequest<ODataEntitySet> req = client.getRetrieveRequestFactory().
-            getEntitySetRequest(uriBuilder.build());
+        getEntitySetRequest(uriBuilder.build());
     req.setAccept("application/json");
     final ODataRetrieveResponse<ODataEntitySet> res = req.execute();
     assertEquals(200, res.getStatusCode());
@@ -223,21 +236,22 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
     assertNotNull(entity);
     assertEquals(entity.size(), 2);
     assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-3,ProductId=-3)",
-            entity.get(0).getProperties().get(0).getValue().toString());
+        entity.get(0).getProperties().get(0).getValue().toString());
     assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-2,ProductId=-2)",
-            entity.get(1).getProperties().get(0).getValue().toString());
+        entity.get(1).getProperties().get(0).getValue().toString());
     for (int i = 0; i < entity.size(); i++) {
       assertNotNull(entity.get(0).getProperties().get(0).getValue());
     }
   }
-  //navigation link of stream, Bad Request(404 error). 'Photo' is not a valid navigation link
+
+  // navigation link of stream, Bad Request(404 error). 'Photo' is not a valid navigation link
 
   @Test
   public void navigationMediaLinkInvalidQuery() {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photo");
+        appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photo");
     final ODataEntitySetRequest<ODataEntitySet> req = client.getRetrieveRequestFactory().
-            getEntitySetRequest(uriBuilder.build());
+        getEntitySetRequest(uriBuilder.build());
     req.setAccept("application/json");
     try {
       final ODataRetrieveResponse<ODataEntitySet> res = req.execute();
@@ -248,9 +262,9 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
       assertNotNull(entity);
       assertEquals(entity.size(), 2);
       assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-3,ProductId=-3)", entity.get(0).
-              getProperties().get(0).getValue().toString());
+          getProperties().get(0).getValue().toString());
       assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-2,ProductId=-2)", entity.get(1).
-              getProperties().get(0).getValue().toString());
+          getProperties().get(0).getValue().toString());
     } catch (ODataClientErrorException e) {
       assertEquals(404, e.getStatusLine().getStatusCode());
     }
@@ -259,9 +273,9 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
   @Test
   public void navigationMediaLinkInvalidFormat() {
     final URIBuilder uriBuilder = client.newURIBuilder(testStaticServiceRootURL).
-            appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photos");
+        appendNavigationSegment("Product").appendKeySegment(-7).appendLinksSegment("Photos");
     final ODataEntitySetRequest<ODataEntitySet> req = client.getRetrieveRequestFactory().
-            getEntitySetRequest(uriBuilder.build());
+        getEntitySetRequest(uriBuilder.build());
     req.setAccept("application/atom+xml");
     try {
       final ODataRetrieveResponse<ODataEntitySet> res = req.execute();
@@ -272,9 +286,9 @@ public class PropertyRetrieveTestITCase extends AbstractTestITCase {
       assertNotNull(entity);
       assertEquals(entity.size(), 2);
       assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-3,ProductId=-3)", entity.get(0).
-              getProperties().get(0).getValue().toString());
+          getProperties().get(0).getValue().toString());
       assertEquals(testStaticServiceRootURL + "/ProductPhoto(PhotoId=-2,ProductId=-2)", entity.get(1).
-              getProperties().get(0).getValue().toString());
+          getProperties().get(0).getValue().toString());
     } catch (ODataClientErrorException e) {
       assertEquals(415, e.getStatusLine().getStatusCode());
     }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/v3/PropertyTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/v3/PropertyTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/v3/PropertyTestITCase.java
index 7a29f0f..ef98577 100644
--- a/fit/src/test/java/org/apache/olingo/fit/v3/PropertyTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/v3/PropertyTestITCase.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
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
+ * with the License. You may obtain a copy of the License at
+ * 
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * 
  * Unless required by applicable law or agreed to in writing,
  * software distributed under the License is distributed on an
  * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
+ * KIND, either express or implied. See the License for the
  * specific language governing permissions and limitations
  * under the License.
  */
@@ -144,29 +144,29 @@ public class PropertyTestITCase extends AbstractTestITCase {
   @Test
   public void nullNullableProperty() {
     final ODataDeleteResponse res = client.getCUDRequestFactory().getDeleteRequest(client.newURIBuilder(
-            getServiceRoot()).
-            appendEntitySetSegment("Order").appendKeySegment(-8).
-            appendPropertySegment("CustomerId").appendValueSegment().build()).
-            execute();
+        getServiceRoot()).
+        appendEntitySetSegment("Order").appendKeySegment(-8).
+        appendPropertySegment("CustomerId").appendValueSegment().build()).
+        execute();
     assertEquals(204, res.getStatusCode());
   }
 
   @Test(expected = ODataClientErrorException.class)
   public void nullNonNullableProperty() {
     client.getCUDRequestFactory().getDeleteRequest(client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Driver").appendKeySegment("1").
-            appendPropertySegment("BirthDate").appendValueSegment().build()).
-            execute();
+        appendEntitySetSegment("Driver").appendKeySegment("1").
+        appendPropertySegment("BirthDate").appendValueSegment().build()).
+        execute();
   }
 
   private void updatePropertyValue(final ODataFormat format, final UpdateType type)
       throws IOException, EdmPrimitiveTypeException {
 
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Customer").appendKeySegment(-9).
-            appendPropertySegment("PrimaryContactInfo").
-            appendPropertySegment("HomePhone").
-            appendPropertySegment("PhoneNumber");
+        appendEntitySetSegment("Customer").appendKeySegment(-9).
+        appendPropertySegment("PrimaryContactInfo").
+        appendPropertySegment("HomePhone").
+        appendPropertySegment("PhoneNumber");
 
     ODataValueRequest retrieveReq = client.getRetrieveRequestFactory().getPropertyValueRequest(uriBuilder.build());
     retrieveReq.setFormat(format);
@@ -185,7 +185,7 @@ public class PropertyTestITCase extends AbstractTestITCase {
     final ODataPrimitiveValue newVal = client.getObjectFactory().newPrimitiveValueBuilder().setValue(newMsg).build();
 
     final ODataValueUpdateRequest updateReq =
-            client.getCUDRequestFactory().getValueUpdateRequest(uriBuilder.build(), type, newVal);
+        client.getCUDRequestFactory().getValueUpdateRequest(uriBuilder.build(), type, newVal);
     updateReq.setFormat(format);
 
     final ODataValueUpdateResponse updateRes = updateReq.execute();
@@ -205,22 +205,22 @@ public class PropertyTestITCase extends AbstractTestITCase {
 
   private void updateComplexProperty(final ODataFormat format, final UpdateType type) throws IOException {
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Customer").appendKeySegment(-9).appendPropertySegment("PrimaryContactInfo");
+        appendEntitySetSegment("Customer").appendKeySegment(-9).appendPropertySegment("PrimaryContactInfo");
 
     ODataPropertyRequest<ODataProperty> retrieveReq = client.getRetrieveRequestFactory().
-            getPropertyRequest(uriBuilder.build());
+        getPropertyRequest(uriBuilder.build());
     retrieveReq.setFormat(format);
 
     ODataRetrieveResponse<ODataProperty> retrieveRes = retrieveReq.execute();
     assertEquals(200, retrieveRes.getStatusCode());
 
     ODataProperty primaryContactInfo = client.getObjectFactory().
-            newComplexProperty("PrimaryContactInfo", retrieveRes.getBody().getComplexValue());
+        newComplexProperty("PrimaryContactInfo", retrieveRes.getBody().getComplexValue());
 
     final String newItem = "new item " + System.currentTimeMillis();
 
     final ODataCollectionValue<ODataValue> originalValue =
-            primaryContactInfo.getComplexValue().get("EmailBag").getCollectionValue();
+        primaryContactInfo.getComplexValue().get("EmailBag").getCollectionValue();
 
     final int origSize = originalValue.size();
 
@@ -228,7 +228,7 @@ public class PropertyTestITCase extends AbstractTestITCase {
     assertEquals(origSize + 1, originalValue.size());
 
     final ODataPropertyUpdateRequest updateReq = client.getCUDRequestFactory().
-            getPropertyComplexValueUpdateRequest(uriBuilder.build(), type, primaryContactInfo);
+        getPropertyComplexValueUpdateRequest(uriBuilder.build(), type, primaryContactInfo);
     if (client.getConfiguration().isUseXHTTPMethod()) {
       assertEquals(HttpMethod.POST, updateReq.getMethod());
     } else {
@@ -253,17 +253,17 @@ public class PropertyTestITCase extends AbstractTestITCase {
   private void updateCollectionProperty(final ODataFormat format) throws IOException {
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot());
     uriBuilder.appendEntitySetSegment("Customer").appendKeySegment(-10).
-            appendPropertySegment("PrimaryContactInfo").appendPropertySegment("AlternativeNames");
+        appendPropertySegment("PrimaryContactInfo").appendPropertySegment("AlternativeNames");
 
     ODataPropertyRequest<ODataProperty> retrieveReq = client.getRetrieveRequestFactory().
-            getPropertyRequest(uriBuilder.build());
+        getPropertyRequest(uriBuilder.build());
     retrieveReq.setFormat(format);
 
     ODataRetrieveResponse<ODataProperty> retrieveRes = retrieveReq.execute();
     assertEquals(200, retrieveRes.getStatusCode());
 
     ODataProperty alternativeNames = client.getObjectFactory().newCollectionProperty("AlternativeNames",
-            retrieveRes.getBody().getCollectionValue());
+        retrieveRes.getBody().getCollectionValue());
 
     final String newItem = "new item " + System.currentTimeMillis();
 
@@ -275,7 +275,7 @@ public class PropertyTestITCase extends AbstractTestITCase {
     assertEquals(origSize + 1, originalValue.size());
 
     final ODataPropertyUpdateRequest updateReq =
-            client.getCUDRequestFactory().getPropertyCollectionValueUpdateRequest(uriBuilder.build(),
+        client.getCUDRequestFactory().getPropertyCollectionValueUpdateRequest(uriBuilder.build(),
             alternativeNames);
     if (client.getConfiguration().isUseXHTTPMethod()) {
       assertEquals(HttpMethod.POST, updateReq.getMethod());
@@ -301,11 +301,11 @@ public class PropertyTestITCase extends AbstractTestITCase {
   private void updatePrimitiveProperty(final ODataFormat format) throws IOException, EdmPrimitiveTypeException {
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot());
     uriBuilder.appendEntitySetSegment("Customer").appendKeySegment(-9).
-            appendPropertySegment("PrimaryContactInfo").
-            appendPropertySegment("HomePhone").appendPropertySegment("PhoneNumber");
+        appendPropertySegment("PrimaryContactInfo").
+        appendPropertySegment("HomePhone").appendPropertySegment("PhoneNumber");
 
     ODataPropertyRequest<ODataProperty> retrieveReq = client.getRetrieveRequestFactory().
-            getPropertyRequest(uriBuilder.build());
+        getPropertyRequest(uriBuilder.build());
     retrieveReq.setFormat(format);
 
     ODataRetrieveResponse<ODataProperty> retrieveRes = retrieveReq.execute();
@@ -319,10 +319,10 @@ public class PropertyTestITCase extends AbstractTestITCase {
     assertNotEquals(newMsg, oldMsg);
 
     phoneNumber = client.getObjectFactory().newPrimitiveProperty("PhoneNumber",
-            client.getObjectFactory().newPrimitiveValueBuilder().setValue(newMsg).build());
+        client.getObjectFactory().newPrimitiveValueBuilder().setValue(newMsg).build());
 
     final ODataPropertyUpdateRequest updateReq =
-            client.getCUDRequestFactory().getPropertyPrimitiveValueUpdateRequest(uriBuilder.build(), phoneNumber);
+        client.getCUDRequestFactory().getPropertyPrimitiveValueUpdateRequest(uriBuilder.build(), phoneNumber);
     if (client.getConfiguration().isUseXHTTPMethod()) {
       assertEquals(HttpMethod.POST, updateReq.getMethod());
     } else {
@@ -345,7 +345,7 @@ public class PropertyTestITCase extends AbstractTestITCase {
 
   private void rawRequest(final ODataFormat format) {
     final URIBuilder uriBuilder = client.newURIBuilder(getServiceRoot()).
-            appendEntitySetSegment("Customer").appendKeySegment(-10).appendPropertySegment("BackupContactInfo");
+        appendEntitySetSegment("Customer").appendKeySegment(-10).appendPropertySegment("BackupContactInfo");
 
     final ODataRawRequest req = client.getRetrieveRequestFactory().getRawRequest(uriBuilder.build());
     req.setFormat(format.getContentType(client.getServiceVersion()).toContentTypeString());