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 2013/09/24 14:43:01 UTC

[34/51] [partial] Refactored project structure

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchException.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchException.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchException.java
deleted file mode 100644
index 647b071..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchException.java
+++ /dev/null
@@ -1,139 +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 org.apache.olingo.odata2.api.batch;
-
-import org.apache.olingo.odata2.api.exception.MessageReference;
-import org.apache.olingo.odata2.api.exception.ODataMessageException;
-
-public class BatchException extends ODataMessageException {
-
-  /**
-   * 
-   */
-  private static final long serialVersionUID = 1L;
-
-  /** INVALID_CHANGESET_BOUNDARY requires 1 content value ('line number') */
-  public static final MessageReference INVALID_CHANGESET_BOUNDARY = createMessageReference(BatchException.class,
-      "INVALID_CHANGESET_BOUNDARY");
-
-  /** INVALID_BOUNDARY_DELIMITER requires 1 content value ('line number') */
-  public static final MessageReference INVALID_BOUNDARY_DELIMITER = createMessageReference(BatchException.class,
-      "INVALID_BOUNDARY_DELIMITER");
-
-  /** MISSING_BOUNDARY_DELIMITER requires 1 content value('line number') */
-  public static final MessageReference MISSING_BOUNDARY_DELIMITER = createMessageReference(BatchException.class,
-      "MISSING_BOUNDARY_DELIMITER");
-
-  /** MISSING_CLOSE_DELIMITER requires 1 content value ('line number') */
-  public static final MessageReference MISSING_CLOSE_DELIMITER = createMessageReference(BatchException.class,
-      "MISSING_CLOSE_DELIMITER");
-
-  /** INVALID_QUERY_OPERATION_METHOD requires 1 content value ('line number') */
-  public static final MessageReference INVALID_QUERY_OPERATION_METHOD = createMessageReference(BatchException.class,
-      "INVALID_QUERY_OPERATION_METHOD");
-
-  /** INVALID_CHANGESET_METHOD requires 1 content value ('line number') */
-  public static final MessageReference INVALID_CHANGESET_METHOD = createMessageReference(BatchException.class,
-      "INVALID_CHANGESET_METHOD");
-
-  /** INVALID_QUERY_PARAMETER requires no content value */
-  public static final MessageReference INVALID_QUERY_PARAMETER = createMessageReference(BatchException.class,
-      "INVALID_QUERY_PARAMETER");
-
-  /** INVALID_URI requires 1 content value('line number') */
-  public static final MessageReference INVALID_URI = createMessageReference(BatchException.class, "INVALID_URI");
-
-  /** INVALID_BOUNDARY requires 1 content value('line number') */
-  public static final MessageReference INVALID_BOUNDARY = createMessageReference(BatchException.class,
-      "INVALID_BOUNDARY");
-
-  /** NO_MATCH_WITH_BOUNDARY_STRING requires 2 content value ('required boundary', 'line number') */
-  public static final MessageReference NO_MATCH_WITH_BOUNDARY_STRING = createMessageReference(BatchException.class,
-      "NO_MATCH_WITH_BOUNDARY_STRING");
-
-  /** MISSING_CONTENT_TYPE requires no content value */
-  public static final MessageReference MISSING_CONTENT_TYPE = createMessageReference(BatchException.class,
-      "MISSING_CONTENT_TYPE");
-
-  /** INVALID_CONTENT_TYPE requires 1 content value ('required content-type') */
-  public static final MessageReference INVALID_CONTENT_TYPE = createMessageReference(BatchException.class,
-      "INVALID_CONTENT_TYPE");
-
-  /** MISSING_PARAMETER_IN_CONTENT_TYPE requires no content value */
-  public static final MessageReference MISSING_PARAMETER_IN_CONTENT_TYPE = createMessageReference(BatchException.class,
-      "MISSING_PARAMETER_IN_CONTENT_TYPE");
-
-  /** INVALID_HEADER requires 1 content value ('header', 'line number') */
-  public static final MessageReference INVALID_HEADER = createMessageReference(BatchException.class, "INVALID_HEADER");
-
-  /** INVALID_ACCEPT_HEADER requires 1 content value ('header') */
-  public static final MessageReference INVALID_ACCEPT_HEADER = createMessageReference(BatchException.class,
-      "INVALID_ACCEPT_HEADER");
-
-  /** INVALID_ACCEPT_LANGUAGE_HEADER requires 1 content value ('header') */
-  public static final MessageReference INVALID_ACCEPT_LANGUAGE_HEADER = createMessageReference(BatchException.class,
-      "INVALID_ACCEPT_LANGUAGE_HEADER");
-
-  /** INVALID_CONTENT_TRANSFER_ENCODING requires no content value */
-  public static final MessageReference INVALID_CONTENT_TRANSFER_ENCODING = createMessageReference(BatchException.class,
-      "INVALID_CONTENT_TRANSFER_ENCODING");
-
-  /** MISSING_BLANK_LINE requires 2 content value ('supplied line','line number') */
-  public static final MessageReference MISSING_BLANK_LINE = createMessageReference(BatchException.class,
-      "MISSING_BLANK_LINE");
-
-  /** INVALID_PATHINFO requires no content value */
-  public static final MessageReference INVALID_PATHINFO = createMessageReference(BatchException.class,
-      "INVALID_PATHINFO");
-
-  /** MISSING_METHOD requires 1 content value ('request line') */
-  public static final MessageReference MISSING_METHOD = createMessageReference(BatchException.class, "MISSING_METHOD");
-
-  /** INVALID_REQUEST_LINE requires 2 content value ('request line', 'line number') */
-  public static final MessageReference INVALID_REQUEST_LINE = createMessageReference(BatchException.class,
-      "INVALID_REQUEST_LINE");
-
-  /** INVALID_STATUS_LINE requires 2 content value ('status line', 'line number') */
-  public static final MessageReference INVALID_STATUS_LINE = createMessageReference(BatchException.class,
-      "INVALID_STATUS_LINE");
-
-  /** TRUNCETED_BODY requires 1 content value ('line number') */
-  public static final MessageReference TRUNCATED_BODY = createMessageReference(BatchException.class, "TRUNCATED_BODY");
-
-  /** UNSUPPORTED_ABSOLUTE_PATH requires 1 content value ('line number') */
-  public static final MessageReference UNSUPPORTED_ABSOLUTE_PATH = createMessageReference(BatchException.class,
-      "UNSUPPORTED_ABSOLUTE_PATH");
-
-  public BatchException(final MessageReference messageReference) {
-    super(messageReference);
-  }
-
-  public BatchException(final MessageReference messageReference, final Throwable cause) {
-    super(messageReference, cause);
-  }
-
-  public BatchException(final MessageReference messageReference, final String errorCode) {
-    super(messageReference, errorCode);
-  }
-
-  public BatchException(final MessageReference messageReference, final Throwable cause, final String errorCode) {
-    super(messageReference, cause, errorCode);
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchHandler.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchHandler.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchHandler.java
deleted file mode 100644
index 673f0ae..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchHandler.java
+++ /dev/null
@@ -1,45 +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 org.apache.olingo.odata2.api.batch;
-
-import org.apache.olingo.odata2.api.exception.ODataException;
-import org.apache.olingo.odata2.api.processor.ODataRequest;
-import org.apache.olingo.odata2.api.processor.ODataResponse;
-
-/**
- *  
- */
-public interface BatchHandler {
-  /**
-   * <p>Handles the {@link BatchRequestPart} in a way that it results in a corresponding {@link BatchResponsePart}.</p>
-   * @param batchRequestPart the incoming MIME part
-   * @return the corresponding result
-   * @throws ODataException
-   */
-  public BatchResponsePart handleBatchPart(BatchRequestPart batchRequestPart) throws ODataException;
-
-  /**
-   * <p>Delegates a handling of the request {@link ODataRequest} to the request handler and provides ODataResponse
-   * {@link ODataResponse}.</p>
-   * @param request the incoming request
-   * @return the corresponding result
-   * @throws ODataException
-   */
-  public ODataResponse handleRequest(ODataRequest request) throws ODataException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchRequestPart.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchRequestPart.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchRequestPart.java
deleted file mode 100644
index 5e3e2f2..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchRequestPart.java
+++ /dev/null
@@ -1,42 +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 org.apache.olingo.odata2.api.batch;
-
-import java.util.List;
-
-import org.apache.olingo.odata2.api.processor.ODataRequest;
-
-/**
- * A BatchPart
- * <p> BatchPart represents a distinct MIME part of a Batch Request body. It can be ChangeSet or Query Operation
- */
-public interface BatchRequestPart {
-
-  /**
-   * Get the info if a BatchPart is a ChangeSet
-   * @return true or false
-   */
-  public boolean isChangeSet();
-
-  /**
-   * Get requests. If a BatchPart is a Query Operation, the list contains one request.
-   * @return a list of {@link ODataRequest}
-   */
-  public List<ODataRequest> getRequests();
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchResponsePart.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchResponsePart.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchResponsePart.java
deleted file mode 100644
index dfafbdb..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/batch/BatchResponsePart.java
+++ /dev/null
@@ -1,85 +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 org.apache.olingo.odata2.api.batch;
-
-import java.util.List;
-
-import org.apache.olingo.odata2.api.processor.ODataResponse;
-import org.apache.olingo.odata2.api.rt.RuntimeDelegate;
-
-/**
- * A BatchResponsePart
- * <p> BatchResponsePart represents a distinct part of a Batch Response body. It can be a ChangeSet response or a
- * response to a retrieve request
- * 
- */
-public abstract class BatchResponsePart {
-
-  /**
-   * Get responses. If a BatchResponsePart is a response to a retrieve request, the list consists of one response.
-   * @return a list of {@link ODataResponse}
-   */
-  public abstract List<ODataResponse> getResponses();
-
-  /**
-   * Get the info if a BatchResponsePart is a ChangeSet response
-   * @return true or false
-   */
-  public abstract boolean isChangeSet();
-
-  /**
-   * 
-   * @param responses a list of {@link ODataResponse}
-   * @return a builder object
-   */
-  public static BatchResponsePartBuilder responses(final List<ODataResponse> responses) {
-    return newBuilder().responses(responses);
-  }
-
-  /**
-   * @param isChangeSet true if a BatchResponsePart is a ChangeSet response
-   * @return a builder object
-   */
-  public static BatchResponsePartBuilder changeSet(final boolean isChangeSet) {
-    return newBuilder().changeSet(isChangeSet);
-  }
-
-  /**
-   * @return returns a new builder object
-   */
-  public static BatchResponsePartBuilder newBuilder() {
-    return BatchResponsePartBuilder.newInstance();
-  }
-
-  /**
-   * Implementation of the builder pattern to create instances of this type of object.
-   * 
-   */
-  public static abstract class BatchResponsePartBuilder {
-    public abstract BatchResponsePart build();
-
-    private static BatchResponsePartBuilder newInstance() {
-      return RuntimeDelegate.createBatchResponsePartBuilder();
-    }
-
-    public abstract BatchResponsePartBuilder responses(List<ODataResponse> responses);
-
-    public abstract BatchResponsePartBuilder changeSet(boolean isChangeSet);
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSet.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSet.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSet.java
deleted file mode 100644
index 83aa367..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSet.java
+++ /dev/null
@@ -1,61 +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 org.apache.olingo.odata2.api.client.batch;
-
-import java.util.List;
-
-import org.apache.olingo.odata2.api.rt.RuntimeDelegate;
-
-/**
- * A BatchChangeSet
- * <p> BatchChangeSet represents a Change Set, that consists of change requests
- */
-public abstract class BatchChangeSet implements BatchPart {
-
-  /**
-   * Add a new change request to the ChangeSet
-   * @param request {@link BatchChangeSetPart}
-   */
-  public abstract void add(BatchChangeSetPart request);
-
-  /**
-   * Get change requests
-   * @return a list of {@link BatchChangeSetPart}
-   */
-  public abstract List<BatchChangeSetPart> getChangeSetParts();
-
-  /**
-   * Get new builder instance
-   * @return {@link BatchChangeSetBuilder}
-   */
-  public static BatchChangeSetBuilder newBuilder() {
-    return BatchChangeSetBuilder.newInstance();
-  }
-
-  public static abstract class BatchChangeSetBuilder {
-
-    protected BatchChangeSetBuilder() {}
-
-    private static BatchChangeSetBuilder newInstance() {
-      return RuntimeDelegate.createBatchChangeSetBuilder();
-    }
-
-    public abstract BatchChangeSet build();
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSetPart.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSetPart.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSetPart.java
deleted file mode 100644
index d9a81d8..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchChangeSetPart.java
+++ /dev/null
@@ -1,110 +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 org.apache.olingo.odata2.api.client.batch;
-
-import java.util.Map;
-
-import org.apache.olingo.odata2.api.rt.RuntimeDelegate;
-
-/**
- * A BatchChangeSetPart
- * <p> BatchChangeSetPart represents a change request within a Change Set
- */
-public abstract class BatchChangeSetPart {
-
-  public abstract Map<String, String> getHeaders();
-
-  public abstract String getBody();
-
-  public abstract String getUri();
-
-  public abstract String getMethod();
-
-  public abstract String getContentId();
-
-  /**
-   * @param headers
-   * @return a new builder object
-   */
-  public static BatchChangeSetPartBuilder headers(final Map<String, String> headers) {
-    return newBuilder().headers(headers);
-  }
-
-  /**
-   * @param body a change request body
-   * @return a new builder object
-   */
-  public static BatchChangeSetPartBuilder body(final String body) {
-    return newBuilder().body(body);
-  }
-
-  /**
-   * @param uri should not be null
-   * @return a new builder object
-   */
-  public static BatchChangeSetPartBuilder uri(final String uri) {
-    return newBuilder().uri(uri);
-  }
-
-  /**
-   * @param method MUST be the PUT, POST, MERGE, DELETE or PATCH method
-   * @return a new builder object
-   */
-  public static BatchChangeSetPartBuilder method(final String method) {
-    return newBuilder().method(method);
-  }
-
-  /**
-   * @param contentId can be used to identify the different request within a the batch
-   * @return a new builder object
-   */
-  public static BatchChangeSetPartBuilder contentId(final String contentId) {
-    return newBuilder().contentId(contentId);
-  }
-
-  /**
-   * @return returns a new builder object
-   */
-  public static BatchChangeSetPartBuilder newBuilder() {
-    return BatchChangeSetPartBuilder.newInstance();
-  }
-
-  public static abstract class BatchChangeSetPartBuilder {
-
-    protected BatchChangeSetPartBuilder() {}
-
-    private static BatchChangeSetPartBuilder newInstance() {
-      return RuntimeDelegate.createBatchChangeSetPartBuilder();
-    }
-
-    public abstract BatchChangeSetPart build();
-
-    public abstract BatchChangeSetPartBuilder headers(Map<String, String> headers);
-
-    public abstract BatchChangeSetPartBuilder body(String body);
-
-    public abstract BatchChangeSetPartBuilder uri(String uri);
-
-    public abstract BatchChangeSetPartBuilder method(String method);
-
-    public abstract BatchChangeSetPartBuilder contentId(String contentId);
-
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchPart.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchPart.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchPart.java
deleted file mode 100644
index 2f2b5d5..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchPart.java
+++ /dev/null
@@ -1,27 +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 org.apache.olingo.odata2.api.client.batch;
-
-/**
- * A BatchPartRequest
- * <p> BatchPartRequest represents a distinct part of a Batch Request body. It can be a ChangeSet or Query Operation.
- */
-public interface BatchPart {
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchQueryPart.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchQueryPart.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchQueryPart.java
deleted file mode 100644
index 78827eb..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchQueryPart.java
+++ /dev/null
@@ -1,97 +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 org.apache.olingo.odata2.api.client.batch;
-
-import java.util.Map;
-
-import org.apache.olingo.odata2.api.rt.RuntimeDelegate;
-
-/**
- * A BatchQueryPart
- * <p>BatchQueryPart represents a single retrieve request
- */
-public abstract class BatchQueryPart implements BatchPart {
-
-  public abstract Map<String, String> getHeaders();
-
-  public abstract String getUri();
-
-  public abstract String getMethod();
-
-  public abstract String getContentId();
-
-  /**
-   * @param headers
-   * @return a new builder object
-   */
-  public static BatchQueryPartBuilder headers(final Map<String, String> headers) {
-    return newBuilder().headers(headers);
-  }
-
-  /**
-   * @param uri should not be null
-   * @return a new builder object
-   */
-  public static BatchQueryPartBuilder uri(final String uri) {
-    return newBuilder().uri(uri);
-  }
-
-  /**
-   * @param method MUST be the HTTP GET method
-   * @return a new builder object
-   */
-  public static BatchQueryPartBuilder method(final String method) {
-    return newBuilder().method(method);
-  }
-
-  /**
-   * @param contentId can be used to identify the different request within a the batch
-   * @return a new builder object
-   */
-  public static BatchQueryPartBuilder contentId(final String contentId) {
-    return newBuilder().contentId(contentId);
-  }
-
-  /**
-   * @return returns a new builder object
-   */
-  public static BatchQueryPartBuilder newBuilder() {
-    return BatchQueryPartBuilder.newInstance();
-  }
-
-  public static abstract class BatchQueryPartBuilder {
-
-    protected BatchQueryPartBuilder() {}
-
-    private static BatchQueryPartBuilder newInstance() {
-      return RuntimeDelegate.createBatchQueryPartBuilder();
-    }
-
-    public abstract BatchQueryPart build();
-
-    public abstract BatchQueryPartBuilder headers(Map<String, String> headers);
-
-    public abstract BatchQueryPartBuilder uri(String uri);
-
-    public abstract BatchQueryPartBuilder method(String method);
-
-    public abstract BatchQueryPartBuilder contentId(String contentId);
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchSingleResponse.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchSingleResponse.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchSingleResponse.java
deleted file mode 100644
index dc8c9b7..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/client/batch/BatchSingleResponse.java
+++ /dev/null
@@ -1,66 +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 org.apache.olingo.odata2.api.client.batch;
-
-import java.util.Map;
-import java.util.Set;
-
-/**
- * A BatchSingleResponse
- * <p> BatchSingleResponse represents a single response of a Batch Response body. It can be a response to a change
- * request of ChangeSet or a response to a retrieve request
- */
-public interface BatchSingleResponse {
-  /**
-   * @return a result code of the attempt to understand and satisfy the request
-   */
-  public String getStatusCode();
-
-  /**
-   * @return a short textual description of the status code
-   */
-  public String getStatusInfo();
-
-  /**
-   * @return a value of the Content-Id header
-   */
-  public String getContentId();
-
-  /**
-   * @return a body part of a response message
-   */
-  public String getBody();
-
-  /**
-   * @return all available headers
-   */
-  public Map<String, String> getHeaders();
-
-  /**
-   * @param name HTTP response header name
-   * @return a header value or null if not set
-   */
-  public String getHeader(final String name);
-
-  /**
-   * @return a set of all available header names
-   */
-  public Set<String> getHeaderNames();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpContentType.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpContentType.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpContentType.java
deleted file mode 100644
index 7f51ae3..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpContentType.java
+++ /dev/null
@@ -1,55 +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 org.apache.olingo.odata2.api.commons;
-
-/**
- * Constants for <code>Http Content Type</code> definitions as specified in
- * <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html">RFC 2616 Section 14</a>.
- * 
- */
-public interface HttpContentType {
-
-  public static final String APPLICATION_XML = "application/xml";
-  public static final String APPLICATION_XML_UTF8 = APPLICATION_XML + ";charset=utf-8";
-
-  public static final String APPLICATION_ATOM_XML = "application/atom+xml";
-  public static final String APPLICATION_ATOM_XML_UTF8 = APPLICATION_ATOM_XML + ";charset=utf-8";
-  public static final String APPLICATION_ATOM_XML_ENTRY = APPLICATION_ATOM_XML + ";type=entry";
-  public static final String APPLICATION_ATOM_XML_ENTRY_UTF8 = APPLICATION_ATOM_XML_ENTRY + ";charset=utf-8";
-  public static final String APPLICATION_ATOM_XML_FEED = APPLICATION_ATOM_XML + ";type=feed";
-  public static final String APPLICATION_ATOM_XML_FEED_UTF8 = APPLICATION_ATOM_XML_FEED + ";charset=utf-8";
-  public static final String APPLICATION_ATOM_SVC = "application/atomsvc+xml";
-  public static final String APPLICATION_ATOM_SVC_UTF8 = APPLICATION_ATOM_SVC + ";charset=utf-8";
-
-  public static final String APPLICATION_JSON = "application/json";
-  public static final String APPLICATION_JSON_VERBOSE = APPLICATION_JSON + ";odata=verbose";
-  public static final String APPLICATION_JSON_UTF8 = APPLICATION_JSON + ";charset=utf-8";
-  public static final String APPLICATION_JSON_UTF8_VERBOSE = APPLICATION_JSON_UTF8 + ";odata=verbose";
-
-  public static final String TEXT_PLAIN = "text/plain";
-  public static final String TEXT_PLAIN_UTF8 = TEXT_PLAIN + ";charset=utf-8";
-
-  public static final String APPLICATION_OCTET_STREAM = "application/octet-stream";
-
-  public static final String APPLICATION_HTTP = "application/http";
-
-  public static final String MULTIPART_MIXED = "multipart/mixed";
-
-  public static final String WILDCARD = "*/*";
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpHeaders.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpHeaders.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpHeaders.java
deleted file mode 100644
index f0851d1..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpHeaders.java
+++ /dev/null
@@ -1,145 +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 org.apache.olingo.odata2.api.commons;
-
-/**
- * HTTP header constants
- * 
- * 
- */
-public interface HttpHeaders {
-
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.1">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ACCEPT = "Accept";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.2">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ACCEPT_CHARSET = "Accept-Charset";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.3">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ACCEPT_ENCODING = "Accept-Encoding";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.4">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ACCEPT_LANGUAGE = "Accept-Language";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.7">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ALLOW = "Allow";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.8">HTTP/1.1 documentation</a>}.
-   */
-  public static final String AUTHORIZATION = "Authorization";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.9">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CACHE_CONTROL = "Cache-Control";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.11">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CONTENT_ENCODING = "Content-Encoding";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.12">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CONTENT_LANGUAGE = "Content-Language";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.13">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CONTENT_LENGTH = "Content-Length";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.14">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CONTENT_LOCATION = "Content-Location";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.17">HTTP/1.1 documentation</a>}.
-   */
-  public static final String CONTENT_TYPE = "Content-Type";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.18">HTTP/1.1 documentation</a>}.
-   */
-  public static final String DATE = "Date";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.19">HTTP/1.1 documentation</a>}.
-   */
-  public static final String ETAG = "ETag";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.21">HTTP/1.1 documentation</a>}.
-   */
-  public static final String EXPIRES = "Expires";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.23">HTTP/1.1 documentation</a>}.
-   */
-  public static final String HOST = "Host";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.24">HTTP/1.1 documentation</a>}.
-   */
-  public static final String IF_MATCH = "If-Match";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.25">HTTP/1.1 documentation</a>}.
-   */
-  public static final String IF_MODIFIED_SINCE = "If-Modified-Since";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.26">HTTP/1.1 documentation</a>}.
-   */
-  public static final String IF_NONE_MATCH = "If-None-Match";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.28">HTTP/1.1 documentation</a>}.
-   */
-  public static final String IF_UNMODIFIED_SINCE = "If-Unmodified-Since";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.29">HTTP/1.1 documentation</a>}.
-   */
-  public static final String LAST_MODIFIED = "Last-Modified";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.30">HTTP/1.1 documentation</a>}.
-   */
-  public static final String LOCATION = "Location";
-  /**
-   * See {@link <a href="http://tools.ietf.org/html/rfc5988#page-6">Web Linking (IETF RFC-5988) documentation</a>}.
-   */
-  public static final String LINK = "Link";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.37">HTTP/1.1 documentation</a>}.
-   */
-  public static final String RETRY_AFTER = "Retry-After";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.43">HTTP/1.1 documentation</a>}.
-   */
-  public static final String USER_AGENT = "User-Agent";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.44">HTTP/1.1 documentation</a>}.
-   */
-  public static final String VARY = "Vary";
-  /**
-   * See {@link <a href="http://www.w3.org/Protocols/rfc2616/rfc2616-sec14.html#sec14.47">HTTP/1.1 documentation</a>}.
-   */
-  public static final String WWW_AUTHENTICATE = "WWW-Authenticate";
-  /**
-   * See {@link <a href="http://www.ietf.org/rfc/rfc2109.txt">IETF RFC 2109</a>}.
-   */
-  public static final String COOKIE = "Cookie";
-  /**
-   * See {@link <a href="http://www.ietf.org/rfc/rfc2109.txt">IETF RFC 2109</a>}.
-   */
-  public static final String SET_COOKIE = "Set-Cookie";
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpStatusCodes.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpStatusCodes.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpStatusCodes.java
deleted file mode 100644
index e2a416f..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/HttpStatusCodes.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 org.apache.olingo.odata2.api.commons;
-
-/**
- * HTTP status codes as defined in RFC2616-sec10
- * and additional status codes as defined in RFC6585
- * 
- */
-public enum HttpStatusCodes {
-
-  OK(200, "OK"), CREATED(201, "Created"), ACCEPTED(202, "Accepted"), NO_CONTENT(204, "No Content"), RESET_CONTENT(205,
-      "Reset Content"), PARTIAL_CONTENT(206, "Partial Content"),
-
-  MOVED_PERMANENTLY(301, "Moved Permanently"), FOUND(302, "Found"), SEE_OTHER(303, "See Other"), NOT_MODIFIED(304,
-      "Not Modified"), USE_PROXY(305, "Use Proxy"), TEMPORARY_REDIRECT(307, "Temporary Redirect"),
-
-  BAD_REQUEST(400, "Bad Request"), UNAUTHORIZED(401, "Unauthorized"), PAYMENT_REQUIRED(402, "Payment Required"),
-  FORBIDDEN(
-      403, "Forbidden"), NOT_FOUND(404, "Not Found"), METHOD_NOT_ALLOWED(405, "Method Not Allowed"), NOT_ACCEPTABLE(
-      406, "Not Acceptable"), PROXY_AUTHENTICATION_REQUIRED(407, "Proxy Authentication Required"), REQUEST_TIMEOUT(408,
-      "Request Timeout"), CONFLICT(409, "Conflict"), GONE(410, "Gone"), LENGTH_REQUIRED(411, "Length Required"),
-  PRECONDITION_FAILED(412, "Precondition Failed"), REQUEST_ENTITY_TOO_LARGE(413, "Request Entity Too Large"),
-  REQUEST_URI_TOO_LONG(414, "Request-URI Too Long"), UNSUPPORTED_MEDIA_TYPE(415, "Unsupported Media Type"),
-  REQUESTED_RANGE_NOT_SATISFIABLE(416, "Requested Range Not Satisfiable"),
-  EXPECTATION_FAILED(417, "Expectation Failed"), PRECONDITION_REQUIRED(428, "Precondition Required"),
-
-  INTERNAL_SERVER_ERROR(500, "Internal Server Error"), NOT_IMPLEMENTED(501, "Not Implemented"), BAD_GATEWAY(502,
-      "Bad Gateway"), SERVICE_UNAVAILABLE(503, "Service Unavailable"), GATEWAY_TIMEOUT(504, "Gateway Timeout"),
-  HTTP_VERSION_NOT_SUPPORTED(505, "HTTP Version Not Supported");
-
-  private final int code;
-  private final String info;
-
-  HttpStatusCodes(final int statusCode, final String info) {
-    code = statusCode;
-    this.info = info;
-  }
-
-  /**
-   * Convert a numerical status code into the corresponding status enum object.
-   * 
-   * @param statusCode the numerical status code
-   * @return the matching status enum object or null if no matching enum is defined
-   */
-  public static HttpStatusCodes fromStatusCode(final int statusCode) {
-    for (final HttpStatusCodes s : HttpStatusCodes.values()) {
-      if (s.code == statusCode) {
-        return s;
-      }
-    }
-    return null;
-  }
-
-  /**
-   * Get the associated status code.
-   * 
-   * @return the status code.
-   */
-  public int getStatusCode() {
-    return code;
-  }
-
-  /**
-   * Get the status code info.
-   * 
-   * @return the status code info
-   */
-  public String getInfo() {
-    return toString();
-  }
-
-  /**
-   * Get the status code info.
-   * 
-   * @return the status code info
-   */
-  @Override
-  public String toString() {
-    return info;
-  }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/InlineCount.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/InlineCount.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/InlineCount.java
deleted file mode 100644
index 03a998e..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/InlineCount.java
+++ /dev/null
@@ -1,27 +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 org.apache.olingo.odata2.api.commons;
-
-/**
- * Inlinecount constants as described in the OData protocol
- * 
- */
-public enum InlineCount {
-  ALLPAGES, NONE;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpHeaders.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpHeaders.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpHeaders.java
deleted file mode 100644
index be139de..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpHeaders.java
+++ /dev/null
@@ -1,29 +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 org.apache.olingo.odata2.api.commons;
-
-/**
- * HTTP header constants as used in the OData protocol
- * 
- */
-public class ODataHttpHeaders {
-
-  public static final String DATASERVICEVERSION = "DataServiceVersion";
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpMethod.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpMethod.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpMethod.java
deleted file mode 100644
index 2cd2a6e..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/ODataHttpMethod.java
+++ /dev/null
@@ -1,27 +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 org.apache.olingo.odata2.api.commons;
-
-/**
- * The supported HTTP methods.
- * 
- */
-public enum ODataHttpMethod {
-  GET, PUT, POST, DELETE, PATCH, MERGE;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/package-info.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/package-info.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/package-info.java
deleted file mode 100644
index ecb129b..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/commons/package-info.java
+++ /dev/null
@@ -1,23 +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.
- ******************************************************************************/
-/**
- * The commons package contains constants used in the HTTP and OData protocol.
- */
-package org.apache.olingo.odata2.api.commons;
-

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/Edm.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/Edm.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/Edm.java
deleted file mode 100644
index 2126254..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/Edm.java
+++ /dev/null
@@ -1,127 +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 org.apache.olingo.odata2.api.edm;
-
-import java.util.List;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * Entity Data Model (EDM)
- * <p>Interface representing a Entity Data Model as described in the Conceptual Schema Definition.
- * 
- */
-public interface Edm {
-
-  public static final String NAMESPACE_EDM_2006_04 = "http://schemas.microsoft.com/ado/2006/04/edm";
-  public static final String NAMESPACE_EDM_2007_05 = "http://schemas.microsoft.com/ado/2007/05/edm";
-  public static final String NAMESPACE_EDM_2008_01 = "http://schemas.microsoft.com/ado/2008/01/edm";
-  public static final String NAMESPACE_EDM_2008_09 = "http://schemas.microsoft.com/ado/2008/09/edm";
-  public static final String NAMESPACE_APP_2007 = "http://www.w3.org/2007/app";
-  public static final String NAMESPACE_ATOM_2005 = "http://www.w3.org/2005/Atom";
-  public static final String NAMESPACE_D_2007_08 = "http://schemas.microsoft.com/ado/2007/08/dataservices";
-  public static final String NAMESPACE_M_2007_08 = "http://schemas.microsoft.com/ado/2007/08/dataservices/metadata";
-  public static final String NAMESPACE_EDMX_2007_06 = "http://schemas.microsoft.com/ado/2007/06/edmx";
-  public static final String NAMESPACE_REL_2007_08 = "http://schemas.microsoft.com/ado/2007/08/dataservices/related/";
-  public static final String NAMESPACE_REL_ASSOC_2007_08 =
-      "http://schemas.microsoft.com/ado/2007/08/dataservices/relatedlinks/";
-  public static final String NAMESPACE_SCHEME_2007_08 = "http://schemas.microsoft.com/ado/2007/08/dataservices/scheme";
-  public static final String NAMESPACE_XML_1998 = "http://www.w3.org/XML/1998/namespace";
-  public static final String PREFIX_EDM = "edm";
-  public static final String PREFIX_APP = "app";
-  public static final String PREFIX_ATOM = "atom";
-  public static final String PREFIX_D = "d";
-  public static final String PREFIX_M = "m";
-  public static final String PREFIX_XML = "xml";
-  public static final String PREFIX_EDMX = "edmx";
-  public static final String LINK_REL_SELF = "self";
-  public static final String LINK_REL_EDIT_MEDIA = "edit-media";
-  public static final String LINK_REL_EDIT = "edit";
-  public static final String LINK_REL_NEXT = "next";
-  public static final String DELIMITER = ".";
-
-  /**
-   * Get entity container by name
-   * <p>See {@link EdmEntityContainer} for more information.
-   * @param name
-   * @return {@link EdmEntityContainer}
-   * @throws EdmException
-   */
-  EdmEntityContainer getEntityContainer(String name) throws EdmException;
-
-  /**
-   * Get entity type by full qualified name
-   * <p>See {@link EdmEntityType} for more information.
-   * @param namespace
-   * @param name
-   * @return {@link EdmEntityType}
-   * @throws EdmException
-   */
-  EdmEntityType getEntityType(String namespace, String name) throws EdmException;
-
-  /**
-   * Get complex type by full qualified name
-   * <p>See {@link EdmComplexType} for more information.
-   * @param namespace
-   * @param name
-   * @return {@link EdmComplexType}
-   * @throws EdmException
-   */
-  EdmComplexType getComplexType(String namespace, String name) throws EdmException;
-
-  /**
-   * Get association by full qualified name
-   * <p>See {@link EdmAssociation} for more information.
-   * @param namespace
-   * @param name
-   * @return {@link EdmAssociation}
-   * @throws EdmException
-   */
-  EdmAssociation getAssociation(String namespace, String name) throws EdmException;
-
-  /**
-   * Get service metadata
-   * <p>See {@link EdmServiceMetadata} for more information.
-   * @return {@link EdmServiceMetadata}
-   */
-  EdmServiceMetadata getServiceMetadata();
-
-  /**
-   * Get default entity container
-   * <p>See {@link EdmEntityContainer} for more information.
-   * @return {@link EdmEntityContainer}
-   * @throws EdmException
-   */
-  EdmEntityContainer getDefaultEntityContainer() throws EdmException;
-
-  /**
-   * Get all contained EntitySets
-   * 
-   * @return a list of {@link EdmEntitySet}
-   * @throws EdmException
-   * */
-  List<EdmEntitySet> getEntitySets() throws EdmException;
-
-  /**
-   * Get all contained FunctionImports
-   * 
-   * @return a list of {@link EdmFunctionImport}
-   * @throws EdmException
-   */
-  List<EdmFunctionImport> getFunctionImports() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAction.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAction.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAction.java
deleted file mode 100644
index cc45a9c..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAction.java
+++ /dev/null
@@ -1,31 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL Action Element
- * <p>EdmAction can either be Cascade or None. Cascade implies that a delete operation on an entity also should delete
- * the relationship instances.
- * 
- */
-public enum EdmAction {
-
-  Cascade, None;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotatable.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotatable.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotatable.java
deleted file mode 100644
index 55120c5..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotatable.java
+++ /dev/null
@@ -1,35 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * EdmAnnotatable can be applied to CSDL elements as described in the Conceptual Schema Definition Language.
- * 
- */
-public interface EdmAnnotatable {
-
-  /**
-   * Get all annotations applied to an EDM element
-   * 
-   * @return {@link EdmAnnotations}
-   * @throws EdmException
-   */
-  EdmAnnotations getAnnotations() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationAttribute.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationAttribute.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationAttribute.java
deleted file mode 100644
index 2cc526d..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationAttribute.java
+++ /dev/null
@@ -1,56 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL AnnotationAttribute element.
- * <p>EdmAnnotationAttribute is a custom XML attribute which can be applied to a CSDL element.
- * 
- */
-public interface EdmAnnotationAttribute {
-
-  /**
-   * Get the namespace of the custom attribute
-   * 
-   * @return String
-   */
-  String getNamespace();
-
-  /**
-   * Get the prefix of the custom attribute
-   * 
-   * @return String
-   */
-  String getPrefix();
-
-  /**
-   * Get the name of the custom attribute
-   * 
-   * @return String
-   */
-  String getName();
-
-  /**
-   * Get the text of the custom attribute
-   * 
-   * @return String
-   */
-  String getText();
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationElement.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationElement.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationElement.java
deleted file mode 100644
index 5dabffd..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotationElement.java
+++ /dev/null
@@ -1,76 +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 org.apache.olingo.odata2.api.edm;
-
-import java.util.List;
-
-import org.apache.olingo.odata2.api.edm.provider.AnnotationAttribute;
-import org.apache.olingo.odata2.api.edm.provider.AnnotationElement;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL AnnotationElement element
- * <p>EdmAnnotationElement is a custom XML element which can be applied to a CSDL element.
- * 
- */
-public interface EdmAnnotationElement {
-
-  /**
-   * Get the namespace of the custom element
-   * 
-   * @return String
-   */
-  String getNamespace();
-
-  /**
-   * Get the prefix of the custom element
-   * 
-   * @return String
-   */
-  String getPrefix();
-
-  /**
-   * Get the name of the custom element
-   * 
-   * @return String
-   */
-  String getName();
-
-  /**
-   * Get the XML data of the custom element
-   * 
-   * @return String
-   */
-  String getText();
-
-  /**
-   * Get the child elements of the custom element
-   * 
-   * @return child elements of this {@link EdmAnnotationElement}
-   */
-  List<AnnotationElement> getChildElements();
-
-  /**
-   * Get the attributes of this custom element
-   * 
-   * @return the attributes of this {@link EdmAnnotationElement}
-   */
-  List<AnnotationAttribute> getAttributes();
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotations.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotations.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotations.java
deleted file mode 100644
index bb0b96b..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAnnotations.java
+++ /dev/null
@@ -1,62 +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 org.apache.olingo.odata2.api.edm;
-
-import java.util.List;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * EdmAnnotations holds all annotation attributes and elements for a specific CSDL element.
- * 
- */
-public interface EdmAnnotations {
-
-  /**
-   * Get all annotation elements for the CSDL element
-   * 
-   * @return List of {@link EdmAnnotationElement}
-   */
-  List<? extends EdmAnnotationElement> getAnnotationElements();
-
-  /**
-   * Get annotation element by full qualified name
-   * 
-   * @param name
-   * @param namespace
-   * @return String
-   */
-
-  EdmAnnotationElement getAnnotationElement(String name, String namespace);
-
-  /**
-   * Get all annotation attributes for the CSDL element
-   * 
-   * @return List of {@link EdmAnnotationAttribute}
-   */
-  List<? extends EdmAnnotationAttribute> getAnnotationAttributes();
-
-  /**
-   * Get annotation attribute by full qualified name
-   * 
-   * @param name
-   * @param namespace
-   * @return String
-   */
-  EdmAnnotationAttribute getAnnotationAttribute(String name, String namespace);
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociation.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociation.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociation.java
deleted file mode 100644
index 5f7c1bc..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociation.java
+++ /dev/null
@@ -1,58 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL Association element
- * 
- * <p>EdmAssociation defines the relationship of two entity types.
- * 
- */
-public interface EdmAssociation extends EdmType {
-
-  /**
-   * Get the {@link EdmAssociationEnd} by role
-   * @param role
-   * @return {@link EdmAssociationEnd}
-   * @throws EdmException
-   */
-  EdmAssociationEnd getEnd(String role) throws EdmException;
-
-  /**
-   * Get the {@link EdmAssociationEnd} for end1
-   * @return {@link EdmAssociationEnd}
-   * @throws EdmException
-   */
-  EdmAssociationEnd getEnd1() throws EdmException;
-
-  /**
-   * Get the {@link EdmAssociationEnd} for end2
-   * @return {@link EdmAssociationEnd}
-   * @throws EdmException
-   */
-  EdmAssociationEnd getEnd2() throws EdmException;
-
-  /**
-   * Get the {@link EdmReferentialConstraint}
-   * @return {@link EdmReferentialConstraint}
-   * @throws EdmException
-   */
-  EdmReferentialConstraint getReferentialConstraint() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationEnd.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationEnd.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationEnd.java
deleted file mode 100644
index 8dc439c..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationEnd.java
+++ /dev/null
@@ -1,46 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL AssociationEnd element
- * 
- * <p>EdmAssociationEnd defines one side of the relationship of two entity types.
- * 
- */
-public interface EdmAssociationEnd {
-
-  /**
-   * @return the role of this {@link EdmAssociationEnd} as a String.
-   */
-  String getRole();
-
-  /**
-   * @return {@link EdmEntityType} this association end points to.
-   * @throws EdmException
-   */
-  EdmEntityType getEntityType() throws EdmException;
-
-  /**
-   * See {@link EdmMultiplicity} for more information about possible multiplicities.
-   * @return {@link EdmMultiplicity}
-   */
-  EdmMultiplicity getMultiplicity();
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSet.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSet.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSet.java
deleted file mode 100644
index 0dd20ca..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSet.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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL AssociationSet element
- * 
- * <p>EdmAssociationSet defines the relationship of two entity sets.
- * 
- */
-public interface EdmAssociationSet extends EdmNamed {
-
-  /**
-   * Get the association
-   * 
-   * @return {@link EdmAssociation}
-   * @throws EdmException
-   */
-  EdmAssociation getAssociation() throws EdmException;
-
-  /**
-   * Get the association set end
-   * 
-   * @param role
-   * @return {@link EdmAssociationSetEnd}
-   * @throws EdmException
-   */
-  EdmAssociationSetEnd getEnd(String role) throws EdmException;
-
-  /**
-   * Get the entity container the association set is located in
-   * 
-   * @return {@link EdmEntityContainer}
-   * @throws EdmException
-   */
-  EdmEntityContainer getEntityContainer() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSetEnd.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSetEnd.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSetEnd.java
deleted file mode 100644
index 3acb0a1..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmAssociationSetEnd.java
+++ /dev/null
@@ -1,44 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * A CSDL AssociationSetEnd element
- * 
- * <p>EdmAssociationSetEnd defines one side of the relationship of two entity sets.
- * 
- */
-public interface EdmAssociationSetEnd {
-
-  /**
-   * Get the role name
-   * 
-   * @return String
-   */
-  String getRole();
-
-  /**
-   * Get the entity set
-   * 
-   * @return {@link EdmEntitySet}
-   * @throws EdmException
-   */
-  EdmEntitySet getEntitySet() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmComplexType.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmComplexType.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmComplexType.java
deleted file mode 100644
index 27caf4f..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmComplexType.java
+++ /dev/null
@@ -1,32 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * <p>A CSDL ComplexType element.</p>
- * <p>EdmComplexType holds a set of related information like {@link EdmSimpleType} properties and EdmComplexType
- * properties.
- * 
- * @org.apache.olingo.odata2.DoNotImplement
- */
-public interface EdmComplexType extends EdmStructuralType {
-
-  @Override
-  EdmComplexType getBaseType() throws EdmException;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmConcurrencyMode.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmConcurrencyMode.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmConcurrencyMode.java
deleted file mode 100644
index 540353f..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmConcurrencyMode.java
+++ /dev/null
@@ -1,31 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * EdmConcurrencyMode can be applied to any primitive Entity Data Model (EDM) type.
- * <p>Possible values are "None", which is the default, and "Fixed". Fixed implies that the property should be used for
- * optimistic concurrency checks.
- * 
- */
-public enum EdmConcurrencyMode {
-
-  None, Fixed;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmContentKind.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmContentKind.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmContentKind.java
deleted file mode 100644
index 51ff83c..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmContentKind.java
+++ /dev/null
@@ -1,31 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * EdmContentType is used for Feed Customization.
- * <p>It specifies the content type of the value of the property being mapped via a customizable feed mapping.
- * This value can be "text", "html" or "xhtml".
- * 
- */
-public enum EdmContentKind {
-
-  text, html, xhtml;
-}

http://git-wip-us.apache.org/repos/asf/incubator-olingo-odata2/blob/57599da6/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmCustomizableFeedMappings.java
----------------------------------------------------------------------
diff --git a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmCustomizableFeedMappings.java b/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmCustomizableFeedMappings.java
deleted file mode 100644
index 643383a..0000000
--- a/odata-api/src/main/java/org/apache/olingo/odata2/api/edm/EdmCustomizableFeedMappings.java
+++ /dev/null
@@ -1,69 +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 org.apache.olingo.odata2.api.edm;
-
-/**
- * @org.apache.olingo.odata2.DoNotImplement
- * Customizable Feed property mappings for the AtomPub Format as defined in the OData specification.
- * 
- */
-public interface EdmCustomizableFeedMappings {
-
-  /**
-   * Get the information if the property should be kept in the content
-   * 
-   * @return <code>true</code> if the property must be kept in the content
-   */
-  public Boolean isFcKeepInContent();
-
-  /**
-   * Get the content kind
-   * 
-   * @return {@link EdmContentKind}
-   */
-  public EdmContentKind getFcContentKind();
-
-  /**
-   * Get the XML namespace prefix
-   * 
-   * @return String
-   */
-  public String getFcNsPrefix();
-
-  /**
-   * Get the XML namespace URI
-   * 
-   * @return String
-   */
-  public String getFcNsUri();
-
-  /**
-   * Get the source path
-   * 
-   * @return String
-   */
-  public String getFcSourcePath();
-
-  /**
-   * Get the target path
-   * 
-   * @return String
-   */
-  public String getFcTargetPath();
-}