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 2015/11/28 06:30:42 UTC

[34/47] olingo-odata4 git commit: [OLINGO-713] Batch and Deep Insert Tutorial

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEdmProvider.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEdmProvider.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEdmProvider.java
new file mode 100644
index 0000000..381db09
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEdmProvider.java
@@ -0,0 +1,215 @@
+/*
+ * 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 myservice.mynamespace.service;
+
+import java.util.ArrayList;
+import java.util.Arrays;
+import java.util.List;
+
+import org.apache.olingo.commons.api.edm.EdmPrimitiveTypeKind;
+import org.apache.olingo.commons.api.edm.FullQualifiedName;
+import org.apache.olingo.commons.api.edm.provider.CsdlAbstractEdmProvider;
+import org.apache.olingo.commons.api.edm.provider.CsdlEntityContainer;
+import org.apache.olingo.commons.api.edm.provider.CsdlEntityContainerInfo;
+import org.apache.olingo.commons.api.edm.provider.CsdlEntitySet;
+import org.apache.olingo.commons.api.edm.provider.CsdlEntityType;
+import org.apache.olingo.commons.api.edm.provider.CsdlNavigationProperty;
+import org.apache.olingo.commons.api.edm.provider.CsdlNavigationPropertyBinding;
+import org.apache.olingo.commons.api.edm.provider.CsdlProperty;
+import org.apache.olingo.commons.api.edm.provider.CsdlPropertyRef;
+import org.apache.olingo.commons.api.edm.provider.CsdlSchema;
+
+/*
+ * this class is supposed to declare the metadata of the OData service
+ * it is invoked by the Olingo framework e.g. when the metadata document of the service is invoked
+ * e.g. http://localhost:8080/ExampleService1/ExampleService1.svc/$metadata
+ */
+public class DemoEdmProvider extends CsdlAbstractEdmProvider {
+
+  // Service Namespace
+  public static final String NAMESPACE = "OData.Demo";
+
+  // EDM Container
+  public static final String CONTAINER_NAME = "Container";
+  public static final FullQualifiedName CONTAINER = new FullQualifiedName(NAMESPACE, CONTAINER_NAME);
+
+  // Entity Types Names
+  public static final String ET_PRODUCT_NAME = "Product";
+  public static final FullQualifiedName ET_PRODUCT_FQN = new FullQualifiedName(NAMESPACE, ET_PRODUCT_NAME);
+
+  public static final String ET_CATEGORY_NAME = "Category";
+  public static final FullQualifiedName ET_CATEGORY_FQN = new FullQualifiedName(NAMESPACE, ET_CATEGORY_NAME);
+  
+  // Entity Set Names
+  public static final String ES_PRODUCTS_NAME = "Products";
+  public static final String ES_CATEGORIES_NAME = "Categories";
+  
+  public CsdlEntityType getEntityType(FullQualifiedName entityTypeName) {
+
+    // this method is called for each EntityType that are configured in the Schema
+    CsdlEntityType entityType = null;
+
+    if (entityTypeName.equals(ET_PRODUCT_FQN)) {
+      // create EntityType properties
+      CsdlProperty id = new CsdlProperty().setName("ID")
+                                          .setType(EdmPrimitiveTypeKind.Int32.getFullQualifiedName());
+      CsdlProperty name = new CsdlProperty().setName("Name")
+                                            .setType(EdmPrimitiveTypeKind.String.getFullQualifiedName());
+      CsdlProperty description = new CsdlProperty().setName("Description")
+                                                   .setType(EdmPrimitiveTypeKind.String.getFullQualifiedName());
+
+      // create PropertyRef for Key element
+      CsdlPropertyRef propertyRef = new CsdlPropertyRef();
+      propertyRef.setName("ID");
+
+      // navigation property: many-to-one, null not allowed (product must have a category)
+      CsdlNavigationProperty navProp = new CsdlNavigationProperty().setName("Category")
+                                                                   .setType(ET_CATEGORY_FQN).setNullable(true)
+                                                                   .setPartner("Products");
+      List<CsdlNavigationProperty> navPropList = new ArrayList<CsdlNavigationProperty>();
+      navPropList.add(navProp);
+
+      // configure EntityType
+      entityType = new CsdlEntityType();
+      entityType.setName(ET_PRODUCT_NAME);
+      entityType.setProperties(Arrays.asList(id, name, description));
+      entityType.setKey(Arrays.asList(propertyRef));
+      entityType.setNavigationProperties(navPropList);
+
+    } else if (entityTypeName.equals(ET_CATEGORY_FQN)) {
+      // create EntityType properties
+      CsdlProperty id = new CsdlProperty().setName("ID")
+                                          .setType(EdmPrimitiveTypeKind.Int32.getFullQualifiedName());
+      CsdlProperty name = new CsdlProperty().setName("Name")
+                                            .setType(EdmPrimitiveTypeKind.String.getFullQualifiedName());
+
+      // create PropertyRef for Key element
+      CsdlPropertyRef propertyRef = new CsdlPropertyRef();
+      propertyRef.setName("ID");
+
+      // navigation property: one-to-many
+      CsdlNavigationProperty navProp = new CsdlNavigationProperty().setName("Products")
+                                                                   .setType(ET_PRODUCT_FQN).setCollection(true)
+                                                                   .setPartner("Category");
+      List<CsdlNavigationProperty> navPropList = new ArrayList<CsdlNavigationProperty>();
+      navPropList.add(navProp);
+
+      // configure EntityType
+      entityType = new CsdlEntityType();
+      entityType.setName(ET_CATEGORY_NAME);
+      entityType.setProperties(Arrays.asList(id, name));
+      entityType.setKey(Arrays.asList(propertyRef));
+      entityType.setNavigationProperties(navPropList);
+    }
+
+    return entityType;
+  }
+
+  @Override
+  public CsdlEntitySet getEntitySet(FullQualifiedName entityContainer, String entitySetName) {
+
+    CsdlEntitySet entitySet = null;
+
+    if (entityContainer.equals(CONTAINER)) {
+
+      if (entitySetName.equals(ES_PRODUCTS_NAME)) {
+
+        entitySet = new CsdlEntitySet();
+        entitySet.setName(ES_PRODUCTS_NAME);
+        entitySet.setType(ET_PRODUCT_FQN);
+
+        // navigation
+        CsdlNavigationPropertyBinding navPropBinding = new CsdlNavigationPropertyBinding();
+        navPropBinding.setTarget("Categories"); // the target entity set, where the navigation property points to
+        navPropBinding.setPath("Category"); // the path from entity type to navigation property
+        List<CsdlNavigationPropertyBinding> navPropBindingList = new ArrayList<CsdlNavigationPropertyBinding>();
+        navPropBindingList.add(navPropBinding);
+        entitySet.setNavigationPropertyBindings(navPropBindingList);
+
+      } else if (entitySetName.equals(ES_CATEGORIES_NAME)) {
+
+        entitySet = new CsdlEntitySet();
+        entitySet.setName(ES_CATEGORIES_NAME);
+        entitySet.setType(ET_CATEGORY_FQN);
+
+        // navigation
+        CsdlNavigationPropertyBinding navPropBinding = new CsdlNavigationPropertyBinding();
+        navPropBinding.setTarget("Products"); // the target entity set, where the navigation property points to
+        navPropBinding.setPath("Products"); // the path from entity type to navigation property
+        List<CsdlNavigationPropertyBinding> navPropBindingList = new ArrayList<CsdlNavigationPropertyBinding>();
+        navPropBindingList.add(navPropBinding);
+        entitySet.setNavigationPropertyBindings(navPropBindingList);
+      }
+    }
+
+    return entitySet;
+
+  }
+
+  @Override
+  public List<CsdlSchema> getSchemas() {
+
+    // create Schema
+    CsdlSchema schema = new CsdlSchema();
+    schema.setNamespace(NAMESPACE);
+
+    // add EntityTypes
+    List<CsdlEntityType> entityTypes = new ArrayList<CsdlEntityType>();
+    entityTypes.add(getEntityType(ET_PRODUCT_FQN));
+    entityTypes.add(getEntityType(ET_CATEGORY_FQN));
+    schema.setEntityTypes(entityTypes);
+    
+    // add EntityContainer
+    schema.setEntityContainer(getEntityContainer());
+
+    // finally
+    List<CsdlSchema> schemas = new ArrayList<CsdlSchema>();
+    schemas.add(schema);
+
+    return schemas;
+  }
+  
+  public CsdlEntityContainer getEntityContainer() {
+    // create EntitySets
+    List<CsdlEntitySet> entitySets = new ArrayList<CsdlEntitySet>();
+    entitySets.add(getEntitySet(CONTAINER, ES_PRODUCTS_NAME));
+    entitySets.add(getEntitySet(CONTAINER, ES_CATEGORIES_NAME));
+    
+    // create EntityContainer
+    CsdlEntityContainer entityContainer = new CsdlEntityContainer();
+    entityContainer.setName(CONTAINER_NAME);
+    entityContainer.setEntitySets(entitySets);
+    
+    return entityContainer;
+
+  }
+
+  @Override
+  public CsdlEntityContainerInfo getEntityContainerInfo(FullQualifiedName entityContainerName) {
+
+    // This method is invoked when displaying the service document at
+    // e.g. http://localhost:8080/DemoService/DemoService.svc
+    if (entityContainerName == null || entityContainerName.equals(CONTAINER)) {
+      CsdlEntityContainerInfo entityContainerInfo = new CsdlEntityContainerInfo();
+      entityContainerInfo.setContainerName(CONTAINER);
+      return entityContainerInfo;
+    }
+    return null;
+  }
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityCollectionProcessor.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityCollectionProcessor.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityCollectionProcessor.java
new file mode 100644
index 0000000..ea43c70
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityCollectionProcessor.java
@@ -0,0 +1,149 @@
+/*
+ * 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 myservice.mynamespace.service;
+
+import java.util.List;
+import java.util.Locale;
+
+import org.apache.olingo.commons.api.data.ContextURL;
+import org.apache.olingo.commons.api.data.Entity;
+import org.apache.olingo.commons.api.data.EntityCollection;
+import org.apache.olingo.commons.api.edm.EdmEntitySet;
+import org.apache.olingo.commons.api.edm.EdmEntityType;
+import org.apache.olingo.commons.api.edm.EdmNavigationProperty;
+import org.apache.olingo.commons.api.format.ContentType;
+import org.apache.olingo.commons.api.http.HttpHeader;
+import org.apache.olingo.commons.api.http.HttpStatusCode;
+import org.apache.olingo.server.api.OData;
+import org.apache.olingo.server.api.ODataApplicationException;
+import org.apache.olingo.server.api.ODataRequest;
+import org.apache.olingo.server.api.ODataResponse;
+import org.apache.olingo.server.api.ServiceMetadata;
+import org.apache.olingo.server.api.processor.EntityCollectionProcessor;
+import org.apache.olingo.server.api.serializer.EntityCollectionSerializerOptions;
+import org.apache.olingo.server.api.serializer.ODataSerializer;
+import org.apache.olingo.server.api.serializer.SerializerException;
+import org.apache.olingo.server.api.serializer.SerializerResult;
+import org.apache.olingo.server.api.uri.UriInfo;
+import org.apache.olingo.server.api.uri.UriParameter;
+import org.apache.olingo.server.api.uri.UriResource;
+import org.apache.olingo.server.api.uri.UriResourceEntitySet;
+import org.apache.olingo.server.api.uri.UriResourceNavigation;
+
+import myservice.mynamespace.data.Storage;
+import myservice.mynamespace.util.Util;
+
+public class DemoEntityCollectionProcessor implements EntityCollectionProcessor {
+
+
+  private OData odata;
+  private ServiceMetadata serviceMetadata;
+  // our database-mock
+  private Storage storage;
+
+  public DemoEntityCollectionProcessor(Storage storage) {
+    this.storage = storage;
+  }
+
+  public void init(OData odata, ServiceMetadata serviceMetadata) {
+    this.odata = odata;
+    this.serviceMetadata = serviceMetadata;
+  }
+
+  /*
+   * This method is invoked when a collection of entities has to be read.
+   * In our example, this can be either a "normal" read operation, or a navigation:
+   * 
+   * Example for "normal" read entity set operation:
+   * http://localhost:8080/DemoService/DemoService.svc/Categories
+   * 
+   * Example for navigation
+   * http://localhost:8080/DemoService/DemoService.svc/Categories(3)/Products
+   */
+  public void readEntityCollection(ODataRequest request, ODataResponse response,
+      UriInfo uriInfo, ContentType responseFormat)
+      throws ODataApplicationException, SerializerException {
+    
+    EdmEntitySet responseEdmEntitySet = null; // we'll need this to build the ContextURL
+    EntityCollection responseEntityCollection = null; // we'll need this to set the response body
+
+    // 1st retrieve the requested EntitySet from the uriInfo (representation of the parsed URI)
+    List<UriResource> resourceParts = uriInfo.getUriResourceParts();
+    int segmentCount = resourceParts.size();
+
+    UriResource uriResource = resourceParts.get(0); // in our example, the first segment is the EntitySet
+    if (!(uriResource instanceof UriResourceEntitySet)) {
+      throw new ODataApplicationException("Only EntitySet is supported",
+          HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+    }
+
+    UriResourceEntitySet uriResourceEntitySet = (UriResourceEntitySet) uriResource;
+    EdmEntitySet startEdmEntitySet = uriResourceEntitySet.getEntitySet();
+
+    if (segmentCount == 1) { // this is the case for: DemoService/DemoService.svc/Categories
+      responseEdmEntitySet = startEdmEntitySet; // the response body is built from the first (and only) entitySet
+
+      // 2nd: fetch the data from backend for this requested EntitySetName and deliver as EntitySet
+      responseEntityCollection = storage.readEntitySetData(startEdmEntitySet);
+    } else if (segmentCount == 2) { // in case of navigation: DemoService.svc/Categories(3)/Products
+
+      UriResource lastSegment = resourceParts.get(1); // in our example we don't support more complex URIs
+      if (lastSegment instanceof UriResourceNavigation) {
+        UriResourceNavigation uriResourceNavigation = (UriResourceNavigation) lastSegment;
+        EdmNavigationProperty edmNavigationProperty = uriResourceNavigation.getProperty();
+        // from Categories(1) to Products
+        responseEdmEntitySet = Util.getNavigationTargetEntitySet(startEdmEntitySet, edmNavigationProperty);
+
+        // 2nd: fetch the data from backend
+        // first fetch the entity where the first segment of the URI points to
+        List<UriParameter> keyPredicates = uriResourceEntitySet.getKeyPredicates();
+        // e.g. for Categories(3)/Products we have to find the single entity: Category with ID 3
+        Entity sourceEntity = storage.readEntityData(startEdmEntitySet, keyPredicates);
+        // error handling for e.g. DemoService.svc/Categories(99)/Products
+        if (sourceEntity == null) {
+          throw new ODataApplicationException("Entity not found.",
+              HttpStatusCode.NOT_FOUND.getStatusCode(), Locale.ROOT);
+        }
+        // then fetch the entity collection where the entity navigates to
+        // note: we don't need to check uriResourceNavigation.isCollection(),
+        // because we are the EntityCollectionProcessor
+        responseEntityCollection = storage.getRelatedEntityCollection(sourceEntity, uriResourceNavigation);
+      }
+    } else { // this would be the case for e.g. Products(1)/Category/Products
+      throw new ODataApplicationException("Not supported",
+          HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+    }
+
+    // 3rd: create and configure a serializer
+    ContextURL contextUrl = ContextURL.with().entitySet(responseEdmEntitySet).build();
+    final String id = request.getRawBaseUri() + "/" + responseEdmEntitySet.getName();
+    EntityCollectionSerializerOptions opts = EntityCollectionSerializerOptions.with()
+        .contextURL(contextUrl).id(id).build();
+    EdmEntityType edmEntityType = responseEdmEntitySet.getEntityType();
+
+    ODataSerializer serializer = odata.createSerializer(responseFormat);
+    SerializerResult serializerResult = serializer.entityCollection(serviceMetadata, edmEntityType,
+        responseEntityCollection, opts);
+
+    // 4th: configure the response object: set the body, headers and status code
+    response.setContent(serializerResult.getContent());
+    response.setStatusCode(HttpStatusCode.OK.getStatusCode());
+    response.setHeader(HttpHeader.CONTENT_TYPE, responseFormat.toContentTypeString());
+  }
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityProcessor.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityProcessor.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityProcessor.java
new file mode 100644
index 0000000..fde3ece
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoEntityProcessor.java
@@ -0,0 +1,242 @@
+/*
+ * 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 myservice.mynamespace.service;
+
+import java.io.InputStream;
+import java.util.List;
+import java.util.Locale;
+
+import org.apache.olingo.commons.api.data.ContextURL;
+import org.apache.olingo.commons.api.data.ContextURL.Suffix;
+import org.apache.olingo.commons.api.data.Entity;
+import org.apache.olingo.commons.api.edm.EdmEntitySet;
+import org.apache.olingo.commons.api.edm.EdmEntityType;
+import org.apache.olingo.commons.api.edm.EdmNavigationProperty;
+import org.apache.olingo.commons.api.format.ContentType;
+import org.apache.olingo.commons.api.http.HttpHeader;
+import org.apache.olingo.commons.api.http.HttpMethod;
+import org.apache.olingo.commons.api.http.HttpStatusCode;
+import org.apache.olingo.server.api.OData;
+import org.apache.olingo.server.api.ODataApplicationException;
+import org.apache.olingo.server.api.ODataRequest;
+import org.apache.olingo.server.api.ODataResponse;
+import org.apache.olingo.server.api.ServiceMetadata;
+import org.apache.olingo.server.api.deserializer.DeserializerException;
+import org.apache.olingo.server.api.deserializer.DeserializerResult;
+import org.apache.olingo.server.api.deserializer.ODataDeserializer;
+import org.apache.olingo.server.api.processor.EntityProcessor;
+import org.apache.olingo.server.api.serializer.EntitySerializerOptions;
+import org.apache.olingo.server.api.serializer.ODataSerializer;
+import org.apache.olingo.server.api.serializer.SerializerException;
+import org.apache.olingo.server.api.serializer.SerializerResult;
+import org.apache.olingo.server.api.uri.UriInfo;
+import org.apache.olingo.server.api.uri.UriParameter;
+import org.apache.olingo.server.api.uri.UriResource;
+import org.apache.olingo.server.api.uri.UriResourceEntitySet;
+import org.apache.olingo.server.api.uri.UriResourceNavigation;
+
+import myservice.mynamespace.data.Storage;
+import myservice.mynamespace.util.Util;
+
+public class DemoEntityProcessor implements EntityProcessor {
+
+	private OData odata;
+	private Storage storage;
+	private ServiceMetadata serviceMetadata;
+
+	public DemoEntityProcessor(Storage storage) {
+		this.storage = storage;
+	}
+
+	public void init(OData odata, ServiceMetadata serviceMetadata) {
+		this.odata = odata;
+		this.serviceMetadata = serviceMetadata;
+	}
+
+	
+  /**
+   * This method is invoked when a single entity has to be read.
+   * In our example, this can be either a "normal" read operation, or a navigation:
+   * 
+   * Example for "normal" read operation:
+   * http://localhost:8080/DemoService/DemoService.svc/Products(1)
+   * 
+   * Example for navigation
+   * http://localhost:8080/DemoService/DemoService.svc/Products(1)/Category
+   */
+  public void readEntity(ODataRequest request, ODataResponse response, UriInfo uriInfo, ContentType responseFormat)
+      throws ODataApplicationException, SerializerException {
+    
+    EdmEntityType responseEdmEntityType = null; // we'll need this to build the ContextURL
+    Entity responseEntity = null; // required for serialization of the response body
+    EdmEntitySet responseEdmEntitySet = null; // we need this for building the contextUrl
+
+    // 1st step: retrieve the requested Entity: can be "normal" read operation, or navigation (to-one)
+    List<UriResource> resourceParts = uriInfo.getUriResourceParts();
+    int segmentCount = resourceParts.size();
+    
+    UriResource uriResource = resourceParts.get(0); // in our example, the first segment is the EntitySet
+    UriResourceEntitySet uriResourceEntitySet = (UriResourceEntitySet) uriResource;
+    EdmEntitySet startEdmEntitySet = uriResourceEntitySet.getEntitySet();
+
+    // Analyze the URI segments
+    if (segmentCount == 1) { // no navigation
+      responseEdmEntityType = startEdmEntitySet.getEntityType();
+      responseEdmEntitySet = startEdmEntitySet; // since we have only one segment
+
+      // 2. step: retrieve the data from backend
+      List<UriParameter> keyPredicates = uriResourceEntitySet.getKeyPredicates();
+      responseEntity = storage.readEntityData(startEdmEntitySet, keyPredicates);
+    } else if (segmentCount == 2) { // navigation
+      UriResource navSegment = resourceParts.get(1); // in our example we don't support more complex URIs
+      if (navSegment instanceof UriResourceNavigation) {
+        UriResourceNavigation uriResourceNavigation = (UriResourceNavigation) navSegment;
+        EdmNavigationProperty edmNavigationProperty = uriResourceNavigation.getProperty();
+        responseEdmEntityType = edmNavigationProperty.getType();
+        // contextURL displays the last segment
+        responseEdmEntitySet = Util.getNavigationTargetEntitySet(startEdmEntitySet, edmNavigationProperty);
+
+        // 2nd: fetch the data from backend.
+        // e.g. for the URI: Products(1)/Category we have to find the correct Category entity
+        List<UriParameter> keyPredicates = uriResourceEntitySet.getKeyPredicates();
+        // e.g. for Products(1)/Category we have to find first the Products(1)
+        Entity sourceEntity = storage.readEntityData(startEdmEntitySet, keyPredicates);
+        responseEntity = storage.getRelatedEntity(sourceEntity, uriResourceNavigation);
+      }
+    } else {
+      // this would be the case for e.g. Products(1)/Category/Products(1)/Category
+      throw new ODataApplicationException("Not supported", HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+    }
+
+    if (responseEntity == null) {
+      // this is the case for e.g. DemoService.svc/Categories(4) or DemoService.svc/Categories(3)/Products(999)
+      throw new ODataApplicationException("Nothing found.", HttpStatusCode.NOT_FOUND.getStatusCode(), Locale.ROOT);
+    }
+
+    // 3. serialize
+    ContextURL contextUrl = ContextURL.with().entitySet(responseEdmEntitySet).suffix(Suffix.ENTITY).build();
+    EntitySerializerOptions opts = EntitySerializerOptions.with().contextURL(contextUrl).build();
+
+    ODataSerializer serializer = odata.createSerializer(responseFormat);
+    SerializerResult serializerResult = serializer.entity(serviceMetadata,
+        responseEdmEntityType, responseEntity, opts);
+
+    // 4. configure the response object
+    response.setContent(serializerResult.getContent());
+    response.setStatusCode(HttpStatusCode.OK.getStatusCode());
+    response.setHeader(HttpHeader.CONTENT_TYPE, responseFormat.toContentTypeString());
+  }
+
+  /*
+	 * Example request:
+	 * 
+	 * POST URL: http://localhost:8080/DemoService/DemoService.svc/Products
+	 * Header: Content-Type: application/json; odata.metadata=minimal
+	 * Request body:
+	 	{
+			"ID":3,
+			"Name":"Ergo Screen",
+			"Description":"17 Optimum Resolution 1024 x 768 @ 85Hz, resolution 1280 x 960"
+		}
+	 * */
+	public void createEntity(ODataRequest request, ODataResponse response, UriInfo uriInfo,
+													 ContentType requestFormat, ContentType responseFormat)
+				throws ODataApplicationException, DeserializerException, SerializerException {
+		
+		// 1. Retrieve the entity type from the URI 
+		EdmEntitySet edmEntitySet = Util.getEdmEntitySet(uriInfo);
+		EdmEntityType edmEntityType = edmEntitySet.getEntityType();
+
+		// 2. create the data in backend 
+		// 2.1. retrieve the payload from the POST request for the entity to create and deserialize it
+		InputStream requestInputStream = request.getBody();
+		ODataDeserializer deserializer = odata.createDeserializer(requestFormat);
+		DeserializerResult result = deserializer.entity(requestInputStream, edmEntityType);
+		Entity requestEntity = result.getEntity();
+		// 2.2 do the creation in backend, which returns the newly created entity
+		Entity createdEntity = null;
+		
+		try {
+		  storage.beginTransaction();
+		  createdEntity = storage.createEntityData(edmEntitySet, requestEntity, request.getRawBaseUri());
+		  storage.commitTransaction();
+		} catch( ODataApplicationException e ) {
+		  storage.rollbackTransaction();
+		  throw e;
+		}
+		  
+		  // 3. serialize the response (we have to return the created entity)
+		ContextURL contextUrl = ContextURL.with().entitySet(edmEntitySet).build(); 
+		EntitySerializerOptions options = EntitySerializerOptions.with().contextURL(contextUrl).build(); // expand and select currently not supported 
+		
+		ODataSerializer serializer = odata.createSerializer(responseFormat);
+		SerializerResult serializedResponse = serializer.entity(serviceMetadata, edmEntityType, createdEntity, options);
+		
+		//4. configure the response object
+		response.setContent(serializedResponse.getContent());
+		response.setStatusCode(HttpStatusCode.CREATED.getStatusCode());
+		response.setHeader(HttpHeader.CONTENT_TYPE, responseFormat.toContentTypeString());
+	}
+
+	
+	public void updateEntity(ODataRequest request, ODataResponse response, UriInfo uriInfo,
+                           ContentType requestFormat, ContentType responseFormat)
+							throws ODataApplicationException, DeserializerException, SerializerException {
+		
+		// 1. Retrieve the entity set which belongs to the requested entity 
+		List<UriResource> resourcePaths = uriInfo.getUriResourceParts();
+		// Note: only in our example we can assume that the first segment is the EntitySet
+		UriResourceEntitySet uriResourceEntitySet = (UriResourceEntitySet) resourcePaths.get(0); 
+		EdmEntitySet edmEntitySet = uriResourceEntitySet.getEntitySet();
+		EdmEntityType edmEntityType = edmEntitySet.getEntityType();
+
+		// 2. update the data in backend
+		// 2.1. retrieve the payload from the PUT request for the entity to be updated 
+		InputStream requestInputStream = request.getBody();
+		ODataDeserializer deserializer = odata.createDeserializer(requestFormat);
+		DeserializerResult result = deserializer.entity(requestInputStream, edmEntityType);
+		Entity requestEntity = result.getEntity();
+		// 2.2 do the modification in backend
+		List<UriParameter> keyPredicates = uriResourceEntitySet.getKeyPredicates();
+		// Note that this updateEntity()-method is invoked for both PUT or PATCH operations
+		HttpMethod httpMethod = request.getMethod();
+		storage.updateEntityData(edmEntitySet, keyPredicates, requestEntity, httpMethod);
+		
+		//3. configure the response object
+		response.setStatusCode(HttpStatusCode.NO_CONTENT.getStatusCode());
+	}
+
+	
+	public void deleteEntity(ODataRequest request, ODataResponse response, UriInfo uriInfo)
+          throws ODataApplicationException {
+		
+		// 1. Retrieve the entity set which belongs to the requested entity 
+		List<UriResource> resourcePaths = uriInfo.getUriResourceParts();
+		// Note: only in our example we can assume that the first segment is the EntitySet
+		UriResourceEntitySet uriResourceEntitySet = (UriResourceEntitySet) resourcePaths.get(0); 
+		EdmEntitySet edmEntitySet = uriResourceEntitySet.getEntitySet();
+
+		// 2. delete the data in backend
+		List<UriParameter> keyPredicates = uriResourceEntitySet.getKeyPredicates();
+		storage.deleteEntityData(edmEntitySet, keyPredicates);
+		
+		//3. configure the response object
+		response.setStatusCode(HttpStatusCode.NO_CONTENT.getStatusCode());
+	}
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoPrimitiveProcessor.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoPrimitiveProcessor.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoPrimitiveProcessor.java
new file mode 100644
index 0000000..8766b8d
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/service/DemoPrimitiveProcessor.java
@@ -0,0 +1,146 @@
+/*
+ * 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 myservice.mynamespace.service;
+
+import java.util.List;
+import java.util.Locale;
+
+import myservice.mynamespace.data.Storage;
+
+import org.apache.olingo.commons.api.data.ContextURL;
+import org.apache.olingo.commons.api.data.Entity;
+import org.apache.olingo.commons.api.data.Property;
+import org.apache.olingo.commons.api.edm.EdmEntitySet;
+import org.apache.olingo.commons.api.edm.EdmPrimitiveType;
+import org.apache.olingo.commons.api.edm.EdmProperty;
+import org.apache.olingo.commons.api.format.ContentType;
+import org.apache.olingo.commons.api.http.HttpHeader;
+import org.apache.olingo.commons.api.http.HttpStatusCode;
+import org.apache.olingo.server.api.OData;
+import org.apache.olingo.server.api.ODataApplicationException;
+import org.apache.olingo.server.api.ODataRequest;
+import org.apache.olingo.server.api.ODataResponse;
+import org.apache.olingo.server.api.ServiceMetadata;
+import org.apache.olingo.server.api.deserializer.DeserializerException;
+import org.apache.olingo.server.api.processor.PrimitiveProcessor;
+import org.apache.olingo.server.api.serializer.ODataSerializer;
+import org.apache.olingo.server.api.serializer.PrimitiveSerializerOptions;
+import org.apache.olingo.server.api.serializer.SerializerException;
+import org.apache.olingo.server.api.serializer.SerializerResult;
+import org.apache.olingo.server.api.uri.UriInfo;
+import org.apache.olingo.server.api.uri.UriParameter;
+import org.apache.olingo.server.api.uri.UriResource;
+import org.apache.olingo.server.api.uri.UriResourceEntitySet;
+import org.apache.olingo.server.api.uri.UriResourceProperty;
+
+public class DemoPrimitiveProcessor implements PrimitiveProcessor {
+
+	private OData odata;
+	private Storage storage;
+  private ServiceMetadata serviceMetadata;
+
+	public DemoPrimitiveProcessor(Storage storage) {
+		this.storage = storage;
+	}
+
+	public void init(OData odata, ServiceMetadata serviceMetadata) {
+		this.odata = odata;
+    this.serviceMetadata = serviceMetadata;
+	}
+	
+	/*
+	 * In our example, the URL would be: http://localhost:8080/DemoService/DemoService.svc/Products(1)/Name
+	 * and the response:
+	 * {
+	 *	  @odata.context: "$metadata#Products/Name",
+	 *	  value: "Notebook Basic 15"
+	 * }
+	 * */
+	public void readPrimitive(ODataRequest request, ODataResponse response, 
+								UriInfo uriInfo, ContentType responseFormat) 
+								throws ODataApplicationException, SerializerException {
+
+		// 1. Retrieve info from URI
+		// 1.1. retrieve the info about the requested entity set 
+		List<UriResource> resourceParts = uriInfo.getUriResourceParts();
+		// Note: only in our example we can rely that the first segment is the EntitySet
+		UriResourceEntitySet uriEntityset = (UriResourceEntitySet) resourceParts.get(0); 
+		EdmEntitySet edmEntitySet = uriEntityset.getEntitySet();
+		// the key for the entity
+		List<UriParameter> keyPredicates = uriEntityset.getKeyPredicates();
+		
+		// 1.2. retrieve the requested (Edm) property 
+		UriResourceProperty uriProperty = (UriResourceProperty)resourceParts.get(resourceParts.size() -1); // the last segment is the Property
+		EdmProperty edmProperty = uriProperty.getProperty();
+		String edmPropertyName = edmProperty.getName();
+		// in our example, we know we have only primitive types in our model
+		EdmPrimitiveType edmPropertyType = (EdmPrimitiveType) edmProperty.getType(); 
+		
+		
+		// 2. retrieve data from backend
+		// 2.1. retrieve the entity data, for which the property has to be read
+		Entity entity = storage.readEntityData(edmEntitySet, keyPredicates);
+		if (entity == null) { // Bad request
+			throw new ODataApplicationException("Entity not found",
+							HttpStatusCode.NOT_FOUND.getStatusCode(), Locale.ENGLISH);
+		} 
+		
+		// 2.2. retrieve the property data from the entity
+		Property property = entity.getProperty(edmPropertyName);
+		if (property == null) {
+			throw new ODataApplicationException("Property not found",
+              HttpStatusCode.NOT_FOUND.getStatusCode(), Locale.ENGLISH);
+		}		
+		
+		// 3. serialize
+		Object value = property.getValue();
+		if (value != null) {
+			// 3.1. configure the serializer
+			ODataSerializer serializer = odata.createSerializer(responseFormat);
+			
+			ContextURL contextUrl = ContextURL.with().entitySet(edmEntitySet).navOrPropertyPath(edmPropertyName).build();
+			PrimitiveSerializerOptions options = PrimitiveSerializerOptions.with().contextURL(contextUrl).build();
+			// 3.2. serialize
+			SerializerResult result = serializer.primitive(serviceMetadata, edmPropertyType, property, options);
+			
+			//4. configure the response object
+			response.setContent(result.getContent());
+			response.setStatusCode(HttpStatusCode.OK.getStatusCode());
+			response.setHeader(HttpHeader.CONTENT_TYPE, responseFormat.toContentTypeString());		
+		}else{
+			// in case there's no value for the property, we can skip the serialization
+			response.setStatusCode(HttpStatusCode.NO_CONTENT.getStatusCode());
+		}
+	}
+
+	/*
+	 * These processor methods are not handled in this tutorial 
+	 *
+	 * */
+	public void updatePrimitive(ODataRequest request, ODataResponse response, UriInfo uriInfo,
+                              ContentType requestFormat, ContentType responseFormat)
+								throws ODataApplicationException, DeserializerException, SerializerException {
+		throw new ODataApplicationException("Not supported.", HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+	}
+
+	public void deletePrimitive(ODataRequest request, ODataResponse response, UriInfo uriInfo)
+          throws ODataApplicationException {
+		throw new ODataApplicationException("Not supported.", HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+	}
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/util/Util.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/util/Util.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/util/Util.java
new file mode 100644
index 0000000..97e8eff
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/util/Util.java
@@ -0,0 +1,161 @@
+/*
+ * 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 myservice.mynamespace.util;
+
+import java.util.List;
+import java.util.Locale;
+
+import org.apache.olingo.commons.api.data.Entity;
+import org.apache.olingo.commons.api.data.EntityCollection;
+import org.apache.olingo.commons.api.edm.EdmBindingTarget;
+import org.apache.olingo.commons.api.edm.EdmEntitySet;
+import org.apache.olingo.commons.api.edm.EdmEntityType;
+import org.apache.olingo.commons.api.edm.EdmNavigationProperty;
+import org.apache.olingo.commons.api.edm.EdmPrimitiveType;
+import org.apache.olingo.commons.api.edm.EdmPrimitiveTypeException;
+import org.apache.olingo.commons.api.edm.EdmProperty;
+import org.apache.olingo.commons.api.edm.EdmType;
+import org.apache.olingo.commons.api.http.HttpStatusCode;
+import org.apache.olingo.server.api.ODataApplicationException;
+import org.apache.olingo.server.api.uri.UriInfoResource;
+import org.apache.olingo.server.api.uri.UriParameter;
+import org.apache.olingo.server.api.uri.UriResource;
+import org.apache.olingo.server.api.uri.UriResourceEntitySet;
+
+public class Util {
+  
+  public static EdmEntitySet getEdmEntitySet(UriInfoResource uriInfo) throws ODataApplicationException {
+
+    List<UriResource> resourcePaths = uriInfo.getUriResourceParts();
+    // To get the entity set we have to interpret all URI segments
+    if (!(resourcePaths.get(0) instanceof UriResourceEntitySet)) {
+      // Here we should interpret the whole URI but in this example we do not support navigation so we throw an
+      // exception
+      throw new ODataApplicationException("Invalid resource type for first segment.", HttpStatusCode.NOT_IMPLEMENTED
+          .getStatusCode(), Locale.ENGLISH);
+    }
+
+    UriResourceEntitySet uriResource = (UriResourceEntitySet) resourcePaths.get(0);
+
+    return uriResource.getEntitySet();
+  }
+  
+  public static Entity findEntity(EdmEntityType edmEntityType, EntityCollection entitySet,
+      List<UriParameter> keyParams) throws ODataApplicationException {
+
+    List<Entity> entityList = entitySet.getEntities();
+
+    // loop over all entities in order to find that one that matches
+    // all keys in request e.g. contacts(ContactID=1, CompanyID=1)
+    for (Entity entity : entityList) {
+      boolean foundEntity = entityMatchesAllKeys(edmEntityType, entity, keyParams);
+      if (foundEntity) {
+        return entity;
+      }
+    }
+
+    return null;
+  }
+
+  public static boolean entityMatchesAllKeys(EdmEntityType edmEntityType, Entity entity, List<UriParameter> keyParams) 
+      throws ODataApplicationException {
+
+    // loop over all keys
+    for (final UriParameter key : keyParams) {
+      // key
+      String keyName = key.getName();
+      String keyText = key.getText();
+      
+      // Edm: we need this info for the comparison below
+      EdmProperty edmKeyProperty = (EdmProperty) edmEntityType.getProperty(keyName);
+      Boolean isNullable = edmKeyProperty.isNullable();
+      Integer maxLength = edmKeyProperty.getMaxLength();
+      Integer precision = edmKeyProperty.getPrecision();
+      Boolean isUnicode = edmKeyProperty.isUnicode();
+      Integer scale = edmKeyProperty.getScale();
+      // get the EdmType in order to compare
+      EdmType edmType = edmKeyProperty.getType();
+      EdmPrimitiveType edmPrimitiveType = (EdmPrimitiveType) edmType;
+
+      // Runtime data: the value of the current entity
+      // don't need to check for null, this is done in olingo library
+      Object valueObject = entity.getProperty(keyName).getValue();
+
+      // now need to compare the valueObject with the keyText String
+      // this is done using the type.valueToString //
+      String valueAsString = null;
+      try {
+        valueAsString = edmPrimitiveType.valueToString(valueObject, isNullable, maxLength, precision, scale, isUnicode);
+      } catch (EdmPrimitiveTypeException e) {
+        throw new ODataApplicationException("Failed to retrieve String value", HttpStatusCode.INTERNAL_SERVER_ERROR
+            .getStatusCode(), Locale.ENGLISH, e);
+      }
+
+      if (valueAsString == null) {
+        return false;
+      }
+
+      boolean matches = valueAsString.equals(keyText);
+      if (!matches) {
+        // if any of the key properties is not found in the entity, we don't need to search further
+        return false;
+      }
+    }
+
+    return true;
+  }
+  
+  /**
+   * Example:
+   * For the following navigation: DemoService.svc/Categories(1)/Products
+   * we need the EdmEntitySet for the navigation property "Products"
+   *
+   * This is defined as follows in the metadata:
+   * <code>
+   * 
+   * <EntitySet Name="Categories" EntityType="OData.Demo.Category">
+   * <NavigationPropertyBinding Path="Products" Target="Products"/>
+   * </EntitySet>
+   * </code>
+   * The "Target" attribute specifies the target EntitySet
+   * Therefore we need the startEntitySet "Categories" in order to retrieve the target EntitySet "Products"
+   */
+  public static EdmEntitySet getNavigationTargetEntitySet(EdmEntitySet startEdmEntitySet,
+      EdmNavigationProperty edmNavigationProperty)
+      throws ODataApplicationException {
+
+    EdmEntitySet navigationTargetEntitySet = null;
+
+    String navPropName = edmNavigationProperty.getName();
+    EdmBindingTarget edmBindingTarget = startEdmEntitySet.getRelatedBindingTarget(navPropName);
+    if (edmBindingTarget == null) {
+      throw new ODataApplicationException("Not supported.",
+              HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+    }
+
+    if (edmBindingTarget instanceof EdmEntitySet) {
+      navigationTargetEntitySet = (EdmEntitySet) edmBindingTarget;
+    } else {
+      throw new ODataApplicationException("Not supported.",
+              HttpStatusCode.NOT_IMPLEMENTED.getStatusCode(), Locale.ROOT);
+    }
+
+    return navigationTargetEntitySet;
+  }
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/web/DemoServlet.java
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/web/DemoServlet.java b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/web/DemoServlet.java
new file mode 100644
index 0000000..9f06d36
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/java/myservice/mynamespace/web/DemoServlet.java
@@ -0,0 +1,74 @@
+/*
+ * 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 myservice.mynamespace.web;
+
+import java.io.IOException;
+import java.util.ArrayList;
+
+import javax.servlet.ServletException;
+import javax.servlet.http.HttpServlet;
+import javax.servlet.http.HttpServletRequest;
+import javax.servlet.http.HttpServletResponse;
+import javax.servlet.http.HttpSession;
+
+import org.apache.olingo.server.api.OData;
+import org.apache.olingo.server.api.ODataHttpHandler;
+import org.apache.olingo.server.api.ServiceMetadata;
+import org.apache.olingo.server.api.edmx.EdmxReference;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import myservice.mynamespace.data.Storage;
+import myservice.mynamespace.service.DemoEdmProvider;
+import myservice.mynamespace.service.DemoEntityCollectionProcessor;
+import myservice.mynamespace.service.DemoEntityProcessor;
+import myservice.mynamespace.service.DemoPrimitiveProcessor;
+
+public class DemoServlet extends HttpServlet {
+
+  private static final long serialVersionUID = 1L;
+  private static final Logger LOG = LoggerFactory.getLogger(DemoServlet.class);
+
+  @Override
+  protected void service(HttpServletRequest req, HttpServletResponse resp) throws ServletException, IOException {
+    try {
+      OData odata = OData.newInstance();
+      ServiceMetadata edm = odata.createServiceMetadata(new DemoEdmProvider(), new ArrayList<EdmxReference>());
+      
+      HttpSession session = req.getSession(true);
+      Storage storage = (Storage) session.getAttribute(Storage.class.getName());
+      if (storage == null) {
+        storage = new Storage(odata, edm.getEdm());
+        session.setAttribute(Storage.class.getName(), storage);
+      }
+
+     
+      ODataHttpHandler handler = odata.createHandler(edm);
+      handler.register(new DemoEntityCollectionProcessor(storage));
+      handler.register(new DemoEntityProcessor(storage));
+      handler.register(new DemoPrimitiveProcessor(storage));
+      
+      // let the handler do the work
+      handler.process(req, resp);
+    } catch (RuntimeException e) {
+      LOG.error("Server Error occurred in ExampleServlet", e);
+      throw new ServletException(e);
+    }
+  }
+}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/WEB-INF/web.xml
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/WEB-INF/web.xml b/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/WEB-INF/web.xml
new file mode 100644
index 0000000..21de52a
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/WEB-INF/web.xml
@@ -0,0 +1,40 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+  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.
+-->
+<web-app xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
+    xmlns="http://java.sun.com/xml/ns/javaee" xmlns:web="http://java.sun.com/xml/ns/javaee/web-app_2_5.xsd"
+    xsi:schemaLocation="http://java.sun.com/xml/ns/javaee http://java.sun.com/xml/ns/javaee/web-app_2_5.xsd"
+				 id="WebApp_ID" version="2.5">
+
+	<!-- Register the HttpServlet implementation -->
+	<servlet>
+	  <servlet-name>DemoServlet</servlet-name>
+	  <servlet-class>myservice.mynamespace.web.DemoServlet</servlet-class>
+	  <load-on-startup>1</load-on-startup>
+	</servlet>
+	
+	<!-- 
+		Our OData service can be invoked at 
+		http://localhost:8080/DemoService/DemoService.svc
+	-->
+	<servlet-mapping>
+	  <servlet-name>DemoServlet</servlet-name>
+	  <url-pattern>/DemoService.svc/*</url-pattern>
+	</servlet-mapping>
+</web-app>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/index.jsp
----------------------------------------------------------------------
diff --git a/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/index.jsp b/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/index.jsp
new file mode 100644
index 0000000..7ffb4ba
--- /dev/null
+++ b/samples/tutorials/p12_deep_insert_preparation/src/main/webapp/index.jsp
@@ -0,0 +1,26 @@
+<!--
+
+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.
+
+-->
+<html>
+<body>
+<h2>Hello World!</h2>
+<a href="DemoService.svc/">OData Olingo V4 Demo Service</a>
+</body>
+</html>

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/a16c9d9c/samples/tutorials/pom.xml
----------------------------------------------------------------------
diff --git a/samples/tutorials/pom.xml b/samples/tutorials/pom.xml
index 792bcea..2d2d0f9 100644
--- a/samples/tutorials/pom.xml
+++ b/samples/tutorials/pom.xml
@@ -47,6 +47,9 @@
 	<module>p9_action</module>
 	<module>p9_action_preparation</module>
 	<module>p10_media</module>
+    <module>p11_batch</module>
+    <module>p12_deep_insert</module>
+    <module>p12_deep_insert_preparation</module>
   </modules>
 
   <build>