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

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

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ConstExprConstruct.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ConstExprConstruct.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ConstExprConstruct.java
deleted file mode 100644
index bb87002..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ConstExprConstruct.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class ConstExprConstruct extends ExprConstruct {
-
-    private static final long serialVersionUID = 2250072064504668969L;
-
-    public enum Type {
-
-        Binary,
-        Bool,
-        Date,
-        DateTimeOffset,
-        Decimal,
-        Duration,
-        EnumMember,
-        Float,
-        Guid,
-        Int,
-        String,
-        TimeOfDay;
-
-        public static Type fromString(final String value) {
-            Type result = null;
-            try {
-                result = valueOf(value);
-            } catch (IllegalArgumentException e) {
-                // ignore
-            }
-            return result;
-        }
-    }
-
-    private Type type;
-
-    private String value;
-
-    public Type getType() {
-        return type;
-    }
-
-    public void setType(final Type type) {
-        this.type = type;
-    }
-
-    public String getValue() {
-        return value;
-    }
-
-    public void setValue(final String value) {
-        this.value = value;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstruct.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstruct.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstruct.java
deleted file mode 100644
index c681299..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstruct.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-
-@JsonDeserialize(using = DynExprConstructDeserializer.class)
-public abstract class DynExprConstruct extends ExprConstruct {
-
-    private static final long serialVersionUID = -642012862023177349L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstructDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstructDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstructDeserializer.java
deleted file mode 100644
index 1b60021..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprConstructDeserializer.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.core.JsonLocation;
-import com.fasterxml.jackson.core.JsonParseException;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-import org.apache.commons.lang3.ArrayUtils;
-import org.apache.commons.lang3.ClassUtils;
-
-public class DynExprConstructDeserializer extends AbstractEdmDeserializer<DynExprConstruct> {
-
-    private static final String[] EL_OR_ATTR = { AnnotationPath.class.getSimpleName(), Path.class.getSimpleName() };
-
-    private static final String APPLY = Apply.class.getSimpleName();
-
-    private static final String CAST = Cast.class.getSimpleName();
-
-    private static final String COLLECTION = Collection.class.getSimpleName();
-
-    private static final String IF = If.class.getSimpleName();
-
-    private static final String IS_OF = IsOf.class.getSimpleName();
-
-    private static final String LABELED_ELEMENT = LabeledElement.class.getSimpleName();
-
-    private static final String NULL = Null.class.getSimpleName();
-
-    private static final String RECORD = Record.class.getSimpleName();
-
-    private static final String URL_REF = UrlRef.class.getSimpleName();
-
-    private AbstractElOrAttrConstruct getElOrAttrInstance(final String simpleClassName) throws JsonParseException {
-        try {
-            @SuppressWarnings("unchecked")
-            Class<? extends AbstractElOrAttrConstruct> elOrAttrClass =
-                    (Class<? extends AbstractElOrAttrConstruct>) ClassUtils.getClass(
-                            getClass().getPackage().getName() + "." + simpleClassName);
-            return elOrAttrClass.newInstance();
-        } catch (Exception e) {
-            throw new JsonParseException("Could not instantiate " + simpleClassName, JsonLocation.NA, e);
-        }
-    }
-
-    private ExprConstruct parseConstOrEnumExprConstruct(final JsonParser jp) throws IOException {
-        ExprConstruct result;
-        if (isAnnotationConstExprConstruct(jp)) {
-            result = parseAnnotationConstExprConstruct(jp);
-        } else {
-            result = jp.getCodec().readValue(jp, DynExprConstruct.class);
-        }
-        jp.nextToken();
-
-        return result;
-    }
-
-    @Override
-    protected DynExprConstruct doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        DynExprConstruct construct = null;
-
-        if (DynExprSingleParamOp.Type.fromString(jp.getCurrentName()) != null) {
-            final DynExprSingleParamOp dynExprSingleParamOp = new DynExprSingleParamOp();
-            dynExprSingleParamOp.setType(DynExprSingleParamOp.Type.fromString(jp.getCurrentName()));
-
-            jp.nextToken();
-            jp.nextToken();
-            dynExprSingleParamOp.setExpression(jp.getCodec().readValue(jp, DynExprConstruct.class));
-
-            construct = dynExprSingleParamOp;
-        } else if (DynExprDoubleParamOp.Type.fromString(jp.getCurrentName()) != null) {
-            final DynExprDoubleParamOp dynExprDoubleParamOp = new DynExprDoubleParamOp();
-            dynExprDoubleParamOp.setType(DynExprDoubleParamOp.Type.fromString(jp.getCurrentName()));
-
-            jp.nextToken();
-            jp.nextToken();
-            dynExprDoubleParamOp.setLeft(jp.getCodec().readValue(jp, DynExprConstruct.class));
-            dynExprDoubleParamOp.setRight(jp.getCodec().readValue(jp, DynExprConstruct.class));
-
-            construct = dynExprDoubleParamOp;
-        } else if (ArrayUtils.contains(EL_OR_ATTR, jp.getCurrentName())) {
-            final AbstractElOrAttrConstruct elOrAttr = getElOrAttrInstance(jp.getCurrentName());
-            elOrAttr.setValue(jp.nextTextValue());
-
-            construct = elOrAttr;
-        } else if (APPLY.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, Apply.class);
-        } else if (CAST.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, Cast.class);
-        } else if (COLLECTION.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, Collection.class);
-        } else if (IF.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            jp.nextToken();
-
-            final If _if = new If();
-            _if.setGuard(parseConstOrEnumExprConstruct(jp));
-            _if.setThen(parseConstOrEnumExprConstruct(jp));
-            _if.setElse(parseConstOrEnumExprConstruct(jp));
-
-            construct = _if;
-        } else if (IS_OF.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, IsOf.class);
-        } else if (LABELED_ELEMENT.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, LabeledElement.class);
-        } else if (NULL.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, Null.class);
-        } else if (RECORD.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, Record.class);
-        } else if (URL_REF.equals(jp.getCurrentName())) {
-            jp.nextToken();
-            construct = jp.getCodec().readValue(jp, UrlRef.class);
-        }
-
-        return construct;
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprDoubleParamOp.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprDoubleParamOp.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprDoubleParamOp.java
deleted file mode 100644
index 49dc15c..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprDoubleParamOp.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class DynExprDoubleParamOp extends DynExprConstruct {
-
-    private static final long serialVersionUID = -7974475975925167731L;
-
-    public static enum Type {
-
-        And,
-        Or;
-
-        public static Type fromString(final String value) {
-            Type result = null;
-            for (Type type : values()) {
-                if (value.equals(type.name())) {
-                    result = type;
-                }
-            }
-            return result;
-        }
-    }
-
-    private Type type;
-
-    private DynExprConstruct left;
-
-    private DynExprConstruct right;
-
-    public Type getType() {
-        return type;
-    }
-
-    public void setType(final Type type) {
-        this.type = type;
-    }
-
-    public DynExprConstruct getLeft() {
-        return left;
-    }
-
-    public void setLeft(final DynExprConstruct left) {
-        this.left = left;
-    }
-
-    public DynExprConstruct getRight() {
-        return right;
-    }
-
-    public void setRight(final DynExprConstruct right) {
-        this.right = right;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprSingleParamOp.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprSingleParamOp.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprSingleParamOp.java
deleted file mode 100644
index ee3892b..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/DynExprSingleParamOp.java
+++ /dev/null
@@ -1,67 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class DynExprSingleParamOp extends DynExprConstruct {
-
-    private static final long serialVersionUID = -7974475975925167731L;
-
-    public static enum Type {
-
-        Not,
-        Eq,
-        Ne,
-        Gt,
-        Ge,
-        Lt,
-        Le;
-
-        public static Type fromString(final String value) {
-            Type result = null;
-            for (Type type : values()) {
-                if (value.equals(type.name())) {
-                    result = type;
-                }
-            }
-            return result;
-        }
-
-    }
-
-    private Type type;
-
-    private DynExprConstruct expression;
-
-    public Type getType() {
-        return type;
-    }
-
-    public void setType(final Type type) {
-        this.type = type;
-    }
-
-    public DynExprConstruct getExpression() {
-        return expression;
-    }
-
-    public void setExpression(final DynExprConstruct expression) {
-        this.expression = expression;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ExprConstruct.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ExprConstruct.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ExprConstruct.java
deleted file mode 100644
index 3977507..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/ExprConstruct.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdm;
-
-public abstract class ExprConstruct extends AbstractEdm {
-
-    private static final long serialVersionUID = 7108626008005050492L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/If.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/If.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/If.java
deleted file mode 100644
index 6bef419..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/If.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class If extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = 6752952406406218936L;
-
-    private ExprConstruct guard;
-
-    private ExprConstruct _then;
-
-    private ExprConstruct _else;
-
-    public ExprConstruct getGuard() {
-        return guard;
-    }
-
-    public void setGuard(final ExprConstruct guard) {
-        this.guard = guard;
-    }
-
-    public ExprConstruct getThen() {
-        return _then;
-    }
-
-    public void setThen(final ExprConstruct _then) {
-        this._then = _then;
-    }
-
-    public ExprConstruct getElse() {
-        return _else;
-    }
-
-    public void setElse(final ExprConstruct _else) {
-        this._else = _else;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOf.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOf.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOf.java
deleted file mode 100644
index 0638c26..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOf.java
+++ /dev/null
@@ -1,89 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-import java.math.BigInteger;
-
-@JsonDeserialize(using = IsOfDeserializer.class)
-public class IsOf extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = 6958304670385303776L;
-
-    private String type;
-
-    private String maxLength;
-
-    private BigInteger precision;
-
-    private BigInteger scale;
-
-    private String srid;
-
-    private DynExprConstruct value;
-
-    public String getType() {
-        return type;
-    }
-
-    public void setType(final String type) {
-        this.type = type;
-    }
-
-    public String getMaxLength() {
-        return maxLength;
-    }
-
-    public void setMaxLength(final String maxLength) {
-        this.maxLength = maxLength;
-    }
-
-    public BigInteger getPrecision() {
-        return precision;
-    }
-
-    public void setPrecision(final BigInteger precision) {
-        this.precision = precision;
-    }
-
-    public BigInteger getScale() {
-        return scale;
-    }
-
-    public void setScale(final BigInteger scale) {
-        this.scale = scale;
-    }
-
-    public String getSrid() {
-        return srid;
-    }
-
-    public void setSrid(final String srid) {
-        this.srid = srid;
-    }
-
-    public DynExprConstruct getValue() {
-        return value;
-    }
-
-    public void setValue(final DynExprConstruct value) {
-        this.value = value;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOfDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOfDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOfDeserializer.java
deleted file mode 100644
index 492f20f..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/IsOfDeserializer.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.v4.Annotation;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-import java.math.BigInteger;
-
-public class IsOfDeserializer extends AbstractEdmDeserializer<IsOf> {
-
-    @Override
-    protected IsOf doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final IsOf isof = new IsOf();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if ("Type".equals(jp.getCurrentName())) {
-                    isof.setType(jp.nextTextValue());
-                } else if ("Annotation".equals(jp.getCurrentName())) {
-                    isof.setAnnotation(jp.getCodec().readValue(jp, Annotation.class));
-                } else if ("MaxLength".equals(jp.getCurrentName())) {
-                    isof.setMaxLength(jp.nextTextValue());
-                } else if ("Precision".equals(jp.getCurrentName())) {
-                    isof.setPrecision(BigInteger.valueOf(jp.nextLongValue(0L)));
-                } else if ("Scale".equals(jp.getCurrentName())) {
-                    isof.setScale(BigInteger.valueOf(jp.nextLongValue(0L)));
-                } else if ("SRID".equals(jp.getCurrentName())) {
-                    isof.setSrid(jp.nextTextValue());
-                } else {
-                    isof.setValue(jp.getCodec().readValue(jp, DynExprConstruct.class));
-                }
-            }
-        }
-
-        return isof;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElement.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElement.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElement.java
deleted file mode 100644
index 2e08c37..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElement.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-
-@JsonDeserialize(using = LabeledElementDeserializer.class)
-public class LabeledElement extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = 6938971787086282939L;
-
-    private String name;
-
-    private DynExprConstruct value;
-
-    public String getName() {
-        return name;
-    }
-
-    public void setName(final String name) {
-        this.name = name;
-    }
-
-    public DynExprConstruct getValue() {
-        return value;
-    }
-
-    public void setValue(final DynExprConstruct value) {
-        this.value = value;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementDeserializer.java
deleted file mode 100644
index 16674bd..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementDeserializer.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.v4.Annotation;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-
-public class LabeledElementDeserializer extends AbstractEdmDeserializer<LabeledElement> {
-
-    @Override
-    protected LabeledElement doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final LabeledElement element = new LabeledElement();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if ("Name".equals(jp.getCurrentName())) {
-                    element.setName(jp.nextTextValue());
-                } else if ("Annotation".equals(jp.getCurrentName())) {
-                    element.setAnnotation(jp.getCodec().readValue(jp, Annotation.class));
-                } else {
-                    element.setValue(jp.getCodec().readValue(jp, DynExprConstruct.class));
-                }
-            }
-        }
-
-        return element;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementReference.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementReference.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementReference.java
deleted file mode 100644
index 9ce3497..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/LabeledElementReference.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class LabeledElementReference extends AbstractElOrAttrConstruct {
-
-    private static final long serialVersionUID = 3649068436729494270L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NavigationPropertyPath.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NavigationPropertyPath.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NavigationPropertyPath.java
deleted file mode 100644
index e01edfa..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NavigationPropertyPath.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class NavigationPropertyPath extends AbstractElOrAttrConstruct {
-
-    private static final long serialVersionUID = -8066400142504963043L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Null.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Null.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Null.java
deleted file mode 100644
index 6c75f34..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Null.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-
-@JsonDeserialize(using = NullDeserializer.class)
-public class Null extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = -3611384710172781951L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NullDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NullDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NullDeserializer.java
deleted file mode 100644
index e974f23..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/NullDeserializer.java
+++ /dev/null
@@ -1,49 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.v4.Annotation;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-
-public class NullDeserializer extends AbstractEdmDeserializer<Null> {
-
-    @Override
-    protected Null doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final Null _null = new Null();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if ("Annotation".equals(jp.getCurrentName())) {
-                    _null.setAnnotation(jp.getCodec().readValue(jp, Annotation.class));
-                }
-            }
-        }
-
-        return _null;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Path.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Path.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Path.java
deleted file mode 100644
index 95f9e9e..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Path.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class Path extends AbstractElOrAttrConstruct {
-
-    private static final long serialVersionUID = -2551058493469292082L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyPath.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyPath.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyPath.java
deleted file mode 100644
index c76905d..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyPath.java
+++ /dev/null
@@ -1,25 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-public class PropertyPath extends AbstractElOrAttrConstruct {
-
-    private static final long serialVersionUID = 2328584735437885159L;
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValue.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValue.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValue.java
deleted file mode 100644
index 644c724..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValue.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-
-@JsonDeserialize(using = PropertyValueDeserializer.class)
-public class PropertyValue extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = 3081968466425707461L;
-
-    private String property;
-
-    private ExprConstruct value;
-
-    public String getProperty() {
-        return property;
-    }
-
-    public void setProperty(final String property) {
-        this.property = property;
-    }
-
-    public ExprConstruct getValue() {
-        return value;
-    }
-
-    public void setValue(final ExprConstruct value) {
-        this.value = value;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValueDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValueDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValueDeserializer.java
deleted file mode 100644
index bf71a3f..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/PropertyValueDeserializer.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.v4.Annotation;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-
-public class PropertyValueDeserializer extends AbstractEdmDeserializer<PropertyValue> {
-
-    @Override
-    protected PropertyValue doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final PropertyValue propValue = new PropertyValue();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if ("Property".equals(jp.getCurrentName())) {
-                    propValue.setProperty(jp.nextTextValue());
-                } else if ("Annotation".equals(jp.getCurrentName())) {
-                    propValue.setAnnotation(jp.getCodec().readValue(jp, Annotation.class));
-                } else if (isAnnotationConstExprConstruct(jp)) {
-                    propValue.setValue(parseAnnotationConstExprConstruct(jp));
-                } else {
-                    propValue.setValue(jp.getCodec().readValue(jp, DynExprConstruct.class));
-                }
-            }
-        }
-
-        return propValue;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Record.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Record.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Record.java
deleted file mode 100644
index d42ae32..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/Record.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 com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-import java.util.ArrayList;
-import java.util.List;
-
-@JsonDeserialize(using = RecordDeserializer.class)
-public class Record extends AnnotatedDynExprConstruct {
-
-    private static final long serialVersionUID = -2886526224721870304L;
-
-    private String type;
-
-    private final List<PropertyValue> propertyValues = new ArrayList<PropertyValue>();
-
-    public String getType() {
-        return type;
-    }
-
-    public void setType(final String type) {
-        this.type = type;
-    }
-
-    public List<PropertyValue> getPropertyValues() {
-        return propertyValues;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/RecordDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/RecordDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/RecordDeserializer.java
deleted file mode 100644
index 727aca7..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/RecordDeserializer.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.msopentech.odatajclient.engine.metadata.edm.v4.Annotation;
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-
-public class RecordDeserializer extends AbstractEdmDeserializer<Record> {
-
-    @Override
-    protected Record doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final Record record = new Record();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if ("Tyoe".equals(jp.getCurrentName())) {
-                    record.setType(jp.nextTextValue());
-                } else if ("Annotation".equals(jp.getCurrentName())) {
-                    record.setAnnotation(jp.getCodec().readValue(jp, Annotation.class));
-                } else {
-                    record.getPropertyValues().add(jp.getCodec().readValue(jp, PropertyValue.class));
-                }
-            }
-        }
-
-        return record;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRef.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRef.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRef.java
deleted file mode 100644
index 1b15eeb..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRef.java
+++ /dev/null
@@ -1,38 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.databind.annotation.JsonDeserialize;
-
-@JsonDeserialize(using = UrlRefDeserializer.class)
-public class UrlRef extends DynExprConstruct {
-
-    private static final long serialVersionUID = 3755101394647430897L;
-
-    private ExprConstruct value;
-
-    public ExprConstruct getValue() {
-        return value;
-    }
-
-    public void setValue(final ExprConstruct value) {
-        this.value = value;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRefDeserializer.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRefDeserializer.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRefDeserializer.java
deleted file mode 100644
index 51107af..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/metadata/edm/v4/annotation/UrlRefDeserializer.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.metadata.edm.v4.annotation;
-
-import com.fasterxml.jackson.core.JsonParser;
-import com.fasterxml.jackson.core.JsonProcessingException;
-import com.fasterxml.jackson.core.JsonToken;
-import com.fasterxml.jackson.databind.DeserializationContext;
-import com.msopentech.odatajclient.engine.metadata.edm.AbstractEdmDeserializer;
-import java.io.IOException;
-
-public class UrlRefDeserializer extends AbstractEdmDeserializer<UrlRef> {
-
-    @Override
-    protected UrlRef doDeserialize(final JsonParser jp, final DeserializationContext ctxt)
-            throws IOException, JsonProcessingException {
-
-        final UrlRef urlref = new UrlRef();
-
-        for (; jp.getCurrentToken() != JsonToken.END_OBJECT; jp.nextToken()) {
-            final JsonToken token = jp.getCurrentToken();
-            if (token == JsonToken.FIELD_NAME) {
-                if (isAnnotationConstExprConstruct(jp)) {
-                    urlref.setValue(parseAnnotationConstExprConstruct(jp));
-                } else {
-                    urlref.setValue(jp.getCodec().readValue(jp, DynExprConstruct.class));
-                }
-            }
-        }
-
-        return urlref;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/AbstractURIBuilder.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/AbstractURIBuilder.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/AbstractURIBuilder.java
deleted file mode 100644
index 1d223cb..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/AbstractURIBuilder.java
+++ /dev/null
@@ -1,240 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.uri;
-
-import com.msopentech.odatajclient.engine.client.Configuration;
-import com.msopentech.odatajclient.engine.uri.filter.ODataFilter;
-import com.msopentech.odatajclient.engine.utils.URIUtils;
-import java.net.URI;
-import java.net.URISyntaxException;
-import java.util.ArrayList;
-import java.util.List;
-import java.util.Map;
-import java.util.TreeMap;
-import org.slf4j.Logger;
-import org.slf4j.LoggerFactory;
-
-public abstract class AbstractURIBuilder implements URIBuilder {
-
-    private static final long serialVersionUID = -3267515371720408124L;
-
-    /**
-     * Logger.
-     */
-    protected static final Logger LOG = LoggerFactory.getLogger(URIBuilder.class);
-
-    protected final List<URIBuilder.Segment> segments;
-
-    /**
-     * Case-insensitive map of query options.
-     */
-    protected final Map<String, String> queryOptions = new TreeMap<String, String>(String.CASE_INSENSITIVE_ORDER);
-
-    /**
-     * Constructor.
-     *
-     * @param serviceRoot absolute URL (schema, host and port included) representing the location of the root of the
-     * data service.
-     */
-    protected AbstractURIBuilder(final String serviceRoot) {
-        segments = new ArrayList<URIBuilder.Segment>();
-        segments.add(new URIBuilder.Segment(SegmentType.SERVICEROOT, serviceRoot));
-    }
-
-    protected abstract Configuration getConfiguration();
-
-    @Override
-    public URIBuilder addQueryOption(final QueryOption option, final String value) {
-        return addQueryOption(option.toString(), value);
-    }
-
-    @Override
-    public URIBuilder addQueryOption(final String option, final String value) {
-        queryOptions.put(option, value);
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendEntitySetSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.ENTITYSET, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendEntityTypeSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.ENTITYTYPE, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendKeySegment(final Object val) {
-        final String segValue = URIUtils.escape(val);
-
-        segments.add(getConfiguration().isKeyAsSegment()
-                ? new URIBuilder.Segment(SegmentType.KEY_AS_SEGMENT, segValue)
-                : new URIBuilder.Segment(SegmentType.KEY, "(" + segValue + ")"));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendKeySegment(final Map<String, Object> segmentValues) {
-        if (!getConfiguration().isKeyAsSegment()) {
-            final StringBuilder keyBuilder = new StringBuilder().append('(');
-            for (Map.Entry<String, Object> entry : segmentValues.entrySet()) {
-                keyBuilder.append(entry.getKey()).append('=').append(URIUtils.escape(entry.getValue()));
-                keyBuilder.append(',');
-            }
-            keyBuilder.deleteCharAt(keyBuilder.length() - 1).append(')');
-
-            segments.add(new URIBuilder.Segment(SegmentType.KEY, keyBuilder.toString()));
-        }
-
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendNavigationLinkSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.NAVIGATION, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendStructuralSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.STRUCTURAL, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendLinksSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.LINKS, SegmentType.LINKS.getValue()));
-        segments.add(new URIBuilder.Segment(SegmentType.ENTITYTYPE, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendValueSegment() {
-        segments.add(new URIBuilder.Segment(SegmentType.VALUE, SegmentType.VALUE.getValue()));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendCountSegment() {
-        segments.add(new URIBuilder.Segment(SegmentType.COUNT, SegmentType.COUNT.getValue()));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendFunctionImportSegment(final String segmentValue) {
-        segments.add(new URIBuilder.Segment(SegmentType.FUNCTIONIMPORT, segmentValue));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendMetadataSegment() {
-        segments.add(new URIBuilder.Segment(SegmentType.METADATA, SegmentType.METADATA.getValue()));
-        return this;
-    }
-
-    @Override
-    public URIBuilder appendBatchSegment() {
-        segments.add(new URIBuilder.Segment(SegmentType.BATCH, SegmentType.BATCH.getValue()));
-        return this;
-    }
-
-    @Override
-    public URIBuilder expand(final String entityName) {
-        return addQueryOption(QueryOption.EXPAND, entityName);
-    }
-
-    @Override
-    public URIBuilder format(final String format) {
-        return addQueryOption(QueryOption.FORMAT, format);
-    }
-
-    @Override
-    public URIBuilder filter(final ODataFilter filter) {
-        return addQueryOption(QueryOption.FILTER, filter.build());
-    }
-
-    @Override
-    public URIBuilder filter(final String filter) {
-        return addQueryOption(QueryOption.FILTER, filter);
-    }
-
-    @Override
-    public URIBuilder select(final String select) {
-        return addQueryOption(QueryOption.SELECT, select);
-    }
-
-    @Override
-    public URIBuilder orderBy(final String order) {
-        return addQueryOption(QueryOption.ORDERBY, order);
-    }
-
-    @Override
-    public URIBuilder top(final int top) {
-        return addQueryOption(QueryOption.TOP, String.valueOf(top));
-    }
-
-    @Override
-    public URIBuilder skip(final int skip) {
-        return addQueryOption(QueryOption.SKIP, String.valueOf(skip));
-    }
-
-    @Override
-    public URIBuilder skipToken(final String skipToken) {
-        return addQueryOption(QueryOption.SKIPTOKEN, skipToken);
-    }
-
-    @Override
-    public URIBuilder inlineCount() {
-        return addQueryOption(QueryOption.INLINECOUNT, "allpages");
-    }
-
-    @Override
-    public URI build() {
-        final StringBuilder segmentsBuilder = new StringBuilder();
-        for (URIBuilder.Segment seg : segments) {
-            if (segmentsBuilder.length() > 0 && seg.getType() != SegmentType.KEY) {
-                segmentsBuilder.append('/');
-            }
-
-            segmentsBuilder.append(seg.getValue());
-        }
-
-        try {
-            final org.apache.http.client.utils.URIBuilder builder =
-                    new org.apache.http.client.utils.URIBuilder(segmentsBuilder.toString());
-
-            for (Map.Entry<String, String> option : queryOptions.entrySet()) {
-                builder.addParameter("$" + option.getKey(), option.getValue());
-            }
-
-            return builder.build().normalize();
-        } catch (URISyntaxException e) {
-            throw new IllegalArgumentException("Could not build valid URI", e);
-        }
-    }
-
-    @Override
-    public String toString() {
-        return build().toASCIIString();
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/QueryOption.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/QueryOption.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/QueryOption.java
deleted file mode 100644
index cded113..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/QueryOption.java
+++ /dev/null
@@ -1,101 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.uri;
-
-/**
- * Query options.
- */
-public enum QueryOption {
-
-    /**
-     * This option indicates entities associated with the EntityType
-     * instance or EntitySet, identified by the resource path section of
-     * the URI, and MUST be represented inline in the data service's
-     * response.
-     */
-    EXPAND("expand"),
-    /**
-     * This option specifies the media type acceptable in a response. If
-     * present, this value SHOULD take precedence over value(s)
-     * specified in an Accept request header.
-     */
-    FORMAT("format"),
-    /**
-     * This option is used to specify that a subset of the properties of
-     * the entities identified by the path of the request URI and
-     * $expand query option SHOULD be returned in the response
-     * from the data service.
-     */
-    SELECT("select"),
-    /**
-     * This option specifies the sort properties and sort direction
-     * (ascending or descending) that the data service MUST use to
-     * order the entities in the EntitySet, identified by the resource
-     * path section of the URI.
-     */
-    ORDERBY("orderby"),
-    /**
-     * This option specifies a positive integer N that is the maximum
-     * number of entities in the EntitySet, identified by the resource
-     * path section of the URI, that the data service MUST return.
-     */
-    TOP("top"),
-    /**
-     * This option specifies a positive integer N that represents the
-     * number of entities, counted from the first entity in the
-     * EntitySet and ordered as specified by the $orderby option,
-     * that the data service should skip when returning the entities in
-     * the EntitySet, which is identified by the resource path section
-     * of the URI. The data service SHOULD return all subsequent
-     * entities, starting from the one in position N+1.
-     */
-    SKIP("skip"),
-    /**
-     * This query option applies only to the OData 2.0 protocol to the AtomPub protocol.
-     * The value of a $skiptoken query option is an opaque token
-     * which identifies an index into the collection of entities identified
-     * by the URI containing the $skiptoken parameter.
-     */
-    SKIPTOKEN("skiptoken"),
-    /**
-     * This option specifies a predicate used to filter the elements from
-     * the EntitySet identified by the resource path section of the URI.
-     */
-    FILTER("filter"),
-    /**
-     * For a value of "allpages", this option indicates that the response
-     * to the request MUST include the count of the number of entities
-     * in the EntitySet, identified by the resource path section of the
-     * URI after all $filter system query options have been applied.
-     * For a value of "none", this option indicates that the response to
-     * the request MUST NOT include the count value.
-     */
-    INLINECOUNT("inlinecount");
-
-    final String option;
-
-    QueryOption(final String option) {
-        this.option = option;
-    }
-
-    @Override
-    public String toString() {
-        return option;
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/SegmentType.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/SegmentType.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/SegmentType.java
deleted file mode 100644
index 3c1e069..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/SegmentType.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 com.msopentech.odatajclient.engine.uri;
-
-import org.apache.commons.lang3.StringUtils;
-
-/**
- * URI Segment types.
- */
-public enum SegmentType {
-
-    ENTITYSET,
-    ENTITYTYPE,
-    KEY,
-    KEY_AS_SEGMENT,
-    NAVIGATION,
-    STRUCTURAL,
-    VALUE("$value"),
-    FUNCTIONIMPORT,
-    METADATA("$metadata"),
-    BATCH("$batch"),
-    LINKS("$links"),
-    COUNT("$count"),
-    SERVICEROOT;
-
-    private String value;
-
-    private SegmentType() {
-        this.value = StringUtils.EMPTY;
-    }
-
-    private SegmentType(final String value) {
-        this.value = value;
-    }
-
-    public String getValue() {
-        return value;
-    }
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/URIBuilder.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/URIBuilder.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/URIBuilder.java
deleted file mode 100644
index dac0cb1..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/URIBuilder.java
+++ /dev/null
@@ -1,262 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.uri;
-
-import com.msopentech.odatajclient.engine.uri.filter.FilterFactory;
-import com.msopentech.odatajclient.engine.uri.filter.ODataFilter;
-import java.io.Serializable;
-import java.net.URI;
-import java.util.Map;
-
-/**
- * OData URI builder.
- */
-public interface URIBuilder extends Serializable {
-
-    public static class Segment {
-
-        private final SegmentType type;
-
-        private final String value;
-
-        public Segment(final SegmentType type, final String value) {
-            this.type = type;
-            this.value = value;
-        }
-
-        public SegmentType getType() {
-            return type;
-        }
-
-        public String getValue() {
-            return value;
-        }
-
-    }
-
-    /**
-     * Adds the specified query option to the URI.
-     *
-     * @param option query option.
-     * @param value query option value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder addQueryOption(QueryOption option, String value);
-
-    /**
-     * Adds the specified (custom) query option to the URI.
-     *
-     * @param option query option.
-     * @param value query option value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder addQueryOption(String option, String value);
-
-    /**
-     * Append EntitySet segment to the URI.
-     *
-     * @param segmentValue segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendEntitySetSegment(String segmentValue);
-
-    /**
-     * Append EntityType segment to the URI.
-     *
-     * @param segmentValue segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendEntityTypeSegment(String segmentValue);
-
-    /**
-     * Append key segment to the URI.
-     *
-     * @param val segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendKeySegment(Object val);
-
-    /**
-     * Append key segment to the URI, for multiple keys.
-     *
-     * @param segmentValues segment values.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendKeySegment(Map<String, Object> segmentValues);
-
-    /**
-     * Append navigation link segment to the URI.
-     *
-     * @param segmentValue segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendNavigationLinkSegment(String segmentValue);
-
-    /**
-     * Append structural segment to the URI.
-     *
-     * @param segmentValue segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendStructuralSegment(String segmentValue);
-
-    URIBuilder appendLinksSegment(String segmentValue);
-
-    /**
-     * Append value segment to the URI.
-     *
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendValueSegment();
-
-    /**
-     * Append count segment to the URI.
-     *
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendCountSegment();
-
-    /**
-     * Append function import segment to the URI.
-     *
-     * @param segmentValue segment value.
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendFunctionImportSegment(String segmentValue);
-
-    /**
-     * Append metadata segment to the URI.
-     *
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendMetadataSegment();
-
-    /**
-     * Append batch segment to the URI.
-     *
-     * @return current ODataURIBuilder object.
-     */
-    URIBuilder appendBatchSegment();
-
-    /**
-     * Adds expand query option.
-     *
-     * @param entityName entity object to be in-line expanded.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#EXPAND
-     */
-    URIBuilder expand(String entityName);
-
-    /**
-     * Adds format query option.
-     *
-     * @param format media type acceptable in a response.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#FORMAT
-     */
-    URIBuilder format(String format);
-
-    /**
-     * Adds filter for filter query option.
-     *
-     * @param filter filter instance (to be obtained via <tt>ODataFilterFactory</tt>):
-     * note that <tt>build()</tt> method will be immediately invoked.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#FILTER
-     * @see ODataFilter
-     * @see FilterFactory
-     */
-    URIBuilder filter(ODataFilter filter);
-
-    /**
-     * Adds filter query option.
-     *
-     * @param filter filter string.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#FILTER
-     */
-    URIBuilder filter(String filter);
-
-    /**
-     * Adds select query option.
-     *
-     * @param select select query option value.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#SELECT
-     */
-    URIBuilder select(String select);
-
-    /**
-     * Adds orderby query option.
-     *
-     * @param order order string.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#ORDERBY
-     */
-    URIBuilder orderBy(String order);
-
-    /**
-     * Adds top query option.
-     *
-     * @param top maximum number of entities to be returned.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#TOP
-     */
-    URIBuilder top(int top);
-
-    /**
-     * Adds skip query option.
-     *
-     * @param skip number of entities to be skipped into the response.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#SKIP
-     */
-    URIBuilder skip(int skip);
-
-    /**
-     * Adds skiptoken query option.
-     *
-     * @param skipToken opaque token.
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#SKIPTOKEN
-     */
-    URIBuilder skipToken(String skipToken);
-
-    /**
-     * Adds inlinecount query option.
-     *
-     * @return current ODataURIBuilder object.
-     * @see QueryOption#INLINECOUNT
-     */
-    URIBuilder inlineCount();
-
-    /**
-     * Build OData URI.
-     *
-     * @return OData URI.
-     */
-    URI build();
-
-    /**
-     * ${@inheritDoc }
-     */
-    @Override
-    String toString();
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V3URIBuilder.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V3URIBuilder.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V3URIBuilder.java
deleted file mode 100644
index 3b79c5e..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V3URIBuilder.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.uri;
-
-import com.msopentech.odatajclient.engine.client.V3Configuration;
-
-public class V3URIBuilder extends AbstractURIBuilder {
-
-    private static final long serialVersionUID = -3506851722447870532L;
-
-    private final V3Configuration configuration;
-
-    public V3URIBuilder(final V3Configuration configuration, final String serviceRoot) {
-        super(serviceRoot);
-        this.configuration = configuration;
-    }
-
-    @Override
-    protected V3Configuration getConfiguration() {
-        return configuration;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V4URIBuilder.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V4URIBuilder.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V4URIBuilder.java
deleted file mode 100644
index de7093a..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/V4URIBuilder.java
+++ /dev/null
@@ -1,39 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package com.msopentech.odatajclient.engine.uri;
-
-import com.msopentech.odatajclient.engine.client.V4Configuration;
-
-public class V4URIBuilder extends AbstractURIBuilder {
-
-    private static final long serialVersionUID = -3506851722447870532L;
-
-    private final V4Configuration configuration;
-
-    public V4URIBuilder(final V4Configuration configuration, final String serviceRoot) {
-        super(serviceRoot);
-        this.configuration = configuration;
-    }
-
-    @Override
-    protected V4Configuration getConfiguration() {
-        return configuration;
-    }
-
-}

http://git-wip-us.apache.org/repos/asf/olingo-odata4/blob/19f3792f/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/filter/AbstractComparingFilter.java
----------------------------------------------------------------------
diff --git a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/filter/AbstractComparingFilter.java b/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/filter/AbstractComparingFilter.java
deleted file mode 100644
index f4a5389..0000000
--- a/ODataJClient/engine/src/main/java/com/msopentech/odatajclient/engine/uri/filter/AbstractComparingFilter.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 com.msopentech.odatajclient.engine.uri.filter;
-
-abstract class AbstractComparingFilter implements ODataFilter {
-
-    private final ODataFilterArg left;
-
-    private final ODataFilterArg right;
-
-    AbstractComparingFilter(final ODataFilterArg left, final ODataFilterArg right) {
-        this.left = left;
-        this.right = right;
-    }
-
-    protected abstract String getOp();
-
-    @Override
-    public String build() {
-        return new StringBuilder().
-                append('(').append(left.build()).
-                append(' ').append(getOp()).append(' ').
-                append(right.build()).append(')').
-                toString();
-    }
-}