You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@olingo.apache.org by il...@apache.org on 2014/05/22 13:43:20 UTC

[12/51] [abbrv] [partial] Removing /ODataJClient: merge complete

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntitySetTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntitySetTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntitySetTestITCase.java
deleted file mode 100644
index 94ba96a..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntitySetTestITCase.java
+++ /dev/null
@@ -1,99 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static com.msopentech.odatajclient.proxy.AbstractTest.container;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Computer;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
-import java.io.IOException;
-import java.util.Iterator;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check basic feed operations.
- */
-public class EntitySetTestITCase extends AbstractTest {
-
-    @Test
-    public void count() {
-        assertNotNull(container.getMessage());
-        assertTrue(10 <= container.getMessage().count());
-
-        assertTrue(container.getCustomer().count() > 0);
-    }
-
-    @Test
-    public void getAll() {
-        int count = 0;
-        for (Customer customer : container.getCustomer().getAll()) {
-            assertNotNull(customer);
-            count++;
-        }
-        assertTrue(count >= 10);
-    }
-
-    @Test
-    public void readEntitySetWithNextLink() {
-        int count = 0;
-        for (Customer customer : container.getCustomer().getAll()) {
-            assertNotNull(customer);
-            count++;
-        }
-        assertTrue(count >= 10);
-
-        int iterating = 0;
-        for (Customer customer : container.getCustomer()) {
-            assertNotNull(customer);
-            iterating++;
-        }
-        assertEquals(count, iterating);
-    }
-
-    @Test
-    public void readODataEntitySet() throws IOException {
-        assertTrue(container.getCar().count() >= 10);
-
-        final Iterable<Car> car = container.getCar().getAll();
-        assertNotNull(car);
-
-        final Iterator<Car> itor = car.iterator();
-
-        int count = 0;
-        while (itor.hasNext()) {
-            assertNotNull(itor.next());
-            count++;
-        }
-        assertTrue(count >= 10);
-    }
-
-    @Test
-    public void readEntitySetIterator() {
-        int count = 0;
-        for (Computer computer : container.getComputer()) {
-            assertNotNull(computer);
-            count++;
-        }
-        assertTrue(count >= 10);
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntityUpdateTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntityUpdateTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntityUpdateTestITCase.java
deleted file mode 100644
index d55cfb7..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/EntityUpdateTestITCase.java
+++ /dev/null
@@ -1,122 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static org.junit.Assert.assertNotEquals;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-import static org.junit.Assert.assertNotNull;
-
-import com.msopentech.odatajclient.proxy.api.impl.EntityTypeInvocationHandler;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Message;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.ConcurrencyInfo;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.MessageKey;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderCollection;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
-import java.lang.reflect.Proxy;
-import org.apache.commons.lang3.StringUtils;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check entity update operations.
- */
-public class EntityUpdateTestITCase extends AbstractTest {
-
-    @Test
-    public void update() {
-        Order order = container.getOrder().get(-9);
-
-        final ConcurrencyInfo ci = order.getConcurrency();
-        ci.setToken("XXX");
-
-        container.flush();
-
-        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);
-
-        Message message = container.getMessage().get(key);
-        assertNotNull(message);
-
-        message.setBody("XXX");
-
-        container.flush();
-
-        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);
-
-        OrderCollection orders = container.getOrder().newOrderCollection();
-        orders.add(order);
-
-        Customer customer = container.getCustomer().get(-9);
-        customer.setOrders(orders);
-        order.setCustomer(customer);
-
-        container.flush();
-
-        order = container.getOrder().get(400);
-        assertEquals(400, order.getOrderId().intValue());
-        assertEquals(-9, order.getCustomerId().intValue());
-
-        customer = container.getCustomer().get(-9);
-
-        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().intValue());
-    }
-
-    @Test
-    public void concurrentModification() {
-        Product product = container.getProduct().get(-10);
-        final String etag = ((EntityTypeInvocationHandler) Proxy.getInvocationHandler(product)).getETag();
-        assertTrue(StringUtils.isNotBlank(etag));
-
-        final String baseConcurrency = String.valueOf(System.currentTimeMillis());
-        product.setBaseConcurrency(baseConcurrency);
-
-        container.flush();
-
-        product = container.getProduct().get(-10);
-        assertEquals(baseConcurrency, product.getBaseConcurrency());
-        assertNotEquals(etag, ((EntityTypeInvocationHandler) Proxy.getInvocationHandler(product)).getETag());
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/InvokeTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/InvokeTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/InvokeTestITCase.java
deleted file mode 100644
index aec8104..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/InvokeTestITCase.java
+++ /dev/null
@@ -1,218 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertFalse;
-import static org.junit.Assert.assertNotEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.EdmSimpleType;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetail;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.ContactDetails;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerCollection;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Dimensions;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Product;
-import java.math.BigDecimal;
-import java.sql.Timestamp;
-import java.util.Collection;
-import java.util.Collections;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.Map;
-import java.util.Set;
-import org.apache.commons.lang3.StringUtils;
-import org.junit.Test;
-
-public class InvokeTestITCase extends AbstractTest {
-
-    @Test
-    public void getWithNoParams() {
-        // 1. primitive result
-        final String string = container.getPrimitiveString();
-        assertEquals("Foo", string);
-
-        // 2. complex collection result
-        final Collection<ContactDetails> details = container.entityProjectionReturnsCollectionOfComplexTypes();
-        assertFalse(details.isEmpty());
-        for (ContactDetails detail : details) {
-            assertNotNull(detail);
-        }
-        assertNotNull(details.iterator().next());
-    }
-
-    @Test
-    public void getWithParam() {
-        // 1. primitive result
-        assertEquals(155, container.getArgumentPlusOne(154).intValue());
-
-        // 2. entity collection result
-        final CustomerCollection customers = container.getSpecificCustomer(StringUtils.EMPTY);
-        assertNotNull(customers);
-        assertFalse(customers.isEmpty());
-        final Set<Integer> customerIds = new HashSet<Integer>(customers.size());
-        for (Customer customer : customers) {
-            assertNotNull(customer);
-            customerIds.add(customer.getCustomerId());
-        }
-        assertTrue(customerIds.contains(-8));
-    }
-
-    @Test
-    public void entityBoundPost() {
-        // 0. create an employee
-        final Integer id = 101;
-
-        Employee employee = container.getPerson().newEmployee();
-        employee.setPersonId(id);
-        employee.setName("sample employee from proxy");
-        employee.setManagersPersonId(-9918);
-        employee.setSalary(2147483647);
-        employee.setTitle("CEO");
-
-        container.flush();
-
-        employee = container.getPerson().get(id, Employee.class);
-        assertNotNull(employee);
-        assertEquals(id, employee.getPersonId());
-
-        try {
-            // 1. invoke action bound to the employee just created
-            employee.sack();
-
-            // 2. check that invoked action has effectively run
-            employee = container.getPerson().get(id, Employee.class);
-            assertEquals(0, employee.getSalary().intValue());
-            assertTrue(employee.getTitle().endsWith("[Sacked]"));
-        } finally {
-            // 3. remove the test employee
-            container.getPerson().delete(employee.getPersonId());
-            container.flush();
-        }
-    }
-
-    @Test
-    public void entityCollectionBoundPostWithParam() {
-        EmployeeCollection employees = container.getPerson().getAll(EmployeeCollection.class);
-        assertFalse(employees.isEmpty());
-        final Map<Integer, Integer> preSalaries = new HashMap<Integer, Integer>(employees.size());
-        for (Employee employee : employees) {
-            preSalaries.put(employee.getPersonId(), employee.getSalary());
-        }
-        assertFalse(preSalaries.isEmpty());
-
-        employees.increaseSalaries(1);
-
-        employees = container.getPerson().getAll(EmployeeCollection.class);
-        assertFalse(employees.isEmpty());
-        for (Employee employee : employees) {
-            assertTrue(preSalaries.get(employee.getPersonId()) < employee.getSalary());
-        }
-    }
-
-    @Test
-    public void changeProductDimensions() {
-        // 0. create a product
-        final Integer id = 101;
-
-        Product product = container.getProduct().newProduct();
-        product.setProductId(id);
-        product.setDescription("New product");
-
-        final Dimensions origDimensions = new Dimensions();
-        origDimensions.setDepth(BigDecimal.ZERO);
-        origDimensions.setHeight(BigDecimal.ZERO);
-        origDimensions.setWidth(BigDecimal.ZERO);
-        product.setDimensions(origDimensions);
-
-        container.flush();
-
-        product = container.getProduct().get(id);
-        assertNotNull(product);
-        assertEquals(id, product.getProductId());
-        assertEquals(BigDecimal.ZERO, product.getDimensions().getDepth());
-        assertEquals(BigDecimal.ZERO, product.getDimensions().getHeight());
-        assertEquals(BigDecimal.ZERO, product.getDimensions().getWidth());
-
-        try {
-            // 1. invoke action bound to the product just created
-            final Dimensions newDimensions = new Dimensions();
-            newDimensions.setDepth(BigDecimal.ONE);
-            newDimensions.setHeight(BigDecimal.ONE);
-            newDimensions.setWidth(BigDecimal.ONE);
-
-            product.changeProductDimensions(newDimensions);
-
-            // 2. check that invoked action has effectively run
-            product = container.getProduct().get(id);
-            assertEquals(BigDecimal.ONE, product.getDimensions().getDepth());
-            assertEquals(BigDecimal.ONE, product.getDimensions().getHeight());
-            assertEquals(BigDecimal.ONE, product.getDimensions().getWidth());
-        } finally {
-            // 3. remove the test product
-            container.getProduct().delete(product.getProductId());
-            container.flush();
-        }
-    }
-
-    @Test
-    public void resetComputerDetailsSpecifications() {
-        // 0. create a computer detail
-        final Integer id = 101;
-
-        ComputerDetail computerDetail = container.getComputerDetail().newComputerDetail();
-        computerDetail.setComputerDetailId(id);
-        computerDetail.setSpecificationsBag(Collections.singleton("First spec"));
-
-        container.flush();
-
-        computerDetail = container.getComputerDetail().get(id);
-        assertNotNull(computerDetail);
-        assertEquals(id, computerDetail.getComputerDetailId());
-        assertEquals(1, computerDetail.getSpecificationsBag().size());
-        assertTrue(computerDetail.getSpecificationsBag().contains("First spec"));
-        assertEquals(ODataTimestamp.parse(EdmSimpleType.DateTime, "0001-01-01T00:00:00"),
-                computerDetail.getPurchaseDate());
-
-        try {
-            // 1. invoke action bound to the computer detail just created
-            computerDetail.resetComputerDetailsSpecifications(
-                    Collections.singleton("Second spec"),
-                    ODataTimestamp.getInstance(EdmSimpleType.DateTime, new Timestamp(System.currentTimeMillis())));
-
-            // 2. check that invoked action has effectively run
-            computerDetail = container.getComputerDetail().get(id);
-            assertNotNull(computerDetail);
-            assertEquals(id, computerDetail.getComputerDetailId());
-            assertEquals(1, computerDetail.getSpecificationsBag().size());
-            assertTrue(computerDetail.getSpecificationsBag().contains("Second spec"));
-            assertNotEquals(ODataTimestamp.parse(EdmSimpleType.DateTime, "0001-01-01T00:00:00"),
-                    computerDetail.getPurchaseDate());
-        } finally {
-            // 3. remove the test product
-            container.getComputerDetail().delete(computerDetail.getComputerDetailId());
-            container.flush();
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/MediaEntityTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/MediaEntityTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/MediaEntityTestITCase.java
deleted file mode 100644
index eefcda1..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/MediaEntityTestITCase.java
+++ /dev/null
@@ -1,108 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-
-import com.msopentech.odatajclient.proxy.api.EntityContainerFactory;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
-import java.io.ByteArrayInputStream;
-import java.io.IOException;
-import java.io.InputStream;
-import org.apache.commons.io.IOUtils;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check media entity retrieve operations.
- */
-public class MediaEntityTestITCase extends AbstractTest {
-
-    @Test
-    public void read() throws IOException {
-        final InputStream is = container.getCar().get(12).getStream();
-        assertNotNull(is);
-        IOUtils.closeQuietly(is);
-    }
-
-    @Test
-    public void updateReadStreamedProperty() throws IOException {
-        final String TO_BE_UPDATED = "buffered stream sample (" + System.currentTimeMillis() + ")";
-        final InputStream input = new ByteArrayInputStream(TO_BE_UPDATED.getBytes());
-
-        Car car = container.getCar().get(12);
-        car.setPhoto(input);
-
-        container.flush();
-
-        car = container.getCar().get(12);
-        final InputStream is = car.getPhoto();
-        assertEquals(TO_BE_UPDATED, IOUtils.toString(is));
-        IOUtils.closeQuietly(is);
-    }
-
-    @Test
-    public void update() throws IOException {
-        final Car car = container.getCar().get(14);
-        assertNotNull(car);
-
-        final String TO_BE_UPDATED = "buffered stream sample (" + System.currentTimeMillis() + ")";
-        InputStream input = IOUtils.toInputStream(TO_BE_UPDATED);
-
-        car.setStream(input);
-
-        container.flush();
-
-        input = container.getCar().get(14).getStream();
-        assertEquals(TO_BE_UPDATED, IOUtils.toString(input));
-        IOUtils.closeQuietly(input);
-    }
-
-    @Test
-    public void create() throws IOException {
-        Car car = container.getCar().newCar();
-
-        final String TO_BE_UPDATED = "buffered stream sample (" + System.currentTimeMillis() + ")";
-        InputStream input = IOUtils.toInputStream(TO_BE_UPDATED);
-
-        final String DESC = "DESC - " + System.currentTimeMillis();
-        car.setStream(input);
-        car.setDescription(DESC);
-
-        container.flush();
-
-        int key = car.getVIN();
-        assertTrue(key > 0);
-
-        EntityContainerFactory.getContext().detachAll();
-
-        car = container.getCar().get(key);
-        assertEquals(DESC, car.getDescription());
-        input = car.getStream();
-        assertEquals(TO_BE_UPDATED, IOUtils.toString(input));
-        IOUtils.closeQuietly(input);
-
-        container.getCar().delete(key);
-        container.flush();
-
-        assertNull(container.getCar().get(key));
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/OpenTypeTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/OpenTypeTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/OpenTypeTestITCase.java
deleted file mode 100644
index 8b435a7..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/OpenTypeTestITCase.java
+++ /dev/null
@@ -1,181 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static com.msopentech.odatajclient.proxy.AbstractTest.testOpenTypeServiceRootURL;
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.EdmSimpleType;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import com.msopentech.odatajclient.proxy.api.EntityContainerFactory;
-import com.msopentech.odatajclient.proxy.api.annotations.EntityType;
-import com.msopentech.odatajclient.proxy.opentypeservice.microsoft.test.odata.services.opentypesservice.DefaultContainer;
-import com.msopentech.odatajclient.proxy.opentypeservice.microsoft.test.odata.services.opentypesservice.types.ContactDetails;
-import com.msopentech.odatajclient.proxy.opentypeservice.microsoft.test.odata.services.opentypesservice.types.IndexedRow;
-import com.msopentech.odatajclient.proxy.opentypeservice.microsoft.test.odata.services.opentypesservice.types.Row;
-import com.msopentech.odatajclient.proxy.opentypeservice.microsoft.test.odata.services.opentypesservice.types.RowIndex;
-import java.sql.Timestamp;
-import java.util.ArrayList;
-import java.util.Date;
-import java.util.List;
-import java.util.UUID;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check basic feed operations.
- */
-public class OpenTypeTestITCase extends AbstractTest {
-
-    @Test
-    public void checkOpenTypeEntityTypesExist() {
-        assertTrue(Row.class.getAnnotation(EntityType.class).openType());
-        assertTrue(IndexedRow.class.getAnnotation(EntityType.class).openType());
-        assertTrue(RowIndex.class.getAnnotation(EntityType.class).openType());
-    }
-
-    @Test
-    public void readRow() {
-        final DefaultContainer otcontainer = EntityContainerFactory.getV3Instance(testOpenTypeServiceRootURL).
-                getEntityContainer(DefaultContainer.class);
-
-        Row row = otcontainer.getRow().get(UUID.fromString("71f7d0dc-ede4-45eb-b421-555a2aa1e58f"));
-        Object value = row.getAdditionalProperty("Double");
-        assertEquals(1.2626D, ((Double) value).doubleValue(), 1.0E-100D);
-    }
-
-    @Test
-    public void cud() {
-        final DefaultContainer otcontainer = EntityContainerFactory.getV3Instance(testOpenTypeServiceRootURL).
-                getEntityContainer(DefaultContainer.class);
-
-        Row row = otcontainer.getRow().newRow();
-
-        final UUID guid = UUID.randomUUID();
-        row.setId(guid);
-
-        row.addAdditionalProperty("aString", "string");
-        row.addAdditionalProperty("aBoolean", true);
-        row.addAdditionalProperty("aLong", 15L);
-        row.addAdditionalProperty("aDouble", 1.5D);
-        row.addAdditionalProperty("aByte", Byte.MAX_VALUE);
-        row.addAdditionalProperty("aDate",
-                ODataTimestamp.getInstance(EdmSimpleType.DateTime, new Timestamp(new Date().getTime())));
-
-        final Point point = new Point(Geospatial.Dimension.GEOGRAPHY);
-        point.setX(1.2);
-        point.setY(2.1);
-        row.addAdditionalProperty("aPoint", point);
-
-        final List<Point> points = new ArrayList<Point>();
-        points.add(point);
-        points.add(point);
-        final MultiPoint multipoint = new MultiPoint(Geospatial.Dimension.GEOMETRY, points);
-        row.addAdditionalProperty("aMultiPoint", multipoint);
-
-        final LineString lineString = new LineString(Geospatial.Dimension.GEOMETRY, points);
-        row.addAdditionalProperty("aLineString", lineString);
-
-        final List<LineString> lineStrings = new ArrayList<LineString>();
-        lineStrings.add(lineString);
-        lineStrings.add(lineString);
-        final MultiLineString multiLineString = new MultiLineString(Geospatial.Dimension.GEOGRAPHY, lineStrings);
-        row.addAdditionalProperty("aMultiLineString", multiLineString);
-
-        final Point otherPoint = new Point(Geospatial.Dimension.GEOGRAPHY);
-        otherPoint.setX(3.4);
-        otherPoint.setY(4.3);
-        points.set(1, otherPoint);
-        points.add(otherPoint);
-        points.add(point);
-        final Polygon polygon = new Polygon(Geospatial.Dimension.GEOGRAPHY, points, points);
-        row.addAdditionalProperty("aPolygon", polygon);
-
-        final List<Polygon> polygons = new ArrayList<Polygon>();
-        polygons.add(polygon);
-        polygons.add(polygon);
-        final MultiPolygon multiPolygon = new MultiPolygon(Geospatial.Dimension.GEOGRAPHY, polygons);
-        row.addAdditionalProperty("aMultiPolygon", multiPolygon);
-
-        final List<Geospatial> geospatials = new ArrayList<Geospatial>();
-        geospatials.add(otherPoint);
-        geospatials.add(polygon);
-        geospatials.add(multiLineString);
-        geospatials.add(multiPolygon);
-        final GeospatialCollection geoColl = new GeospatialCollection(Geospatial.Dimension.GEOGRAPHY, geospatials);
-        row.addAdditionalProperty("aCollection", geoColl);
-
-        ContactDetails contactDetails = new ContactDetails();
-        contactDetails.setFirstContacted("text".getBytes());
-        contactDetails.setLastContacted(
-                ODataTimestamp.parse(EdmSimpleType.DateTimeOffset, "2001-04-05T05:05:05.001+00:01"));
-        contactDetails.setContacted(
-                ODataTimestamp.parse(EdmSimpleType.DateTime, "2001-04-05T05:05:04.001"));
-        contactDetails.setGUID(UUID.randomUUID());
-        contactDetails.setPreferedContactTime(new ODataDuration("-P9DT51M10.5063807S"));
-        contactDetails.setByte(241);
-        contactDetails.setSignedByte(Byte.MAX_VALUE);
-        contactDetails.setDouble(Double.MAX_VALUE);
-        contactDetails.setSingle(Float.MAX_VALUE);
-        contactDetails.setShort(Short.MAX_VALUE);
-        contactDetails.setInt(Integer.MAX_VALUE);
-        contactDetails.setLong(Long.MAX_VALUE);
-        row.addAdditionalProperty("aContact", contactDetails);
-
-        otcontainer.flush();
-
-        row = otcontainer.getRow().get(guid);
-        assertNotNull(row);
-
-        assertEquals(1.5D, ((Double) row.getAdditionalProperty("aDouble")).doubleValue(), 0.1E-100);
-        assertEquals(1.2D, ((Point) row.getAdditionalProperty("aPoint")).getX(), 0.1E-100);
-        assertEquals(2.1D, ((Point) row.getAdditionalProperty("aPoint")).getY(), 0.1E-100);
-
-        GeospatialCollection aCollection = (GeospatialCollection) row.getAdditionalProperty("aCollection");
-        assertEquals(Geospatial.Dimension.GEOGRAPHY, aCollection.getDimension());
-        int count = 0;
-        for (Geospatial geospatial : aCollection) {
-            count++;
-        }
-        assertEquals(4, count);
-
-        ContactDetails aContact = (ContactDetails) row.getAdditionalProperty("aContact");
-        assertEquals("text", new String(aContact.getFirstContacted()));
-        assertEquals(Short.MAX_VALUE, aContact.getShort().shortValue());
-        assertEquals(241, aContact.getByte().intValue());
-        assertEquals(ODataTimestamp.parse(EdmSimpleType.DateTime, "2001-04-05T05:05:04.001").toString(),
-                aContact.getContacted().toString());
-
-        otcontainer.getRow().delete(guid);
-        otcontainer.flush();
-
-        assertNull(otcontainer.getRow().get(guid));
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PrimitiveKeysTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PrimitiveKeysTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PrimitiveKeysTestITCase.java
deleted file mode 100644
index ed5754d..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PrimitiveKeysTestITCase.java
+++ /dev/null
@@ -1,74 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static org.junit.Assert.assertEquals;
-
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.proxy.api.EntityContainerFactory;
-import com.msopentech.odatajclient.proxy.primitivekeysservice.microsoft.test.odata.services.primitivekeysservice.TestContext;
-import java.math.BigDecimal;
-import java.util.UUID;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check basic feed operations.
- */
-public class PrimitiveKeysTestITCase extends AbstractTest {
-
-    @Test
-    public void readPrimitiveKeys() {
-        final EntityContainerFactory factory = EntityContainerFactory.getV3Instance(testPrimitiveKeysServiceRootURL);
-        final TestContext pkcontainer = factory.getEntityContainer(TestContext.class);
-
-        // commented as per #115
-        //assertEquals(new byte[] {Byte.valueOf("2"), Byte.valueOf("3"), Byte.valueOf("4")}, 
-        //        container.getEdmBinarySet().get(
-        //        new byte[] {Byte.valueOf("2"), Byte.valueOf("3"), Byte.valueOf("4")}).getId());
-
-        assertEquals(Boolean.TRUE, pkcontainer.getEdmBooleanSet().get(Boolean.TRUE).getId());
-        assertEquals(Integer.valueOf(255), pkcontainer.getEdmByteSet().get(255).getId());
-        assertEquals(new BigDecimal("79228162514264337593543950335"),
-                pkcontainer.getEdmDecimalSet().get(new BigDecimal("79228162514264337593543950335")).getId());
-        assertEquals(UUID.fromString("00000000-0000-0000-0000-000000000000"),
-                pkcontainer.getEdmGuidSet().get(UUID.fromString("00000000-0000-0000-0000-000000000000")).getId());
-        assertEquals(Integer.valueOf(-2147483648),
-                pkcontainer.getEdmInt32Set().get(Integer.valueOf(-2147483648)).getId());
-        assertEquals(Long.valueOf(9223372036854775807L),
-                pkcontainer.getEdmInt64Set().get(Long.valueOf(9223372036854775807L)).getId());
-        assertEquals("$", pkcontainer.getEdmStringSet().get("$").getId());
-        assertEquals(new ODataDuration("-P10675199DT2H48M5.4775808S"),
-                pkcontainer.getEdmTimeSet().get(new ODataDuration("-P10675199DT2H48M5.4775808S")).getId());
-        assertEquals(32767, pkcontainer.getEdmInt16Set().get(Short.valueOf("32767")).getId().shortValue());
-        assertEquals(Double.valueOf(1.7976931348623157E+308D),
-                pkcontainer.getEdmDoubleSet().get(1.7976931348623157E+308D).getId());
-        assertEquals(Float.valueOf(3.40282347E+38F),
-                pkcontainer.getEdmSingleSet().get(Float.valueOf(3.40282347E+38F)).getId());
-
-        // commented as per #115
-        //assertEquals(
-        //        ODataTimestamp.parse(EdmSimpleType.DATE_TIME.pattern(), "0001-01-01T00:00:00"),
-        //        container.getEdmDateTimeSet().get(
-        //        ODataTimestamp.parse(EdmSimpleType.DATE_TIME.pattern(), "0001-01-01T00:00:00")));
-        //assertEquals(
-        //        ODataTimestamp.parse(EdmSimpleType.DATE_TIME_OFFSET.pattern(), "2013-08-14T13:33:46.1045905+02:00"),
-        //        container.getEdmDateTimeOffsetSet().get(
-        //        ODataTimestamp.parse(EdmSimpleType.DATE_TIME_OFFSET.pattern(), "2013-08-14T13:33:46.1045905+02:00")));
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PropertyTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PropertyTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PropertyTestITCase.java
deleted file mode 100644
index a6b0b27..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/PropertyTestITCase.java
+++ /dev/null
@@ -1,59 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-import static com.msopentech.odatajclient.proxy.AbstractTest.container;
-import static org.junit.Assert.assertNull;
-import static org.junit.Assert.fail;
-
-import com.msopentech.odatajclient.proxy.api.EntityContainerFactory;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Driver;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Order;
-import org.junit.Test;
-
-/**
- * This is the unit test class to check actions overloading.
- */
-public class PropertyTestITCase extends AbstractTest {
-
-    @Test
-    public void nullNullableProperty() {
-        Order order = container.getOrder().get(-8);
-        order.setCustomerId(null);
-
-        container.flush();
-
-        order = container.getOrder().get(-8);
-        assertNull(order.getCustomerId());
-    }
-
-    @Test
-    public void nullNonNullableProperty() {
-        Driver driver = container.getDriver().get("1");
-        driver.setBirthDate(null);
-
-        try {
-            container.flush();
-            fail();
-        } catch (IllegalStateException e) {
-            // ignore and detach all
-            EntityContainerFactory.getContext().detachAll();
-        }
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/QueryTestITCase.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/QueryTestITCase.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/QueryTestITCase.java
deleted file mode 100644
index cbd25cf..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/QueryTestITCase.java
+++ /dev/null
@@ -1,107 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy;
-
-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 static org.junit.Assert.fail;
-
-import com.msopentech.odatajclient.proxy.api.NonUniqueResultException;
-import com.msopentech.odatajclient.proxy.api.Query;
-import com.msopentech.odatajclient.proxy.api.Sort;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Car;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.CarCollection;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee;
-import com.msopentech.odatajclient.proxy.defaultservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.List;
-import org.junit.Test;
-
-public class QueryTestITCase extends AbstractTest {
-
-    @Test
-    public void filterOrderby() {
-        final Query<Car, CarCollection> query = container.getCar().createQuery().setFilter("VIN lt 16");
-        CarCollection result = query.getResult();
-        assertNotNull(result);
-
-        // 1. check that filtered entity set looks as expected
-        assertEquals(5, result.size());
-
-        // 2. extract VIN values - sorted ASC by default
-        final List<Integer> vinsASC = new ArrayList<Integer>(5);
-        for (Car car : result) {
-            assertTrue(car.getVIN() < 16);
-            vinsASC.add(car.getVIN());
-        }
-
-        // 3. add orderby clause to filter above
-        result = query.setOrderBy(new Sort("VIN", Sort.Direction.DESC)).getResult();
-        assertNotNull(result);
-        assertEquals(5, result.size());
-
-        // 4. extract again VIN value - now they were required to be sorted DESC
-        final List<Integer> vinsDESC = new ArrayList<Integer>(5);
-        for (Car car : result) {
-            assertTrue(car.getVIN() < 16);
-            vinsDESC.add(car.getVIN());
-        }
-
-        // 5. reverse vinsASC and expect to be equal to vinsDESC
-        Collections.reverse(vinsASC);
-        assertEquals(vinsASC, vinsDESC);
-    }
-
-    @Test
-    public void single() {
-        final Query<Car, CarCollection> query = container.getCar().createQuery().setFilter("VIN lt 16");
-
-        Exception exception = null;
-        try {
-            query.getSingleResult();
-            fail();
-        } catch (NonUniqueResultException e) {
-            exception = e;
-        }
-        assertNotNull(exception);
-
-        query.setFilter(containerFactory.getFilterFactory().eq("VIN", 16));
-        final Car result = query.getSingleResult();
-        assertNotNull(result);
-    }
-
-    @Test
-    public void polymorph() {
-        final Query<Employee, EmployeeCollection> queryEmployee =
-                container.getPerson().createQuery(EmployeeCollection.class);
-        assertFalse(queryEmployee.getResult().isEmpty());
-
-        final Query<SpecialEmployee, SpecialEmployeeCollection> querySpecialEmployee =
-                container.getPerson().createQuery(SpecialEmployeeCollection.class);
-        assertFalse(querySpecialEmployee.getResult().isEmpty());
-
-        assertTrue(container.getPerson().getAll().size()
-                > queryEmployee.getResult().size() + querySpecialEmployee.getResult().size());
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
deleted file mode 100644
index 9f5156b..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoCollectionTypesSet.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "AllGeoCollectionTypesSet")
-public interface AllGeoCollectionTypesSet extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes newAllSpatialCollectionTypes();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypesCollection newAllSpatialCollectionTypesCollection();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_Simple newAllSpatialCollectionTypes_Simple();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialCollectionTypes_SimpleCollection newAllSpatialCollectionTypes_SimpleCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoTypesSet.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoTypesSet.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoTypesSet.java
deleted file mode 100644
index 23effcb..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/AllGeoTypesSet.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "AllGeoTypesSet")
-public interface AllGeoTypesSet extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialTypes, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialTypesCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialTypes newAllSpatialTypes();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.AllSpatialTypesCollection newAllSpatialTypesCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Car.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Car.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Car.java
deleted file mode 100644
index df09c51a..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Car.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "Car")
-public interface Car extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Car, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CarCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Car newCar();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CarCollection newCarCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Computer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Computer.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Computer.java
deleted file mode 100644
index 81949ad..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Computer.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "Computer")
-public interface Computer extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Computer, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Computer newComputer();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerCollection newComputerCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/ComputerDetail.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/ComputerDetail.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/ComputerDetail.java
deleted file mode 100644
index 7ae0992..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/ComputerDetail.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "ComputerDetail")
-public interface ComputerDetail extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetail, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetailCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetail newComputerDetail();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.ComputerDetailCollection newComputerDetailCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Customer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Customer.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Customer.java
deleted file mode 100644
index 722f3ef..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Customer.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "Customer")
-public interface Customer extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Customer newCustomer();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerCollection newCustomerCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/CustomerInfo.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/CustomerInfo.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/CustomerInfo.java
deleted file mode 100644
index a71fbf0..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/CustomerInfo.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "CustomerInfo")
-public interface CustomerInfo extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfo, Integer, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfoCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfo newCustomerInfo();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.CustomerInfoCollection newCustomerInfoCollection();
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/DefaultContainer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/DefaultContainer.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/DefaultContainer.java
deleted file mode 100644
index 85b8702..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/DefaultContainer.java
+++ /dev/null
@@ -1,159 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.engine.client.http.HttpMethod;
-import com.msopentech.odatajclient.proxy.api.annotations.Namespace;
-import com.msopentech.odatajclient.proxy.api.annotations.EntityContainer;
-import com.msopentech.odatajclient.proxy.api.annotations.Operation;
-import com.msopentech.odatajclient.proxy.api.annotations.Parameter;
-import com.msopentech.odatajclient.engine.metadata.edm.v3.ParameterMode;
-import com.msopentech.odatajclient.proxy.api.AbstractContainer;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-@Namespace("Microsoft.Test.OData.Services.AstoriaDefaultService")
-@EntityContainer(name = "DefaultContainer",
-  isDefaultEntityContainer = true)
-public interface DefaultContainer extends AbstractContainer {
-
-    AllGeoTypesSet getAllGeoTypesSet();
-
-    AllGeoCollectionTypesSet getAllGeoCollectionTypesSet();
-
-    Customer getCustomer();
-
-    Login getLogin();
-
-    RSAToken getRSAToken();
-
-    PageView getPageView();
-
-    LastLogin getLastLogin();
-
-    Message getMessage();
-
-    MessageAttachment getMessageAttachment();
-
-    Order getOrder();
-
-    OrderLine getOrderLine();
-
-    Product getProduct();
-
-    ProductDetail getProductDetail();
-
-    ProductReview getProductReview();
-
-    ProductPhoto getProductPhoto();
-
-    CustomerInfo getCustomerInfo();
-
-    Computer getComputer();
-
-    ComputerDetail getComputerDetail();
-
-    Driver getDriver();
-
-    License getLicense();
-
-    MappedEntityType getMappedEntityType();
-
-    Car getCar();
-
-    Person getPerson();
-
-    PersonMetadata getPersonMetadata();
-
-
-
-
-      @Operation(name = "RetrieveProduct"     ,
-                    httpMethod = HttpMethod.POST ,
-                    returnType = "Edm.Int32")
-    Integer retrieveProduct(
-    );
-        @Operation(name = "RetrieveProduct"      ,
-                    returnType = "Edm.Int32")
-    Integer retrieveProduct(
-        @Parameter(name = "product", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.Product", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Product product
-    );
-        @Operation(name = "RetrieveProduct"      ,
-                    returnType = "Edm.Int32")
-    Integer retrieveProduct(
-        @Parameter(name = "orderLine", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.OrderLine", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.OrderLine orderLine
-    );
-        @Operation(name = "IncreaseSalaries"      )
-    void increaseSalaries(
-        @Parameter(name = "employees", type = "Collection(Microsoft.Test.OData.Services.AstoriaDefaultService.Employee)", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.EmployeeCollection employees, 
-        @Parameter(name = "n", type = "Edm.Int32", nullable = false) Integer n
-    );
-        @Operation(name = "IncreaseSalaries"      )
-    void increaseSalaries(
-        @Parameter(name = "specialEmployees", type = "Collection(Microsoft.Test.OData.Services.AstoriaDefaultService.SpecialEmployee)", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployeeCollection specialEmployees, 
-        @Parameter(name = "n", type = "Edm.Int32", nullable = false) Integer n
-    );
-        @Operation(name = "UpdatePersonInfo"      )
-    void updatePersonInfo(
-    );
-        @Operation(name = "UpdatePersonInfo"      )
-    void updatePersonInfo(
-        @Parameter(name = "person", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.Person", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Person person
-    );
-        @Operation(name = "UpdatePersonInfo"      )
-    void updatePersonInfo(
-        @Parameter(name = "employee", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.Employee", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee employee
-    );
-        @Operation(name = "UpdatePersonInfo"      )
-    void updatePersonInfo(
-        @Parameter(name = "specialEmployee", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.SpecialEmployee", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee specialEmployee
-    );
-        @Operation(name = "UpdatePersonInfo"      )
-    void updatePersonInfo(
-        @Parameter(name = "contractor", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.Contractor", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Contractor contractor
-    );
-        @Operation(name = "IncreaseEmployeeSalary"      ,
-                    returnType = "Edm.Boolean")
-    Boolean increaseEmployeeSalary(
-        @Parameter(name = "employee", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.Employee", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Employee employee, 
-        @Parameter(name = "n", type = "Edm.Int32", nullable = false) Integer n
-    );
-        @Operation(name = "IncreaseEmployeeSalary"      ,
-                    returnType = "Edm.Int32")
-    Integer increaseEmployeeSalary(
-        @Parameter(name = "specialEmployee", type = "Microsoft.Test.OData.Services.AstoriaDefaultService.SpecialEmployee", nullable = true) com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.SpecialEmployee specialEmployee
-    );
-  }

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Driver.java
----------------------------------------------------------------------
diff --git a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Driver.java b/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Driver.java
deleted file mode 100644
index 520ad6e..0000000
--- a/ODataJClient/proxy/src/test/java/com/msopentech/odatajclient/proxy/actionoverloadingservice/microsoft/test/odata/services/astoriadefaultservice/Driver.java
+++ /dev/null
@@ -1,52 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice;
-
-import com.msopentech.odatajclient.proxy.api.AbstractEntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.EntitySet;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKey;
-import com.msopentech.odatajclient.proxy.api.annotations.CompoundKeyElement;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.*;
-import com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.*;
-
-// EdmSimpleType property imports
-import com.msopentech.odatajclient.engine.data.ODataDuration;
-import com.msopentech.odatajclient.engine.data.ODataTimestamp;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Geospatial;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.GeospatialCollection;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.LineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiLineString;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPoint;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.MultiPolygon;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Point;
-import com.msopentech.odatajclient.engine.metadata.edm.geospatial.Polygon;
-import java.math.BigDecimal;
-import java.net.URI;
-import java.util.UUID;
-import java.io.Serializable;
-import java.util.Collection;
-
-
-
-@EntitySet(name = "Driver")
-public interface Driver extends AbstractEntitySet<com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Driver, String, com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.DriverCollection> {
-
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.Driver newDriver();
-    com.msopentech.odatajclient.proxy.actionoverloadingservice.microsoft.test.odata.services.astoriadefaultservice.types.DriverCollection newDriverCollection();
-}