You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@olingo.apache.org by mi...@apache.org on 2014/07/03 09:16:43 UTC

[46/55] [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/proxy/v3/AbstractTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AbstractTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AbstractTestITCase.java
index f2de82a..cf19a12 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AbstractTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AbstractTestITCase.java
@@ -1,42 +1,42 @@
 /*
  * 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.proxy.v3;
 
-import static org.junit.Assert.assertTrue;
-import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertFalse;
 import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertTrue;
 
 import java.io.IOException;
 import java.util.Arrays;
 import java.util.Collections;
+
 import org.apache.olingo.client.api.v3.EdmEnabledODataClient;
 import org.apache.olingo.commons.api.format.ContentType;
 import org.apache.olingo.ext.proxy.EntityContainerFactory;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        DefaultContainer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        ContactDetails;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.DefaultContainer;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Aliases;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ContactDetails;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Phone;
-
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.BeforeClass;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
@@ -83,9 +83,9 @@ public abstract class AbstractTestITCase {
   }
 
   protected Customer getSampleCustomerProfile(
-          final Integer id,
-          final String sampleName,
-          final DefaultContainer container) {
+      final Integer id,
+      final String sampleName,
+      final DefaultContainer container) {
 
     final Customer customer = container.getCustomer().newCustomer();
 
@@ -97,27 +97,27 @@ public abstract class AbstractTestITCase {
 
     final ContactDetails cd = customer.factory().newPrimaryContactInfo();
     cd.setAlternativeNames(Arrays.asList("alternative1", "alternative2"));
-    cd.setEmailBag(Collections.<String>singleton("myname@mydomain.org"));
-    cd.setMobilePhoneBag(Collections.<Phone>emptySet());
+    cd.setEmailBag(Collections.<String> singleton("myname@mydomain.org"));
+    cd.setMobilePhoneBag(Collections.<Phone> emptySet());
     customer.setPrimaryContactInfo(cd);
 
     final Aliases aliases = cd.factory().newContactAlias();
-    aliases.setAlternativeNames(Collections.<String>singleton("myAlternativeName"));
+    aliases.setAlternativeNames(Collections.<String> singleton("myAlternativeName"));
     cd.setContactAlias(aliases);
 
     final ContactDetails bcd = customer.factory().newBackupContactInfo();
     bcd.setAlternativeNames(Arrays.asList("alternative3", "alternative4"));
-    bcd.setEmailBag(Collections.<String>emptySet());
-    bcd.setMobilePhoneBag(Collections.<Phone>emptySet());
-    customer.setBackupContactInfo(Collections.<ContactDetails>singleton(bcd));
+    bcd.setEmailBag(Collections.<String> emptySet());
+    bcd.setMobilePhoneBag(Collections.<Phone> emptySet());
+    customer.setBackupContactInfo(Collections.<ContactDetails> singleton(bcd));
 
     return customer;
   }
 
   protected void checkSampleCustomerProfile(
-          final Customer customer,
-          final Integer id,
-          final String sampleName) {
+      final Customer customer,
+      final Integer id,
+      final String sampleName) {
 
     assertEquals(id, customer.getCustomerId());
     assertNotNull(customer.getPrimaryContactInfo());
@@ -138,7 +138,7 @@ public abstract class AbstractTestITCase {
     assertTrue(bcd.getMobilePhoneBag().isEmpty());
   }
 
-  protected Customer readCustomer(final DefaultContainer container, int id) {
+  protected Customer readCustomer(final DefaultContainer container, final int id) {
     final Customer customer = container.getCustomer().get(id);
     assertNotNull(customer);
     assertEquals(Integer.valueOf(id), customer.getCustomerId());

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ActionOverloadingTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ActionOverloadingTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ActionOverloadingTestITCase.java
index 5c8019b..b43c842 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ActionOverloadingTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ActionOverloadingTestITCase.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.
  */
@@ -25,18 +25,14 @@ import static org.junit.Assert.assertNotNull;
 import org.apache.olingo.client.api.v3.EdmEnabledODataClient;
 import org.apache.olingo.commons.api.format.ContentType;
 import org.apache.olingo.ext.proxy.EntityContainerFactory;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.
-        DefaultContainer;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.
-        Employee;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.
-        EmployeeCollection;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.
-        OrderLineKey;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployee;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployeeCollection;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.DefaultContainer;
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.OrderLineKey;
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee;
+import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 /**
@@ -45,8 +41,8 @@ import org.junit.Test;
 public class ActionOverloadingTestITCase extends AbstractTestITCase {
 
   private DefaultContainer getContainer() {
-    final EntityContainerFactory<EdmEnabledODataClient> ecf = 
-            EntityContainerFactory.getV3(testActionOverloadingServiceRootURL);
+    final EntityContainerFactory<EdmEnabledODataClient> ecf =
+        EntityContainerFactory.getV3(testActionOverloadingServiceRootURL);
     ecf.getClient().getConfiguration().setDefaultBatchAcceptFormat(ContentType.APPLICATION_OCTET_STREAM);
     return ecf.getEntityContainer(DefaultContainer.class);
   }
@@ -83,16 +79,16 @@ public class ActionOverloadingTestITCase extends AbstractTestITCase {
     Employee empl = ecoll.iterator().next();
     assertNotNull(empl);
 
-    int key = empl.getPersonId();
+    empl.getPersonId();
     int salary = empl.getSalary();
 
     ecoll.operations().increaseSalaries(5);
 
     // the invoke above changed the local entities, re-read
-    containerFactory.getContext().detachAll();        
+    containerFactory.getContext().detachAll();
     ecoll = aocontainer.getPerson().getAll(EmployeeCollection.class);
     empl = ecoll.iterator().next();
-    
+
     assertEquals(salary + 5, empl.getSalary(), 0);
 
     SpecialEmployeeCollection secoll = aocontainer.getPerson().getAll(SpecialEmployeeCollection.class);
@@ -101,16 +97,16 @@ public class ActionOverloadingTestITCase extends AbstractTestITCase {
     SpecialEmployee sempl = secoll.toArray(new SpecialEmployee[secoll.size()])[1];
     assertNotNull(sempl);
 
-    key = sempl.getPersonId();
+    sempl.getPersonId();
     salary = sempl.getSalary();
 
     secoll.operations().increaseSalaries(5);
 
     // the invoke above changed the local entities, re-read
-    containerFactory.getContext().detachAll();        
+    containerFactory.getContext().detachAll();
     secoll = aocontainer.getPerson().getAll(SpecialEmployeeCollection.class);
     sempl = secoll.toArray(new SpecialEmployee[secoll.size()])[1];
-    
+
     assertEquals(salary + 5, sempl.getSalary(), 0);
   }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AsyncTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AsyncTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AsyncTestITCase.java
index 70346f7..951e499 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AsyncTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/AsyncTestITCase.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.
  */
@@ -26,18 +26,17 @@ import static org.junit.Assert.assertTrue;
 import java.util.UUID;
 import java.util.concurrent.ExecutionException;
 import java.util.concurrent.Future;
+
 import org.apache.olingo.ext.proxy.api.AsyncCall;
 import org.apache.olingo.ext.proxy.api.Filter;
+//CHECKSTYLE:OFF (Maven checkstyle)
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        EmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        ProductCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ProductCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 public class AsyncTestITCase extends AbstractTestITCase {
@@ -45,13 +44,13 @@ public class AsyncTestITCase extends AbstractTestITCase {
   @Test
   public void retrieveEntitySet() throws InterruptedException, ExecutionException {
     final Future<ProductCollection> futureProds =
-            new AsyncCall<ProductCollection>(containerFactory.getClient().getConfiguration()) {
+        new AsyncCall<ProductCollection>(containerFactory.getClient().getConfiguration()) {
 
-              @Override
-              public ProductCollection call() {
-                return container.getProduct().getAll();
-              }
-            };
+          @Override
+          public ProductCollection call() {
+            return container.getProduct().getAll();
+          }
+        };
     assertNotNull(futureProds);
 
     while (!futureProds.isDone()) {
@@ -101,27 +100,27 @@ public class AsyncTestITCase extends AbstractTestITCase {
   @Test
   public void polymorphQuery() throws Exception {
     final Future<Filter<Employee, EmployeeCollection>> queryEmployee =
-            new AsyncCall<Filter<Employee, EmployeeCollection>>(containerFactory.getClient().getConfiguration()) {
+        new AsyncCall<Filter<Employee, EmployeeCollection>>(containerFactory.getClient().getConfiguration()) {
 
-              @Override
-              public Filter<Employee, EmployeeCollection> call() {
-                return container.getPerson().createFilter(EmployeeCollection.class);
-              }
-            };
+          @Override
+          public Filter<Employee, EmployeeCollection> call() {
+            return container.getPerson().createFilter(EmployeeCollection.class);
+          }
+        };
     assertFalse(queryEmployee.get().getResult().isEmpty());
 
     final Future<Filter<SpecialEmployee, SpecialEmployeeCollection>> querySpecialEmployee =
-            new AsyncCall<Filter<SpecialEmployee, SpecialEmployeeCollection>>(
-                    containerFactory.getClient().getConfiguration()) {
-
-              @Override
-              public Filter<SpecialEmployee, SpecialEmployeeCollection> call() {
-                return container.getPerson().createFilter(SpecialEmployeeCollection.class);
-              }
-            };
+        new AsyncCall<Filter<SpecialEmployee, SpecialEmployeeCollection>>(
+            containerFactory.getClient().getConfiguration()) {
+
+          @Override
+          public Filter<SpecialEmployee, SpecialEmployeeCollection> call() {
+            return container.getPerson().createFilter(SpecialEmployeeCollection.class);
+          }
+        };
     assertFalse(querySpecialEmployee.get().getResult().isEmpty());
 
     assertTrue(container.getPerson().getAll().size()
-            > queryEmployee.get().getResult().size() + querySpecialEmployee.get().getResult().size());
+    > queryEmployee.get().getResult().size() + querySpecialEmployee.get().getResult().size());
   }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ContextTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ContextTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ContextTestITCase.java
index 8db857a..9caab38 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ContextTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/ContextTestITCase.java
@@ -1,30 +1,30 @@
 /*
  * 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.proxy.v3;
 
-import static org.junit.Assert.fail;
 import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotEquals;
-import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.assertFalse;
+import static org.junit.Assert.assertNotEquals;
 import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertNull;
+import static org.junit.Assert.assertTrue;
+import static org.junit.Assert.fail;
 
 import java.lang.reflect.Proxy;
 import java.util.ArrayList;
@@ -33,23 +33,19 @@ import java.util.Collection;
 import java.util.Collections;
 import java.util.List;
 import java.util.Map;
+
 import org.apache.olingo.ext.proxy.api.annotations.NavigationProperty;
 import org.apache.olingo.ext.proxy.commons.EntityInvocationHandler;
 import org.apache.olingo.ext.proxy.context.AttachedEntityStatus;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        ContactDetails;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        Customer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        CustomerInfo;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        Login;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        Order;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        OrderCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        Phone;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ContactDetails;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfo;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Login;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Phone;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 /**
@@ -63,9 +59,9 @@ public class ContextTestITCase extends AbstractTestITCase {
     final Customer customer2 = container.getCustomer().newCustomer();
 
     final EntityInvocationHandler source1 =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer1);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer1);
     final EntityInvocationHandler source2 =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer2);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer2);
 
     assertTrue(containerFactory.getContext().entityContext().isAttached(source1));
     assertTrue(containerFactory.getContext().entityContext().isAttached(source2));
@@ -86,11 +82,11 @@ public class ContextTestITCase extends AbstractTestITCase {
     final Customer customer3 = container.getCustomer().get(-10);
 
     final EntityInvocationHandler source1 =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer1);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer1);
     final EntityInvocationHandler source2 =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer2);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer2);
     final EntityInvocationHandler source3 =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer3);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer3);
 
     assertFalse(containerFactory.getContext().entityContext().isAttached(source1));
     assertFalse(containerFactory.getContext().entityContext().isAttached(source2));
@@ -134,9 +130,9 @@ public class ContextTestITCase extends AbstractTestITCase {
     assertNotNull(customer.getInfo());
 
     final EntityInvocationHandler source =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
     final EntityInvocationHandler target =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
 
     assertTrue(containerFactory.getContext().entityContext().isAttached(source));
     assertEquals(AttachedEntityStatus.NEW, containerFactory.getContext().entityContext().getStatus(source));
@@ -153,7 +149,8 @@ public class ContextTestITCase extends AbstractTestITCase {
 
   @Test
   public void linkSourceExisting() {
-    final Customer customer = container.getCustomer().get(-10);;
+    final Customer customer = container.getCustomer().get(-10);
+    ;
     final CustomerInfo customerInfo = container.getCustomerInfo().newCustomerInfo();
 
     customer.setInfo(customerInfo);
@@ -161,9 +158,9 @@ public class ContextTestITCase extends AbstractTestITCase {
     assertNotNull(customer.getInfo());
 
     final EntityInvocationHandler source =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
     final EntityInvocationHandler target =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
 
     assertTrue(containerFactory.getContext().entityContext().isAttached(source));
     assertEquals(AttachedEntityStatus.CHANGED, containerFactory.getContext().entityContext().getStatus(source));
@@ -188,9 +185,9 @@ public class ContextTestITCase extends AbstractTestITCase {
     assertNotNull(customer.getInfo());
 
     final EntityInvocationHandler source =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customer);
     final EntityInvocationHandler target =
-            (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
+        (EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo);
 
     assertTrue(containerFactory.getContext().entityContext().isAttached(source));
     assertEquals(AttachedEntityStatus.CHANGED, containerFactory.getContext().entityContext().getStatus(source));
@@ -238,7 +235,7 @@ public class ContextTestITCase extends AbstractTestITCase {
 
     for (Order order : toBeLinked) {
       assertFalse(containerFactory.getContext().entityContext().
-              isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(order)));
+          isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(order)));
     }
   }
 
@@ -253,7 +250,7 @@ public class ContextTestITCase extends AbstractTestITCase {
     cd.setAlternativeNames(Arrays.asList("alternative1", "alternative2"));
 
     final ContactDetails bcd = customer.factory().newBackupContactInfo();
-    customer.setBackupContactInfo(Collections.<ContactDetails>singletonList(bcd));
+    customer.setBackupContactInfo(Collections.<ContactDetails> singletonList(bcd));
 
     bcd.setAlternativeNames(Arrays.asList("alternative3", "alternative4"));
 
@@ -377,35 +374,35 @@ public class ContextTestITCase extends AbstractTestITCase {
 
     final ContactDetails cd = customer.factory().newPrimaryContactInfo();
     cd.setAlternativeNames(Arrays.asList("alternative1", "alternative2"));
-    cd.setEmailBag(Collections.<String>singleton("myemail@mydomain.org"));
-    cd.setMobilePhoneBag(Collections.<Phone>emptySet());
+    cd.setEmailBag(Collections.<String> singleton("myemail@mydomain.org"));
+    cd.setMobilePhoneBag(Collections.<Phone> emptySet());
 
     final ContactDetails bcd = customer.factory().newBackupContactInfo();
     bcd.setAlternativeNames(Arrays.asList("alternative3", "alternative4"));
-    bcd.setEmailBag(Collections.<String>emptySet());
-    bcd.setMobilePhoneBag(Collections.<Phone>emptySet());
+    bcd.setEmailBag(Collections.<String> emptySet());
+    bcd.setMobilePhoneBag(Collections.<Phone> emptySet());
 
     customer.setPrimaryContactInfo(cd);
-    customer.setBackupContactInfo(Collections.<ContactDetails>singletonList(bcd));
+    customer.setBackupContactInfo(Collections.<ContactDetails> singletonList(bcd));
 
     assertTrue(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo)));
     assertTrue(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
     for (Order linked : toBeLinked) {
       assertTrue(containerFactory.getContext().entityContext().
-              isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
+          isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
     }
 
     container.flush();
 
     assertFalse(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customerInfo)));
     assertFalse(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
     for (Order linked : toBeLinked) {
       assertFalse(containerFactory.getContext().entityContext().
-              isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
+          isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
     }
 
     assertEquals("some new info ...", container.getCustomerInfo().get(16).getInformation());
@@ -414,25 +411,25 @@ public class ContextTestITCase extends AbstractTestITCase {
     container.getCustomer().delete(customer.getCustomerId());
 
     assertTrue(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
     for (Order linked : toBeLinked) {
       assertTrue(containerFactory.getContext().entityContext().
-              isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
+          isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
     }
 
     container.flush();
 
     assertFalse(containerFactory.getContext().entityContext().
-            isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
+        isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(customer)));
     for (Order linked : toBeLinked) {
       assertFalse(containerFactory.getContext().entityContext().
-              isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
+          isAttached((EntityInvocationHandler) Proxy.getInvocationHandler(linked)));
     }
   }
 
   private void checkUnlink(
-          final String sourceName,
-          final EntityInvocationHandler source) {
+      final String sourceName,
+      final EntityInvocationHandler source) {
 
     boolean found = false;
     for (Map.Entry<NavigationProperty, Object> property : source.getLinkChanges().entrySet()) {
@@ -444,10 +441,10 @@ public class ContextTestITCase extends AbstractTestITCase {
   }
 
   private void checkLink(
-          final String sourceName,
-          final EntityInvocationHandler source,
-          final EntityInvocationHandler target,
-          final boolean isCollection) {
+      final String sourceName,
+      final EntityInvocationHandler source,
+      final EntityInvocationHandler target,
+      final boolean isCollection) {
 
     boolean found = false;
     for (Map.Entry<NavigationProperty, Object> property : source.getLinkChanges().entrySet()) {
@@ -461,7 +458,7 @@ public class ContextTestITCase extends AbstractTestITCase {
           }
         } else {
           found = target.equals(
-                  (EntityInvocationHandler) Proxy.getInvocationHandler(property.getValue()));
+              (EntityInvocationHandler) Proxy.getInvocationHandler(property.getValue()));
         }
       }
     }
@@ -469,11 +466,11 @@ public class ContextTestITCase extends AbstractTestITCase {
   }
 
   private void checkUnidirectional(
-          final String sourceName,
-          final EntityInvocationHandler source,
-          final String targetName,
-          final EntityInvocationHandler target,
-          final boolean isCollection) {
+      final String sourceName,
+      final EntityInvocationHandler source,
+      final String targetName,
+      final EntityInvocationHandler target,
+      final boolean isCollection) {
 
     checkLink(sourceName, source, target, isCollection);
     checkUnlink(targetName, target);

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityCreateTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityCreateTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityCreateTestITCase.java
index 75e583d..766db4f 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityCreateTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityCreateTestITCase.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.
  */
@@ -23,18 +23,14 @@ import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertNull;
 import static org.junit.Assert.assertTrue;
 
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Customer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Employee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Message;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.MessageKey;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Order;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.OrderCollection;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Message;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.MessageKey;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderCollection;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 /**

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityRetrieveTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityRetrieveTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityRetrieveTestITCase.java
index 0ea8ad5..2c95dcf 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityRetrieveTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityRetrieveTestITCase.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.
  */
@@ -27,54 +27,36 @@ import static org.junit.Assert.fail;
 import java.lang.reflect.Proxy;
 import java.util.Calendar;
 import java.util.Collection;
+
 import org.apache.commons.lang3.StringUtils;
 import org.apache.olingo.commons.api.edm.geo.Geospatial;
 import org.apache.olingo.commons.api.edm.geo.Geospatial.Type;
 import org.apache.olingo.commons.api.edm.geo.MultiLineString;
 import org.apache.olingo.commons.api.edm.geo.Point;
 import org.apache.olingo.ext.proxy.commons.EntityInvocationHandler;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        DefaultContainer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.AllSpatialTypes;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.ComputerDetail;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.ConcurrencyInfo;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.ContactDetails;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Contractor;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.ContractorCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.CustomerInfo;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Message;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.MessageKey;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Order;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.OrderCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Product;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.SpecialEmployee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.SpecialEmployeeCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Customer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Employee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.EmployeeCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Person;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.PersonCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Phone;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.DefaultContainer;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialTypes;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetail;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ConcurrencyInfo;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ContactDetails;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Contractor;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ContractorCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfo;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Message;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.MessageKey;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Person;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.PersonCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Phone;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 /**
@@ -114,7 +96,7 @@ public class EntityRetrieveTestITCase extends AbstractTestITCase {
     }
 
     final SpecialEmployeeCollection specialEmployees =
-            getContainer().getPerson().getAll(SpecialEmployeeCollection.class);
+        getContainer().getPerson().getAll(SpecialEmployeeCollection.class);
     assertNotNull(specialEmployees);
     assertFalse(specialEmployees.isEmpty());
     for (SpecialEmployee employee : specialEmployees) {
@@ -189,9 +171,8 @@ public class EntityRetrieveTestITCase extends AbstractTestITCase {
     assertEquals(-10, computerDetail.getComputerDetailId(), 0);
 
     try {
-      assertNotNull(
-              computerDetail.operations().getClass().getMethod(
-              "resetComputerDetailsSpecifications", Collection.class, Calendar.class));
+      assertNotNull(computerDetail.operations().getClass().getMethod(
+          "resetComputerDetailsSpecifications", Collection.class, Calendar.class));
     } catch (Exception e) {
       fail();
     }
@@ -212,7 +193,7 @@ public class EntityRetrieveTestITCase extends AbstractTestITCase {
   public void checkForETag() {
     Product product = getContainer().getProduct().get(-10);
     assertTrue(StringUtils.isNotBlank(
-            ((EntityInvocationHandler) Proxy.getInvocationHandler(product)).getETag()));
+        ((EntityInvocationHandler) Proxy.getInvocationHandler(product)).getETag()));
   }
 
   @Test
@@ -221,14 +202,13 @@ public class EntityRetrieveTestITCase extends AbstractTestITCase {
     boolean found = false;
 
     assertTrue(customer.getPrimaryContactInfo().getEmailBag().contains("psgdkmxamznjulzbsohqjytbxhnojbufe"));
-    
+
     final Collection<ContactDetails> backupContactInfo = customer.getBackupContactInfo();
     assertEquals(9, backupContactInfo.size());
-    
 
     for (ContactDetails contact : backupContactInfo) {
       if (contact.getContactAlias() != null && contact.getContactAlias().getAlternativeNames() != null && contact.
-              getContactAlias().getAlternativeNames().contains("vxiefursgkqzptijhincpdm")) {
+          getContactAlias().getAlternativeNames().contains("vxiefursgkqzptijhincpdm")) {
         found = true;
       }
     }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntitySetTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntitySetTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntitySetTestITCase.java
index 29049b1..a86f7ba 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntitySetTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntitySetTestITCase.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.
  */
@@ -24,6 +24,7 @@ import static org.junit.Assert.assertTrue;
 
 import java.io.IOException;
 import java.util.Iterator;
+
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Computer;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityUpdateTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityUpdateTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityUpdateTestITCase.java
index 9450d29..464204c 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityUpdateTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/EntityUpdateTestITCase.java
@@ -1,44 +1,40 @@
 /*
  * 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.proxy.v3;
 
 import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertTrue;
 
 import java.lang.reflect.Proxy;
+
 import org.apache.commons.lang3.StringUtils;
 import org.apache.olingo.ext.proxy.commons.EntityInvocationHandler;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.ConcurrencyInfo;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Customer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Message;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.MessageKey;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Order;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.OrderCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.
-        types.Product;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ConcurrencyInfo;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Message;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.MessageKey;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 /**
@@ -46,82 +42,82 @@ import org.junit.Test;
  */
 public class EntityUpdateTestITCase extends AbstractTestITCase {
 
-    @Test
-    public void update() {
-        Order order = container.getOrder().get(-9);
+  @Test
+  public void update() {
+    Order order = container.getOrder().get(-9);
 
-        final ConcurrencyInfo ci = order.getConcurrency();
-        ci.setToken("XXX");
+    final ConcurrencyInfo ci = order.getConcurrency();
+    ci.setToken("XXX");
 
-        container.flush();
+    container.flush();
 
-        order = container.getOrder().get(-9);
-        assertEquals("XXX", order.getConcurrency().getToken());
-    }
+    order = container.getOrder().get(-9);
+    assertEquals("XXX", order.getConcurrency().getToken());
+  }
 
-    @Test
-    public void multiKey() {
-        final MessageKey key = new MessageKey();
-        key.setFromUsername("1");
-        key.setMessageId(-10);
+  @Test
+  public void multiKey() {
+    final MessageKey key = new MessageKey();
+    key.setFromUsername("1");
+    key.setMessageId(-10);
 
-        Message message = container.getMessage().get(key);
-        assertNotNull(message);
+    Message message = container.getMessage().get(key);
+    assertNotNull(message);
 
-        message.setBody("XXX");
+    message.setBody("XXX");
 
-        container.flush();
+    container.flush();
 
-        message = container.getMessage().get(key);
-        assertNotNull(message);
-        assertEquals("XXX", message.getBody());
-    }
+    message = container.getMessage().get(key);
+    assertNotNull(message);
+    assertEquals("XXX", message.getBody());
+  }
 
-    @Test
-    public void patchLink() {
-        Order order = container.getOrder().newOrder();
-        order.setOrderId(400);
-        order.setCustomerId(-9);
+  @Test
+  public void patchLink() {
+    Order order = container.getOrder().newOrder();
+    order.setOrderId(400);
+    order.setCustomerId(-9);
 
-        OrderCollection orders = container.getOrder().newOrderCollection();
-        orders.add(order);
+    OrderCollection orders = container.getOrder().newOrderCollection();
+    orders.add(order);
 
-        Customer customer = container.getCustomer().get(-9);
-        customer.setOrders(orders);
-        order.setCustomer(customer);
+    Customer customer = container.getCustomer().get(-9);
+    customer.setOrders(orders);
+    order.setCustomer(customer);
 
-        container.flush();
+    container.flush();
 
-        order = container.getOrder().get(400);
-        assertEquals(400, order.getOrderId().intValue());
-        assertEquals(-9, order.getCustomerId().intValue());
+    order = container.getOrder().get(400);
+    assertEquals(400, order.getOrderId().intValue());
+    assertEquals(-9, order.getCustomerId().intValue());
 
-        customer = container.getCustomer().get(-9);
+    customer = container.getCustomer().get(-9);
 
-        assertEquals(2, customer.getOrders().size());
+    assertEquals(2, customer.getOrders().size());
 
-        int count = 0;
-        for (Order inside : customer.getOrders()) {
-            if (inside.getOrderId() == 400) {
-                count++;
-            }
-        }
-        assertEquals(1, count);
-        assertEquals(-9, order.getCustomer().getCustomerId(), 0);
+    int count = 0;
+    for (Order inside : customer.getOrders()) {
+      if (inside.getOrderId() == 400) {
+        count++;
+      }
     }
+    assertEquals(1, count);
+    assertEquals(-9, order.getCustomer().getCustomerId(), 0);
+  }
 
-    @Test
-    public void concurrentModification() {
-        Product product = container.getProduct().get(-10);
-        final String etag = ((EntityInvocationHandler) Proxy.getInvocationHandler(product)).getETag();
-        assertTrue(StringUtils.isNotBlank(etag));
+  @Test
+  public void concurrentModification() {
+    Product product = container.getProduct().get(-10);
+    final String etag = ((EntityInvocationHandler) Proxy.getInvocationHandler(product)).getETag();
+    assertTrue(StringUtils.isNotBlank(etag));
 
-        final String baseConcurrency = String.valueOf(System.currentTimeMillis());
-        product.setBaseConcurrency(baseConcurrency);
+    final String baseConcurrency = String.valueOf(System.currentTimeMillis());
+    product.setBaseConcurrency(baseConcurrency);
 
-        container.flush();
+    container.flush();
 
-        product = container.getProduct().get(-10);
-        assertEquals(baseConcurrency, product.getBaseConcurrency());
-    }
+    product = container.getProduct().get(-10);
+    assertEquals(baseConcurrency, product.getBaseConcurrency());
+  }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/FilterTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/FilterTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/FilterTestITCase.java
index 2ceb3c7..d015141 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/FilterTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/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.
  */
@@ -27,19 +27,18 @@ import static org.junit.Assert.fail;
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.List;
-import org.apache.olingo.ext.proxy.api.NonUniqueResultException;
+
 import org.apache.olingo.ext.proxy.api.Filter;
+import org.apache.olingo.ext.proxy.api.NonUniqueResultException;
 import org.apache.olingo.ext.proxy.api.Sort;
+//CHECKSTYLE:OFF (Maven checkstyle)
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        CarCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.CarCollection;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        EmployeeCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        SpecialEmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 public class FilterTestITCase extends AbstractTestITCase {
@@ -47,7 +46,7 @@ public class FilterTestITCase extends AbstractTestITCase {
   @Test
   public void filterOrderby() {
     final Filter<Car, CarCollection> filter = container.getCar().createFilter().
-            setFilter(containerFactory.getClient().getFilterFactory().lt("VIN", 16));
+        setFilter(containerFactory.getClient().getFilterFactory().lt("VIN", 16));
     CarCollection result = filter.getResult();
     assertNotNull(result);
 
@@ -81,7 +80,7 @@ public class FilterTestITCase extends AbstractTestITCase {
   @Test
   public void single() {
     final Filter<Car, CarCollection> filter = container.getCar().createFilter().
-            setFilter(containerFactory.getClient().getFilterFactory().lt("VIN", 16));
+        setFilter(containerFactory.getClient().getFilterFactory().lt("VIN", 16));
 
     Exception exception = null;
     try {
@@ -100,14 +99,14 @@ public class FilterTestITCase extends AbstractTestITCase {
   @Test
   public void derived() {
     final Filter<Employee, EmployeeCollection> filterEmployee =
-            container.getPerson().createFilter(EmployeeCollection.class);
+        container.getPerson().createFilter(EmployeeCollection.class);
     assertFalse(filterEmployee.getResult().isEmpty());
 
     final Filter<SpecialEmployee, SpecialEmployeeCollection> filterSpecialEmployee =
-            container.getPerson().createFilter(SpecialEmployeeCollection.class);
+        container.getPerson().createFilter(SpecialEmployeeCollection.class);
     assertFalse(filterSpecialEmployee.getResult().isEmpty());
 
     assertTrue(container.getPerson().getAll().size()
-            > filterEmployee.getResult().size() + filterSpecialEmployee.getResult().size());
+    > filterEmployee.getResult().size() + filterSpecialEmployee.getResult().size());
   }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/InvokeTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/InvokeTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/InvokeTestITCase.java
index a91fb68..e8c5946 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/InvokeTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/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.
  */
@@ -33,20 +33,18 @@ import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
+
 import org.apache.commons.lang3.StringUtils;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        ComputerDetail;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        ContactDetails;
+//CHECKSTYLE:OFF (Maven checkstyle)
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetail;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.ContactDetails;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        CustomerCollection;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        Dimensions;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Dimensions;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
-import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.
-        EmployeeCollection;
+import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
+//CHECKSTYLE:ON (Maven checkstyle)
 import org.junit.Test;
 
 public class InvokeTestITCase extends AbstractTestITCase {
@@ -212,7 +210,7 @@ public class InvokeTestITCase extends AbstractTestITCase {
     try {
       // 1. invoke action bound to the computer detail just created
       computerDetail.operations().resetComputerDetailsSpecifications(
-              Collections.singleton("Second spec"), Calendar.getInstance());
+          Collections.singleton("Second spec"), Calendar.getInstance());
 
       // 2. check that invoked action has effectively run
       computerDetail = container.getComputerDetail().get(id);

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/MediaEntityTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/MediaEntityTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/MediaEntityTestITCase.java
index c20b056..d5af7fb 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/MediaEntityTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/MediaEntityTestITCase.java
@@ -1,31 +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
- *
- *   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.proxy.v3;
 
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotNull;
+import static org.junit.Assert.assertNull;
 import static org.junit.Assert.assertTrue;
 
 import java.io.ByteArrayInputStream;
 import java.io.IOException;
 import java.io.InputStream;
+
 import org.apache.commons.io.IOUtils;
 import org.apache.olingo.fit.proxy.v3.staticservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/OpenTypeTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/OpenTypeTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/OpenTypeTestITCase.java
index 3ee02ba..adda881 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/OpenTypeTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/OpenTypeTestITCase.java
@@ -1,33 +1,34 @@
 /*
  * 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.proxy.v3;
 
-import static org.junit.Assert.assertTrue;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertNull;
+import static org.junit.Assert.assertTrue;
 
 import java.math.BigDecimal;
 import java.text.ParseException;
 import java.text.SimpleDateFormat;
 import java.util.Calendar;
 import java.util.UUID;
+
 import org.apache.olingo.client.api.v3.EdmEnabledODataClient;
 import org.apache.olingo.commons.api.format.ContentType;
 import org.apache.olingo.ext.proxy.EntityContainerFactory;
@@ -52,7 +53,7 @@ public class OpenTypeTestITCase extends AbstractTestITCase {
   public static void initContainer() {
     otcontainerFactory = EntityContainerFactory.getV3(testOpenTypeServiceRootURL);
     otcontainerFactory.getClient().getConfiguration().
-            setDefaultBatchAcceptFormat(ContentType.APPLICATION_OCTET_STREAM);
+        setDefaultBatchAcceptFormat(ContentType.APPLICATION_OCTET_STREAM);
     otcontainer = otcontainerFactory.getEntityContainer(DefaultContainer.class);
     assertNotNull(otcontainer);
   }
@@ -60,11 +61,11 @@ public class OpenTypeTestITCase extends AbstractTestITCase {
   @Test
   public void checkOpenTypeEntityTypesExist() {
     assertTrue(otcontainer.getRow().newRow().getClass().getInterfaces()[0].
-            getAnnotation(EntityType.class).openType());
+        getAnnotation(EntityType.class).openType());
     assertTrue(otcontainer.getRowIndex().newRowIndex().getClass().getInterfaces()[0].
-            getAnnotation(EntityType.class).openType());
+        getAnnotation(EntityType.class).openType());
     assertTrue(otcontainer.getRow().newIndexedRow().getClass().getInterfaces()[0].
-            getAnnotation(EntityType.class).openType());
+        getAnnotation(EntityType.class).openType());
     otcontainerFactory.getContext().detachAll();
   }
 

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PrimitiveKeysTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PrimitiveKeysTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PrimitiveKeysTestITCase.java
index f0a4912..b9d85c9 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PrimitiveKeysTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PrimitiveKeysTestITCase.java
@@ -1,28 +1,29 @@
 /*
  * 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.proxy.v3;
 
-import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotNull;
 
 import java.math.BigDecimal;
 import java.util.UUID;
+
 import org.apache.olingo.client.api.v3.EdmEnabledODataClient;
 import org.apache.olingo.commons.api.format.ContentType;
 import org.apache.olingo.ext.proxy.EntityContainerFactory;
@@ -46,10 +47,10 @@ public class PrimitiveKeysTestITCase extends AbstractTestITCase {
 
   @Test
   public void readPrimitiveKeys() {
-    final EntityContainerFactory<EdmEnabledODataClient> testContainerFactory = 
-            EntityContainerFactory.getV3(testPrimitiveKeysServiceRootURL);
+    final EntityContainerFactory<EdmEnabledODataClient> testContainerFactory =
+        EntityContainerFactory.getV3(testPrimitiveKeysServiceRootURL);
     testContainerFactory.getClient().getConfiguration().
-            setDefaultBatchAcceptFormat(ContentType.APPLICATION_OCTET_STREAM);
+        setDefaultBatchAcceptFormat(ContentType.APPLICATION_OCTET_STREAM);
     final TestContext testContainer = testContainerFactory.getEntityContainer(TestContext.class);
     assertNotNull(testContainer);
 
@@ -62,7 +63,7 @@ public class PrimitiveKeysTestITCase extends AbstractTestITCase {
     assertEquals(Short.valueOf("255"), edmByteSet.getId());
 
     final EdmDecimal edmDecimalSet =
-            testContainer.getEdmDecimalSet().get(new BigDecimal("79228162514264337593543950335"));
+        testContainer.getEdmDecimalSet().get(new BigDecimal("79228162514264337593543950335"));
     assertNotNull(edmDecimalSet);
     assertEquals(new BigDecimal("79228162514264337593543950335"), edmDecimalSet.getId());
 
@@ -75,7 +76,7 @@ public class PrimitiveKeysTestITCase extends AbstractTestITCase {
     assertEquals(3.4028235E+38F, edmSingleSet.getId(), 0);
 
     final EdmGuid edmGuidSet =
-            testContainer.getEdmGuidSet().get(UUID.fromString("00000000-0000-0000-0000-000000000000"));
+        testContainer.getEdmGuidSet().get(UUID.fromString("00000000-0000-0000-0000-000000000000"));
     assertNotNull(edmGuidSet);
     assertEquals(UUID.fromString("00000000-0000-0000-0000-000000000000"), edmGuidSet.getId());
 

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PropertyTestITCase.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PropertyTestITCase.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PropertyTestITCase.java
index e0aec63..9d94d2c 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/PropertyTestITCase.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/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.
  */
@@ -30,26 +30,26 @@ import org.junit.Test;
  */
 public class PropertyTestITCase extends AbstractTestITCase {
 
-    @Test
-    public void nullNullableProperty() {
-        Order order = container.getOrder().get(-8);
-        order.setCustomerId(null);
-        container.flush();
+  @Test
+  public void nullNullableProperty() {
+    Order order = container.getOrder().get(-8);
+    order.setCustomerId(null);
+    container.flush();
 
-        assertNull(container.getOrder().get(-8).getCustomerId());
-    }
+    assertNull(container.getOrder().get(-8).getCustomerId());
+  }
 
-    @Test
-    public void nullNonNullableProperty() {
-        Driver driver = container.getDriver().get("2");
-        driver.setBirthDate(null);
+  @Test
+  public void nullNonNullableProperty() {
+    Driver driver = container.getDriver().get("2");
+    driver.setBirthDate(null);
 
-        try {
-            container.flush();
-            fail();
-        } catch (IllegalStateException e) {
-            // ignore and detach all
-            containerFactory.getContext().detachAll();
-        }
+    try {
+      container.flush();
+      fail();
+    } catch (IllegalStateException e) {
+      // ignore and detach all
+      containerFactory.getContext().detachAll();
     }
+  }
 }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/2ab4b2fd/fit/src/test/java/org/apache/olingo/fit/proxy/v3/actionoverloading/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
----------------------------------------------------------------------
diff --git a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/actionoverloading/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/actionoverloading/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
index 8965f17..8c34849 100644
--- a/fit/src/test/java/org/apache/olingo/fit/proxy/v3/actionoverloading/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
+++ b/fit/src/test/java/org/apache/olingo/fit/proxy/v3/actionoverloading/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.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,35 +20,21 @@
 package org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice;
 
 import org.apache.olingo.ext.proxy.api.AbstractEntitySet;
-import org.apache.olingo.ext.proxy.api.annotations.EntitySet;
-import org.apache.olingo.ext.proxy.api.annotations.CompoundKey;
-import org.apache.olingo.ext.proxy.api.annotations.CompoundKeyElement;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.*;
-import org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.*;
 
-import org.apache.olingo.commons.api.edm.geo.Geospatial;
-import org.apache.olingo.commons.api.edm.geo.GeospatialCollection;
-import org.apache.olingo.commons.api.edm.geo.LineString;
-import org.apache.olingo.commons.api.edm.geo.MultiLineString;
-import org.apache.olingo.commons.api.edm.geo.MultiPoint;
-import org.apache.olingo.commons.api.edm.geo.MultiPolygon;
-import org.apache.olingo.commons.api.edm.geo.Point;
-import org.apache.olingo.commons.api.edm.geo.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-import java.util.Calendar;
-import javax.xml.datatype.Duration;
+@org.apache.olingo.ext.proxy.api.annotations.EntitySet(name = "AllGeoCollectionTypesSet")
+public interface AllGeoCollectionTypesSet
+    extends
+    AbstractEntitySet<org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes, java.lang.Integer, org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection> {
 
+      org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes
+      newAllSpatialCollectionTypes();
 
-@org.apache.olingo.ext.proxy.api.annotations.EntitySet(name = "AllGeoCollectionTypesSet")
-public interface AllGeoCollectionTypesSet 
-  extends AbstractEntitySet<org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes, java.lang.Integer, org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection> {
+      org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection
+      newAllSpatialCollectionTypesCollection();
+
+      org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_Simple
+      newAllSpatialCollectionTypes_Simple();
 
-    org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes newAllSpatialCollectionTypes();
-    org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection newAllSpatialCollectionTypesCollection();
-    org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_Simple newAllSpatialCollectionTypes_Simple();
-    org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_SimpleCollection newAllSpatialCollectionTypes_SimpleCollection();
+      org.apache.olingo.fit.proxy.v3.actionoverloading.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_SimpleCollection
+      newAllSpatialCollectionTypes_SimpleCollection();
 }