You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@deltaspike.apache.org by gp...@apache.org on 2012/07/16 00:40:33 UTC

git commit: DELTASPIKE-244 unified names for base-classes

Updated Branches:
  refs/heads/master c14bf5052 -> 45712e0c7


DELTASPIKE-244 unified names for base-classes


Project: http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/commit/45712e0c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/tree/45712e0c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/diff/45712e0c

Branch: refs/heads/master
Commit: 45712e0c7486efaf48605271a66426163bea84a7
Parents: c14bf50
Author: gpetracek <gp...@apache.org>
Authored: Mon Jul 16 00:38:32 2012 +0200
Committer: gpetracek <gp...@apache.org>
Committed: Mon Jul 16 00:38:32 2012 +0200

----------------------------------------------------------------------
 .../AbstractPropertyExpressionInterpreter.java     |  100 -------
 .../BasePropertyExpressionInterpreter.java         |  100 +++++++
 .../core/api/interpreter/SimpleOperationEnum.java  |    2 +-
 .../core/util/bean/AbstractImmutableBean.java      |  227 ---------------
 .../core/util/bean/BaseImmutableBean.java          |  227 +++++++++++++++
 .../core/util/bean/ImmutableBeanWrapper.java       |    2 +-
 .../interpreter/PropertyExpressionInterpreter.java |    4 +-
 7 files changed, 331 insertions(+), 331 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/AbstractPropertyExpressionInterpreter.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/AbstractPropertyExpressionInterpreter.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/AbstractPropertyExpressionInterpreter.java
deleted file mode 100644
index 0bdaa39..0000000
--- a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/AbstractPropertyExpressionInterpreter.java
+++ /dev/null
@@ -1,100 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.deltaspike.core.api.interpreter;
-
-/**
- * Base implementation for simple (property) expressions
- *
- * Supported operations:<p/>
- * <ul>
- *     <li>[key]==[value]</li>
- *     <li>[key]!=[value]</li>
- *     <li>[key]==* (a value is required)</li>
- *     <li>; (separator)</li>
- * </ul>
- */
-public abstract class AbstractPropertyExpressionInterpreter implements ExpressionInterpreter<String, Boolean>
-{
-    private static final String ASTERISK = "*";
-
-    @Override
-    public final Boolean evaluate(String expressions)
-    {
-        boolean result = false;
-        String[] foundExpressions = expressions.split(";");
-
-        SimpleOperationEnum operation;
-        for (String expression : foundExpressions)
-        {
-            result = false;
-            if (expression.contains(SimpleOperationEnum.IS.getValue()))
-            {
-                operation = SimpleOperationEnum.IS;
-            }
-            else if (expression.contains(SimpleOperationEnum.NOT.getValue()))
-            {
-                operation = SimpleOperationEnum.NOT;
-            }
-            else
-            {
-                throw new IllegalStateException("expression: " + expression + " isn't supported by " +
-                        getClass().getName() + " supported operations: " + SimpleOperationEnum.getOperations() +
-                        "separator: ';'");
-            }
-
-            String[] keyValue = expression.split(operation.getValue());
-
-            String configuredValue = getConfiguredValue(keyValue[0]);
-
-            if (configuredValue != null)
-            {
-                configuredValue = configuredValue.trim();
-            }
-            else
-            {
-                configuredValue = "";
-            }
-
-            if (!ASTERISK.equals(keyValue[1]) && "".equals(configuredValue))
-            {
-                continue;
-            }
-
-            if (ASTERISK.equals(keyValue[1]) && !"".equals(configuredValue))
-            {
-                result = true;
-                continue;
-            }
-
-            if (SimpleOperationEnum.IS.equals(operation) && !keyValue[1].equalsIgnoreCase(configuredValue))
-            {
-                return false;
-            }
-            else if (SimpleOperationEnum.NOT.equals(operation) && keyValue[1].equalsIgnoreCase(configuredValue))
-            {
-                return false;
-            }
-            result = true;
-        }
-
-        return result;
-    }
-
-    protected abstract String getConfiguredValue(String key);
-}

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/BasePropertyExpressionInterpreter.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/BasePropertyExpressionInterpreter.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/BasePropertyExpressionInterpreter.java
new file mode 100644
index 0000000..4c6935e
--- /dev/null
+++ b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/BasePropertyExpressionInterpreter.java
@@ -0,0 +1,100 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied. See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.deltaspike.core.api.interpreter;
+
+/**
+ * Base implementation for simple (property) expressions
+ *
+ * Supported operations:<p/>
+ * <ul>
+ *     <li>[key]==[value]</li>
+ *     <li>[key]!=[value]</li>
+ *     <li>[key]==* (a value is required)</li>
+ *     <li>; (separator)</li>
+ * </ul>
+ */
+public abstract class BasePropertyExpressionInterpreter implements ExpressionInterpreter<String, Boolean>
+{
+    private static final String ASTERISK = "*";
+
+    @Override
+    public final Boolean evaluate(String expressions)
+    {
+        boolean result = false;
+        String[] foundExpressions = expressions.split(";");
+
+        SimpleOperationEnum operation;
+        for (String expression : foundExpressions)
+        {
+            result = false;
+            if (expression.contains(SimpleOperationEnum.IS.getValue()))
+            {
+                operation = SimpleOperationEnum.IS;
+            }
+            else if (expression.contains(SimpleOperationEnum.NOT.getValue()))
+            {
+                operation = SimpleOperationEnum.NOT;
+            }
+            else
+            {
+                throw new IllegalStateException("expression: " + expression + " isn't supported by " +
+                        getClass().getName() + " supported operations: " + SimpleOperationEnum.getOperations() +
+                        "separator: ';'");
+            }
+
+            String[] keyValue = expression.split(operation.getValue());
+
+            String configuredValue = getConfiguredValue(keyValue[0]);
+
+            if (configuredValue != null)
+            {
+                configuredValue = configuredValue.trim();
+            }
+            else
+            {
+                configuredValue = "";
+            }
+
+            if (!ASTERISK.equals(keyValue[1]) && "".equals(configuredValue))
+            {
+                continue;
+            }
+
+            if (ASTERISK.equals(keyValue[1]) && !"".equals(configuredValue))
+            {
+                result = true;
+                continue;
+            }
+
+            if (SimpleOperationEnum.IS.equals(operation) && !keyValue[1].equalsIgnoreCase(configuredValue))
+            {
+                return false;
+            }
+            else if (SimpleOperationEnum.NOT.equals(operation) && keyValue[1].equalsIgnoreCase(configuredValue))
+            {
+                return false;
+            }
+            result = true;
+        }
+
+        return result;
+    }
+
+    protected abstract String getConfiguredValue(String key);
+}

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/SimpleOperationEnum.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/SimpleOperationEnum.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/SimpleOperationEnum.java
index 9638e50..29634d7 100644
--- a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/SimpleOperationEnum.java
+++ b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/api/interpreter/SimpleOperationEnum.java
@@ -19,7 +19,7 @@
 package org.apache.deltaspike.core.api.interpreter;
 
 /**
- * Operations supported by {@link AbstractPropertyExpressionInterpreter}
+ * Operations supported by {@link BasePropertyExpressionInterpreter}
  */
 enum SimpleOperationEnum
 {

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/AbstractImmutableBean.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/AbstractImmutableBean.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/AbstractImmutableBean.java
deleted file mode 100644
index 3377d6f..0000000
--- a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/AbstractImmutableBean.java
+++ /dev/null
@@ -1,227 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements. See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership. The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License. You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied. See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.deltaspike.core.util.bean;
-
-import java.lang.annotation.Annotation;
-import java.lang.reflect.Type;
-import java.util.Collections;
-import java.util.HashSet;
-import java.util.Set;
-import java.util.logging.Logger;
-
-import javax.enterprise.context.Dependent;
-import javax.enterprise.inject.spi.Bean;
-import javax.enterprise.inject.spi.InjectionPoint;
-
-import org.apache.deltaspike.core.api.literal.DefaultLiteral;
-import org.apache.deltaspike.core.util.ArraysUtils;
-
-/**
- * <p>
- * A base class for implementing {@link Bean}. The attributes are immutable, and
- * collections are defensively copied on instantiation. It uses the defaults
- * from the specification for properties if not specified.
- * </p>
- * <p/>
- * <p>
- * This class does not provide any bean lifecycle operations
- * </p>
- *
- * @see ImmutableBeanWrapper
- */
-public abstract class AbstractImmutableBean<T> implements Bean<T>
-{
-    private static final Logger LOG = Logger.getLogger(AbstractImmutableBean.class.getName());
-
-    private final Class<?> beanClass;
-    private final String name;
-    private final Set<Annotation> qualifiers;
-    private final Class<? extends Annotation> scope;
-    private final Set<Class<? extends Annotation>> stereotypes;
-    private final Set<Type> types;
-    private final boolean alternative;
-    private final boolean nullable;
-    private final Set<InjectionPoint> injectionPoints;
-    private final String toString;
-
-    /**
-     * Create a new, immutable bean. All arguments passed as collections are
-     * defensively copied.
-     *
-     * @param beanClass       The Bean class, may not be null
-     * @param name            The bean name
-     * @param qualifiers      The bean's qualifiers, if null, a singleton set of
-     *                        {@link javax.enterprise.inject.Default} is used
-     * @param scope           The bean's scope, if null, the default scope of
-     *                        {@link Dependent} is used
-     * @param stereotypes     The bean's stereotypes, if null, an empty set is used
-     * @param types           The bean's types, if null, the beanClass and {@link Object}
-     *                        will be used
-     * @param alternative     True if the bean is an alternative
-     * @param nullable        True if the bean is nullable
-     * @param injectionPoints the bean's injection points, if null an empty set is used
-     * @param toString        the string which should be returned by #{@link #toString()}
-     * @throws IllegalArgumentException if the beanClass is null
-     */
-    public AbstractImmutableBean(Class<?> beanClass,
-                                 String name,
-                                 Set<Annotation> qualifiers,
-                                 Class<? extends Annotation> scope,
-                                 Set<Class<? extends Annotation>> stereotypes,
-                                 Set<Type> types,
-                                 boolean alternative,
-                                 boolean nullable,
-                                 Set<InjectionPoint> injectionPoints,
-                                 String toString)
-    {
-        if (beanClass == null)
-        {
-            throw new IllegalArgumentException("beanClass cannot be null");
-        }
-
-        this.beanClass = beanClass;
-        this.name = name;
-
-        if (qualifiers == null)
-        {
-            this.qualifiers = Collections.<Annotation>singleton(new DefaultLiteral());
-
-            LOG.finest("No qualifers provided for bean class " + beanClass + ", using singleton set of @Default");
-        }
-        else
-        {
-            this.qualifiers = new HashSet<Annotation>(qualifiers);
-        }
-
-        if (scope == null)
-        {
-            this.scope = Dependent.class;
-
-            LOG.finest("No scope provided for bean class " + beanClass + ", using @Dependent");
-        }
-        else
-        {
-            this.scope = scope;
-        }
-
-        if (stereotypes == null)
-        {
-            this.stereotypes = Collections.emptySet();
-        }
-        else
-        {
-            this.stereotypes = new HashSet<Class<? extends Annotation>>(stereotypes);
-        }
-
-        if (types == null)
-        {
-            //noinspection unchecked
-            this.types = ArraysUtils.<Type>asSet(Object.class, beanClass);
-
-            LOG.finest("No types provided for bean class " + beanClass
-                    + ", using [java.lang.Object.class, " + beanClass.getName()
-                    + ".class]");
-        }
-        else
-        {
-            this.types = new HashSet<Type>(types);
-        }
-
-        if (injectionPoints == null)
-        {
-            this.injectionPoints = Collections.emptySet();
-        }
-        else
-        {
-            this.injectionPoints = new HashSet<InjectionPoint>(injectionPoints);
-        }
-
-        this.alternative = alternative;
-        this.nullable = nullable;
-
-        if (toString != null)
-        {
-            this.toString = toString;
-        }
-        else
-        {
-            this.toString = "Custom Bean with bean class " + beanClass + " and qualifiers " + qualifiers;
-        }
-    }
-
-    @Override
-    public Class<?> getBeanClass()
-    {
-        return beanClass;
-    }
-
-    @Override
-    public Set<InjectionPoint> getInjectionPoints()
-    {
-        return injectionPoints;
-    }
-
-    @Override
-    public String getName()
-    {
-        return name;
-    }
-
-    @Override
-    public Set<Annotation> getQualifiers()
-    {
-        return Collections.unmodifiableSet(qualifiers);
-    }
-
-    @Override
-    public Class<? extends Annotation> getScope()
-    {
-        return scope;
-    }
-
-    @Override
-    public Set<Class<? extends Annotation>> getStereotypes()
-    {
-        return Collections.unmodifiableSet(stereotypes);
-    }
-
-    @Override
-    public Set<Type> getTypes()
-    {
-        return Collections.unmodifiableSet(types);
-    }
-
-    @Override
-    public boolean isAlternative()
-    {
-        return alternative;
-    }
-
-    @Override
-    public boolean isNullable()
-    {
-        return nullable;
-    }
-
-    @Override
-    public String toString()
-    {
-        return toString;
-    }
-}

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/BaseImmutableBean.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/BaseImmutableBean.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/BaseImmutableBean.java
new file mode 100644
index 0000000..ed7ba8b
--- /dev/null
+++ b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/BaseImmutableBean.java
@@ -0,0 +1,227 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied. See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+package org.apache.deltaspike.core.util.bean;
+
+import java.lang.annotation.Annotation;
+import java.lang.reflect.Type;
+import java.util.Collections;
+import java.util.HashSet;
+import java.util.Set;
+import java.util.logging.Logger;
+
+import javax.enterprise.context.Dependent;
+import javax.enterprise.inject.spi.Bean;
+import javax.enterprise.inject.spi.InjectionPoint;
+
+import org.apache.deltaspike.core.api.literal.DefaultLiteral;
+import org.apache.deltaspike.core.util.ArraysUtils;
+
+/**
+ * <p>
+ * A base class for implementing {@link Bean}. The attributes are immutable, and
+ * collections are defensively copied on instantiation. It uses the defaults
+ * from the specification for properties if not specified.
+ * </p>
+ * <p/>
+ * <p>
+ * This class does not provide any bean lifecycle operations
+ * </p>
+ *
+ * @see ImmutableBeanWrapper
+ */
+public abstract class BaseImmutableBean<T> implements Bean<T>
+{
+    private static final Logger LOG = Logger.getLogger(BaseImmutableBean.class.getName());
+
+    private final Class<?> beanClass;
+    private final String name;
+    private final Set<Annotation> qualifiers;
+    private final Class<? extends Annotation> scope;
+    private final Set<Class<? extends Annotation>> stereotypes;
+    private final Set<Type> types;
+    private final boolean alternative;
+    private final boolean nullable;
+    private final Set<InjectionPoint> injectionPoints;
+    private final String toString;
+
+    /**
+     * Create a new, immutable bean. All arguments passed as collections are
+     * defensively copied.
+     *
+     * @param beanClass       The Bean class, may not be null
+     * @param name            The bean name
+     * @param qualifiers      The bean's qualifiers, if null, a singleton set of
+     *                        {@link javax.enterprise.inject.Default} is used
+     * @param scope           The bean's scope, if null, the default scope of
+     *                        {@link Dependent} is used
+     * @param stereotypes     The bean's stereotypes, if null, an empty set is used
+     * @param types           The bean's types, if null, the beanClass and {@link Object}
+     *                        will be used
+     * @param alternative     True if the bean is an alternative
+     * @param nullable        True if the bean is nullable
+     * @param injectionPoints the bean's injection points, if null an empty set is used
+     * @param toString        the string which should be returned by #{@link #toString()}
+     * @throws IllegalArgumentException if the beanClass is null
+     */
+    public BaseImmutableBean(Class<?> beanClass,
+                             String name,
+                             Set<Annotation> qualifiers,
+                             Class<? extends Annotation> scope,
+                             Set<Class<? extends Annotation>> stereotypes,
+                             Set<Type> types,
+                             boolean alternative,
+                             boolean nullable,
+                             Set<InjectionPoint> injectionPoints,
+                             String toString)
+    {
+        if (beanClass == null)
+        {
+            throw new IllegalArgumentException("beanClass cannot be null");
+        }
+
+        this.beanClass = beanClass;
+        this.name = name;
+
+        if (qualifiers == null)
+        {
+            this.qualifiers = Collections.<Annotation>singleton(new DefaultLiteral());
+
+            LOG.finest("No qualifers provided for bean class " + beanClass + ", using singleton set of @Default");
+        }
+        else
+        {
+            this.qualifiers = new HashSet<Annotation>(qualifiers);
+        }
+
+        if (scope == null)
+        {
+            this.scope = Dependent.class;
+
+            LOG.finest("No scope provided for bean class " + beanClass + ", using @Dependent");
+        }
+        else
+        {
+            this.scope = scope;
+        }
+
+        if (stereotypes == null)
+        {
+            this.stereotypes = Collections.emptySet();
+        }
+        else
+        {
+            this.stereotypes = new HashSet<Class<? extends Annotation>>(stereotypes);
+        }
+
+        if (types == null)
+        {
+            //noinspection unchecked
+            this.types = ArraysUtils.<Type>asSet(Object.class, beanClass);
+
+            LOG.finest("No types provided for bean class " + beanClass
+                    + ", using [java.lang.Object.class, " + beanClass.getName()
+                    + ".class]");
+        }
+        else
+        {
+            this.types = new HashSet<Type>(types);
+        }
+
+        if (injectionPoints == null)
+        {
+            this.injectionPoints = Collections.emptySet();
+        }
+        else
+        {
+            this.injectionPoints = new HashSet<InjectionPoint>(injectionPoints);
+        }
+
+        this.alternative = alternative;
+        this.nullable = nullable;
+
+        if (toString != null)
+        {
+            this.toString = toString;
+        }
+        else
+        {
+            this.toString = "Custom Bean with bean class " + beanClass + " and qualifiers " + qualifiers;
+        }
+    }
+
+    @Override
+    public Class<?> getBeanClass()
+    {
+        return beanClass;
+    }
+
+    @Override
+    public Set<InjectionPoint> getInjectionPoints()
+    {
+        return injectionPoints;
+    }
+
+    @Override
+    public String getName()
+    {
+        return name;
+    }
+
+    @Override
+    public Set<Annotation> getQualifiers()
+    {
+        return Collections.unmodifiableSet(qualifiers);
+    }
+
+    @Override
+    public Class<? extends Annotation> getScope()
+    {
+        return scope;
+    }
+
+    @Override
+    public Set<Class<? extends Annotation>> getStereotypes()
+    {
+        return Collections.unmodifiableSet(stereotypes);
+    }
+
+    @Override
+    public Set<Type> getTypes()
+    {
+        return Collections.unmodifiableSet(types);
+    }
+
+    @Override
+    public boolean isAlternative()
+    {
+        return alternative;
+    }
+
+    @Override
+    public boolean isNullable()
+    {
+        return nullable;
+    }
+
+    @Override
+    public String toString()
+    {
+        return toString;
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/ImmutableBeanWrapper.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/ImmutableBeanWrapper.java b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/ImmutableBeanWrapper.java
index 220acde..3fb3ad0 100644
--- a/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/ImmutableBeanWrapper.java
+++ b/deltaspike/core/api/src/main/java/org/apache/deltaspike/core/util/bean/ImmutableBeanWrapper.java
@@ -68,7 +68,7 @@ import javax.enterprise.inject.spi.Bean;
  *
  * @see org.apache.deltaspike.core.util.bean.WrappingBeanBuilder
  */
-public class ImmutableBeanWrapper<T> extends AbstractImmutableBean<T>
+public class ImmutableBeanWrapper<T> extends BaseImmutableBean<T>
 {
     private final Bean<T> wrapped;
 

http://git-wip-us.apache.org/repos/asf/incubator-deltaspike/blob/45712e0c/deltaspike/core/impl/src/main/java/org/apache/deltaspike/core/impl/interpreter/PropertyExpressionInterpreter.java
----------------------------------------------------------------------
diff --git a/deltaspike/core/impl/src/main/java/org/apache/deltaspike/core/impl/interpreter/PropertyExpressionInterpreter.java b/deltaspike/core/impl/src/main/java/org/apache/deltaspike/core/impl/interpreter/PropertyExpressionInterpreter.java
index 8ad33fc..61e5558 100644
--- a/deltaspike/core/impl/src/main/java/org/apache/deltaspike/core/impl/interpreter/PropertyExpressionInterpreter.java
+++ b/deltaspike/core/impl/src/main/java/org/apache/deltaspike/core/impl/interpreter/PropertyExpressionInterpreter.java
@@ -19,12 +19,12 @@
 package org.apache.deltaspike.core.impl.interpreter;
 
 import org.apache.deltaspike.core.api.config.ConfigResolver;
-import org.apache.deltaspike.core.api.interpreter.AbstractPropertyExpressionInterpreter;
+import org.apache.deltaspike.core.api.interpreter.BasePropertyExpressionInterpreter;
 
 /**
  * Interpreter which uses the lookup chain of DeltaSpike for configured values
  */
-public class PropertyExpressionInterpreter extends AbstractPropertyExpressionInterpreter
+public class PropertyExpressionInterpreter extends BasePropertyExpressionInterpreter
 {
     /**
      * {@inheritDoc}