You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tomee.apache.org by db...@apache.org on 2011/06/08 11:31:37 UTC

svn commit: r1133306 - in /openejb/trunk/openejb3: container/openejb-core/src/main/java/org/apache/openejb/cdi/ container/openejb-core/src/test/java/org/apache/openejb/cdi/ tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/ tck/cdi-emb...

Author: dblevins
Date: Wed Jun  8 09:31:36 2011
New Revision: 1133306

URL: http://svn.apache.org/viewvc?rev=1133306&view=rev
Log:
Another step forward in EJB/CDI integration OPENEJB-1197 OPENEJB-1337
Better processing of extension files
Some test cases to demonstrate challenges for some CDI TCK tests

Added:
    openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/BasicObserverTest.java
    openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDecoratorInjectionTest.java
    openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDependentInjectionTest.java
Modified:
    openejb/trunk/openejb3/container/openejb-core/src/main/java/org/apache/openejb/cdi/OpenEJBLifecycle.java
    openejb/trunk/openejb3/tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/Report.java
    openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/failing.xml
    openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/passing.xml

Modified: openejb/trunk/openejb3/container/openejb-core/src/main/java/org/apache/openejb/cdi/OpenEJBLifecycle.java
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/container/openejb-core/src/main/java/org/apache/openejb/cdi/OpenEJBLifecycle.java?rev=1133306&r1=1133305&r2=1133306&view=diff
==============================================================================
--- openejb/trunk/openejb3/container/openejb-core/src/main/java/org/apache/openejb/cdi/OpenEJBLifecycle.java (original)
+++ openejb/trunk/openejb3/container/openejb-core/src/main/java/org/apache/openejb/cdi/OpenEJBLifecycle.java Wed Jun  8 09:31:36 2011
@@ -20,8 +20,14 @@
 
 package org.apache.openejb.cdi;
 
+import java.io.BufferedInputStream;
+import java.io.IOException;
+import java.io.InputStream;
 import java.lang.annotation.Annotation;
+import java.net.URL;
 import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Enumeration;
 import java.util.HashSet;
 import java.util.List;
 import java.util.Properties;
@@ -29,6 +35,9 @@ import java.util.Set;
 
 import javax.enterprise.inject.spi.AnnotatedType;
 import javax.enterprise.inject.spi.BeanManager;
+import javax.enterprise.inject.spi.Extension;
+
+import org.apache.openejb.AppContext;
 import org.apache.openejb.BeanContext;
 import org.apache.openejb.assembler.classic.Assembler;
 import org.apache.webbeans.config.OWBLogConst;
@@ -39,6 +48,7 @@ import org.apache.webbeans.container.Inj
 import org.apache.webbeans.ejb.common.util.EjbUtility;
 import org.apache.webbeans.intercept.InterceptorData;
 import org.apache.webbeans.logger.WebBeansLogger;
+import org.apache.webbeans.portable.events.ExtensionLoader;
 import org.apache.webbeans.portable.events.ProcessAnnotatedTypeImpl;
 import org.apache.webbeans.portable.events.discovery.BeforeShutdownImpl;
 import org.apache.webbeans.spi.ContainerLifecycle;
@@ -49,6 +59,7 @@ import org.apache.webbeans.spi.ScannerSe
 import org.apache.webbeans.util.WebBeansConstants;
 import org.apache.webbeans.util.WebBeansUtil;
 import org.apache.webbeans.xml.WebBeansXMLConfigurator;
+import org.apache.xbean.finder.ResourceFinder;
 
 /**
  * @version $Rev:$ $Date:$
@@ -104,6 +115,30 @@ public class OpenEJBLifecycle implements
         return this.beanManager;
     }
 
+    private String readContents(URL resource) throws IOException {
+        InputStream in = resource.openStream();
+        BufferedInputStream reader = null;
+        StringBuffer sb = new StringBuffer();
+
+        try {
+            reader = new BufferedInputStream(in);
+
+            int b = reader.read();
+            while (b != -1) {
+                sb.append((char) b);
+                b = reader.read();
+            }
+
+            return sb.toString().trim();
+        } finally {
+            try {
+                in.close();
+                reader.close();
+            } catch (Exception e) {
+            }
+        }
+    }
+
     @Override
     public void startApplication(Object startupObject)
     {
@@ -123,8 +158,10 @@ public class OpenEJBLifecycle implements
         //Get Plugin
         CdiPlugin cdiPlugin = (CdiPlugin) webBeansContext.getPluginLoader().getEjbPlugin();
 
-        cdiPlugin.setAppContext(stuff.getAppContext());
-        stuff.getAppContext().setWebBeansContext(webBeansContext);
+        final AppContext appContext = stuff.getAppContext();
+
+        cdiPlugin.setAppContext(appContext);
+        appContext.setWebBeansContext(webBeansContext);
         cdiPlugin.startup();
 
         //Configure EJB Deployments
@@ -133,12 +170,12 @@ public class OpenEJBLifecycle implements
         //Resournce Injection Service
         CdiResourceInjectionService injectionService = (CdiResourceInjectionService) webBeansContext.getService(ResourceInjectionService.class);
         injectionService.setAppModule(stuff.getAppInfo());
-        injectionService.setClassLoader(stuff.getAppContext().getClassLoader());
+        injectionService.setClassLoader(appContext.getClassLoader());
 
         //Deploy the beans
         try {
             //Load Extensions
-            webBeansContext.getExtensionLoader().loadExtensionServices();
+            loadExtensions(appContext);
 
             //Initialize contexts
             this.contextsService.init(startupObject);
@@ -244,6 +281,28 @@ public class OpenEJBLifecycle implements
         logger.info(OWBLogConst.INFO_0001, Long.toString(System.currentTimeMillis() - begin));
     }
 
+    private void loadExtensions(AppContext appContext) throws IOException, ClassNotFoundException, InstantiationException, IllegalAccessException {
+        final ExtensionLoader extensionLoader = webBeansContext.getExtensionLoader();
+
+        // Load regularly visible Extensions
+        extensionLoader.loadExtensionServices(appContext.getClassLoader());
+
+        // Load any potentially misplaced extensions -- TCK seems to be full of them
+        // This could perhaps be improved or addressed elsewhere
+        final String s = "WEB-INF/classes/META-INF/services/javax.enterprise.inject.spi.Extension";
+        final ArrayList<URL> list = Collections.list(appContext.getClassLoader().getResources(s));
+        for (URL url : list) {
+            final String className = readContents(url).trim();
+
+            final Class<?> extensionClass = appContext.getClassLoader().loadClass(className);
+
+            if (Extension.class.isAssignableFrom(extensionClass)) {
+                final Extension extension = (Extension) extensionClass.newInstance();
+                extensionLoader.addExtension(extension);
+            }
+        }
+    }
+
     private void deployManagedBeans(Set<Class<?>> beanClasses, List<BeanContext> ejbs) {
         Set<Class<?>> managedBeans = new HashSet<Class<?>>(beanClasses);
         for (BeanContext beanContext: ejbs) {

Added: openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/BasicObserverTest.java
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/BasicObserverTest.java?rev=1133306&view=auto
==============================================================================
--- openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/BasicObserverTest.java (added)
+++ openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/BasicObserverTest.java Wed Jun  8 09:31:36 2011
@@ -0,0 +1,73 @@
+/**
+ * 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.openejb.cdi;
+
+import org.apache.openejb.jee.Beans;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.junit.Module;
+import org.apache.webbeans.config.WebBeansContext;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import javax.enterprise.event.Observes;
+import javax.enterprise.inject.spi.BeanManager;
+import java.util.ArrayList;
+import java.util.List;
+
+import static junit.framework.Assert.assertEquals;
+import static junit.framework.Assert.assertNotNull;
+
+/**
+ * @version $Rev$ $Date$
+ */
+@RunWith(ApplicationComposer.class)
+public class BasicObserverTest {
+
+    @Test
+    public void test() throws Exception {
+        final BeanManager beanManager = WebBeansContext.getInstance().getBeanManagerImpl();
+        assertNotNull(beanManager);
+
+        final Catastrophy catastrophy = new Catastrophy();
+        beanManager.fireEvent(catastrophy);
+
+        assertEquals(1, catastrophy.getClasses().size());
+        assertEquals(SuperHero.class, catastrophy.getClasses().get(0));
+    }
+
+    @Module
+    public Beans getBeans() {
+        final Beans beans = new Beans();
+        beans.addManagedClass(SuperHero.class);
+        return beans;
+    }
+
+    public static class SuperHero {
+
+        public void jumpToAction(@Observes Catastrophy catastrophy) {
+            catastrophy.getClasses().add(this.getClass());
+        }
+    }
+
+    public static class Catastrophy {
+        private final List<Class> classes = new ArrayList<Class>();
+
+        public List<Class> getClasses() {
+            return classes;
+        }
+    }
+}

Added: openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDecoratorInjectionTest.java
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDecoratorInjectionTest.java?rev=1133306&view=auto
==============================================================================
--- openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDecoratorInjectionTest.java (added)
+++ openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDecoratorInjectionTest.java Wed Jun  8 09:31:36 2011
@@ -0,0 +1,132 @@
+/**
+ * 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.openejb.cdi;
+
+import org.apache.openejb.jee.Beans;
+import org.apache.openejb.jee.SessionBean;
+import org.apache.openejb.jee.SingletonBean;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.junit.Module;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import javax.annotation.Resource;
+import javax.decorator.Decorator;
+import javax.decorator.Delegate;
+import javax.ejb.ApplicationException;
+import javax.ejb.EJB;
+import javax.ejb.EJBAccessException;
+import javax.ejb.Local;
+import javax.ejb.SessionContext;
+import javax.ejb.Stateful;
+import javax.enterprise.inject.Produces;
+import javax.inject.Inject;
+
+import java.security.Principal;
+
+import static junit.framework.Assert.assertNotNull;
+import static junit.framework.Assert.fail;
+
+/**
+ * @version $Rev$ $Date$
+ */
+@RunWith(ApplicationComposer.class)
+public class StatefulDecoratorInjectionTest {
+
+
+    @EJB
+    private OrangeStateful orange;
+
+    @Test
+    public void test() throws Exception {
+
+        assertNotNull(orange);
+
+        try {
+            orange.someBusinessMethod();
+
+            fail("call should not be allowed");
+        } catch (AccessDeniedException e) {
+            // pass
+        }
+    }
+
+    @Module
+    public SessionBean getEjbs() {
+        return new SingletonBean(OrangeStatefulBean.class);
+    }
+
+    @Module
+    public Beans getBeans() {
+        final Beans beans = new Beans();
+        beans.addDecorator(OrangeSecurity.class);
+        return beans;
+    }
+
+    @Local
+    public static interface OrangeStateful {
+
+        public void someBusinessMethod();
+    }
+
+    @Stateful
+    public static class OrangeStatefulBean implements OrangeStateful {
+
+        @Produces
+        @Resource
+        private javax.ejb.SessionContext sessionContext;
+
+        public void someBusinessMethod() {
+
+            // do work
+        }
+    }
+
+    @Decorator
+    public static class OrangeSecurity implements OrangeStateful {
+
+        @Inject
+        private SessionContext sessionContext;
+
+        @Inject
+        @Delegate
+        private OrangeStateful orangeStateful;
+
+        @Override
+        public void someBusinessMethod() {
+            if (!sessionContext.isCallerInRole("worker")) {
+                throw new AccessDeniedException(sessionContext.getCallerPrincipal());
+            }
+
+            orangeStateful.someBusinessMethod();
+        }
+    }
+
+    @ApplicationException
+    public static class AccessDeniedException extends RuntimeException {
+
+        private final Principal principal;
+
+        public AccessDeniedException(Principal principal) {
+            this.principal = principal;
+        }
+
+        public Principal getPrincipal() {
+            return principal;
+        }
+    }
+}

Added: openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDependentInjectionTest.java
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDependentInjectionTest.java?rev=1133306&view=auto
==============================================================================
--- openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDependentInjectionTest.java (added)
+++ openejb/trunk/openejb3/container/openejb-core/src/test/java/org/apache/openejb/cdi/StatefulDependentInjectionTest.java Wed Jun  8 09:31:36 2011
@@ -0,0 +1,105 @@
+/**
+ * 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.openejb.cdi;
+
+import org.apache.openejb.jee.Beans;
+import org.apache.openejb.jee.SessionBean;
+import org.apache.openejb.jee.SingletonBean;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.junit.Module;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import javax.annotation.Resource;
+import javax.ejb.EJB;
+import javax.ejb.SessionContext;
+import javax.ejb.Stateful;
+import javax.enterprise.inject.Produces;
+import javax.inject.Inject;
+
+import static junit.framework.Assert.assertNotNull;
+import static junit.framework.Assert.fail;
+
+/**
+ * @version $Rev$ $Date$
+ */
+@RunWith(ApplicationComposer.class)
+public class StatefulDependentInjectionTest {
+
+
+    @EJB
+    private OrangeStateful orange;
+
+    @Test
+    public void test() throws Exception {
+
+        assertNotNull(orange);
+
+        try {
+            orange.someBusinessMethod();
+
+            fail("call should not be allowed");
+        } catch (IllegalStateException e) {
+            // pass
+        }
+    }
+
+    @Module
+    public SessionBean getEjbs() {
+        return new SingletonBean(OrangeStateful.class);
+    }
+
+    @Module
+    public Beans getBeans() {
+        final Beans beans = new Beans();
+        beans.addManagedClass(Peeler.class);
+        return beans;
+    }
+
+
+    @Stateful
+    public static class OrangeStateful {
+
+        @Produces
+        @Resource
+        private SessionContext sessionContext;
+
+        @Inject
+        private Peeler peeler;
+
+        public void someBusinessMethod() {
+
+            peeler.peel();
+
+        }
+    }
+
+    public static class Peeler {
+
+        @Inject
+        private SessionContext sessionContext;
+
+        public void peel() {
+            if (!sessionContext.isCallerInRole("worker")) {
+                throw new IllegalStateException("denied");
+            }
+
+            // do the work
+        }
+    }
+
+}

Modified: openejb/trunk/openejb3/tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/Report.java
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/Report.java?rev=1133306&r1=1133305&r2=1133306&view=diff
==============================================================================
--- openejb/trunk/openejb3/tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/Report.java (original)
+++ openejb/trunk/openejb3/tck/cdi-embedded/src/test/java/org/apache/openejb/tck/cdi/embedded/Report.java Wed Jun  8 09:31:36 2011
@@ -23,8 +23,10 @@ import org.xml.sax.helpers.DefaultHandle
 import javax.xml.parsers.SAXParser;
 import javax.xml.parsers.SAXParserFactory;
 import java.io.File;
+import java.util.ArrayList;
 import java.util.Collections;
 import java.util.LinkedList;
+import java.util.List;
 
 /**
  * @version $Rev$ $Date$
@@ -38,7 +40,7 @@ public class Report {
     private final LinkedList<TestClass> classes = new LinkedList<TestClass>();
 
     private void main() throws Exception {
-        final File file = new File("/Users/dblevins/work/uber/openejb/tck/cdi-embedded/target/surefire-reports/testng-results.xml");
+        final File file = new File("/Users/dblevins/work/uber/geronimo-tck-public-trunk/jcdi-tck-runner/latest.xml");
 
         final SAXParser parser = SAXParserFactory.newInstance().newSAXParser();
 
@@ -51,7 +53,7 @@ public class Report {
                 }
 
                 if ("test-method".equals(name)) {
-                    classes.getLast().addStatus(attributes.getValue("status"));
+                    classes.getLast().addStatus(attributes.getValue("status"), attributes.getValue("name"));
                 }
             }
         });
@@ -60,31 +62,54 @@ public class Report {
 
         int i = 0;
         for (TestClass testClass : classes) {
-            if (!testClass.hasFailures()) continue;
-            System.out.printf("<class name=\"%s\"/>\n", testClass.name);
-            i++;
+
+            for (TestResult result : testClass.getResults()) {
+                if (result.status == Status.PASS) continue;
+
+                System.out.printf("%s(%s)\n", result.name, testClass.name);
+            }
         }
+        i++;
 
         System.out.println(i);
     }
 
+    public static enum Status {
+        PASS, FAIL, ERROR;
+    }
+    public static class TestResult {
+        private final String name;
+        private final Status status;
+
+        public TestResult(String name, Status status) {
+            this.name = name;
+            this.status = status;
+        }
+    }
+
     public static class TestClass implements Comparable<TestClass>{
 
         private final String name;
         private int failed;
         private int passed;
         private int error;
+        private final List<TestResult> results = new ArrayList<TestResult>();
 
         public TestClass(String name) {
             this.name = name;
         }
 
-        public void addStatus(String status) {
+        public void addStatus(String status, String testName) {
+            results.add(new TestResult(testName, Status.valueOf(status)));
             if ("PASS".equals(status)) passed++;
             if ("FAIL".equals(status)) failed++;
             if ("ERROR".equals(status)) error++;
         }
 
+        public List<TestResult> getResults() {
+            return results;
+        }
+
         public boolean hasFailures() {
             return failed > 0 || error > 0;
         }

Modified: openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/failing.xml
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/failing.xml?rev=1133306&r1=1133305&r2=1133306&view=diff
==============================================================================
--- openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/failing.xml (original)
+++ openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/failing.xml Wed Jun  8 09:31:36 2011
@@ -8,38 +8,37 @@
     <!--</packages>-->
 
     <classes>
-      <class name="org.jboss.jsr299.tck.tests.context.application.ejb.ApplicationContextSharedTest"/>
-      <class name="org.jboss.jsr299.tck.tests.context.dependent.ejb.DependentContextEjbTest"/>
-      <class name="org.jboss.jsr299.tck.tests.context.passivating.PassivatingContextTest"/>
-      <class name="org.jboss.jsr299.tck.tests.context.passivating.broken.dependentScopedProducerFieldReturnsNonSerializableObjectForInjectionIntoStatefulSessionBean.EnterpriseBeanWithIllegalDependencyTest"/>
-      <class name="org.jboss.jsr299.tck.tests.context.passivating.broken.dependentScopedProducerMethodReturnsNonSerializableObjectForInjectionIntoStatefulSessionBean.EnterpriseBeanWithIllegalDependencyTest"/>
-      <class name="org.jboss.jsr299.tck.tests.context.request.ejb.EJBRequestContextTest"/>
-      <class name="org.jboss.jsr299.tck.tests.deployment.packaging.bundledLibrary.LibraryInEarTest"/>
-      <class name="org.jboss.jsr299.tck.tests.event.observer.enterprise.EnterpriseEventInheritenceTest"/>
-      <class name="org.jboss.jsr299.tck.tests.extensions.container.event.ContainerEventTest"/>
+      <!--<class name="org.jboss.jsr299.tck.tests.context.application.ejb.ApplicationContextSharedTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.context.dependent.ejb.DependentContextEjbTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.context.passivating.PassivatingContextTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.context.passivating.broken.dependentScopedProducerFieldReturnsNonSerializableObjectForInjectionIntoStatefulSessionBean.EnterpriseBeanWithIllegalDependencyTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.context.passivating.broken.dependentScopedProducerMethodReturnsNonSerializableObjectForInjectionIntoStatefulSessionBean.EnterpriseBeanWithIllegalDependencyTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.context.request.ejb.EJBRequestContextTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.deployment.packaging.bundledLibrary.LibraryInEarTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.event.observer.enterprise.EnterpriseEventInheritenceTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.extensions.container.event.ContainerEventTest"/>-->
       <class name="org.jboss.jsr299.tck.tests.extensions.processBean.ProcessSessionBeanTest"/>
-      <class name="org.jboss.jsr299.tck.tests.extensions.producer.ProducerTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.builtin.BuiltInBeansTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.definition.EnterpriseBeanDefinitionTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.definition.EnterpriseBeanViaXmlTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.lifecycle.EnterpriseBeanLifecycleTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.newBean.NewEnterpriseBeanICTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.newBean.NewEnterpriseBeanTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.enterprise.remove.EnterpriseBeanRemoveMethodTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.initializer.EjbInitializerMethodTest"/>
-      <class name="org.jboss.jsr299.tck.tests.implementation.producer.method.definition.enterprise.EnterpriseProducerMethodDefinitionTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.EnterpriseBeanSpecializationIntegrationTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.EnterpriseBeanSpecializationTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.directlyExtendsNothing.DirectlyExtendsNothingTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.directlyExtendsSimpleBean.DirectlyExtendsSimpleBeanTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.implementInterfaceAndExtendsNothing.ImplementsInterfaceAndExtendsNothingTest"/>
-      <class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.sameName.SameNameTest"/>
-      <class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.interceptorOrder.SessionBeanInterceptorOrderTest"/>
-      <class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.nonContextualReference.SessionBeanInterceptorOnNonContextualEjbReferenceTest"/>
-      <class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.simpleInterception.SessionBeanInterceptorDefinitionTest"/>
-      <class name="org.jboss.jsr299.tck.tests.lookup.injection.enterprise.SessionBeanInjectionOrderingTest"/>
-      <class name="org.jboss.jsr299.tck.tests.lookup.injection.non.contextual.ws.InjectionIntoWebServiceEndPointTest"/>
-      <class name="org.jboss.jsr299.tck.tests.lookup.typesafe.resolution.parameterized.AssignabilityOfRawAndParameterizedTypesTest"/>
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.builtin.BuiltInBeansTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.definition.EnterpriseBeanDefinitionTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.definition.EnterpriseBeanViaXmlTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.lifecycle.EnterpriseBeanLifecycleTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.newBean.NewEnterpriseBeanICTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.newBean.NewEnterpriseBeanTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.enterprise.remove.EnterpriseBeanRemoveMethodTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.initializer.EjbInitializerMethodTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.implementation.producer.method.definition.enterprise.EnterpriseProducerMethodDefinitionTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.EnterpriseBeanSpecializationIntegrationTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.EnterpriseBeanSpecializationTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.directlyExtendsNothing.DirectlyExtendsNothingTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.directlyExtendsSimpleBean.DirectlyExtendsSimpleBeanTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.implementInterfaceAndExtendsNothing.ImplementsInterfaceAndExtendsNothingTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.inheritance.specialization.enterprise.broken.sameName.SameNameTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.interceptorOrder.SessionBeanInterceptorOrderTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.nonContextualReference.SessionBeanInterceptorOnNonContextualEjbReferenceTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.interceptors.definition.enterprise.simpleInterception.SessionBeanInterceptorDefinitionTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.lookup.injection.enterprise.SessionBeanInjectionOrderingTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.lookup.injection.non.contextual.ws.InjectionIntoWebServiceEndPointTest"/>-->
+      <!--<class name="org.jboss.jsr299.tck.tests.lookup.typesafe.resolution.parameterized.AssignabilityOfRawAndParameterizedTypesTest"/>-->
     </classes>
   </test>
 </suite>

Modified: openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/passing.xml
URL: http://svn.apache.org/viewvc/openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/passing.xml?rev=1133306&r1=1133305&r2=1133306&view=diff
==============================================================================
--- openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/passing.xml (original)
+++ openejb/trunk/openejb3/tck/cdi-embedded/src/test/resources/passing.xml Wed Jun  8 09:31:36 2011
@@ -99,6 +99,7 @@
       <class name="org.jboss.jsr299.tck.tests.event.fires.nonbinding.NonBindingTypePassedToFireTest"/>
       <class name="org.jboss.jsr299.tck.tests.event.implicit.ImplicitEventTest"/>
       <class name="org.jboss.jsr299.tck.tests.event.observer.ObserverTest"/>
+      <class name="org.jboss.jsr299.tck.tests.extensions.producer.ProducerTest"/>
       <class name="org.jboss.jsr299.tck.tests.event.observer.abortProcessing.ObserverExceptionAbortsProcessingTest"/>
       <class name="org.jboss.jsr299.tck.tests.event.observer.checkedException.CheckedExceptionWrappedTest"/>
       <class name="org.jboss.jsr299.tck.tests.event.observer.conditional.ConditionalObserverTest"/>