You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tomee.apache.org by an...@apache.org on 2015/12/01 23:03:29 UTC

[17/77] [abbrv] [partial] tomee git commit: removing ^M (windows eol)

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/application-composer/src/test/java/org/superbiz/composed/MoviesTest.java
----------------------------------------------------------------------
diff --git a/examples/application-composer/src/test/java/org/superbiz/composed/MoviesTest.java b/examples/application-composer/src/test/java/org/superbiz/composed/MoviesTest.java
index 3cd5f78..d5afb06 100644
--- a/examples/application-composer/src/test/java/org/superbiz/composed/MoviesTest.java
+++ b/examples/application-composer/src/test/java/org/superbiz/composed/MoviesTest.java
@@ -1,100 +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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.composed;
-
-import junit.framework.TestCase;
-import org.apache.openejb.jee.EjbJar;
-import org.apache.openejb.jee.StatefulBean;
-import org.apache.openejb.jee.jpa.unit.PersistenceUnit;
-import org.apache.openejb.junit.ApplicationComposer;
-import org.apache.openejb.testing.Configuration;
-import org.apache.openejb.testing.Module;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import javax.annotation.Resource;
-import javax.ejb.EJB;
-import javax.persistence.EntityManager;
-import javax.persistence.PersistenceContext;
-import javax.transaction.UserTransaction;
-import java.util.List;
-import java.util.Properties;
-
-//START SNIPPET: code
-@RunWith(ApplicationComposer.class)
-public class MoviesTest extends TestCase {
-
-    @EJB
-    private Movies movies;
-
-    @Resource
-    private UserTransaction userTransaction;
-
-    @PersistenceContext
-    private EntityManager entityManager;
-
-    @Module
-    public PersistenceUnit persistence() {
-        PersistenceUnit unit = new PersistenceUnit("movie-unit");
-        unit.setJtaDataSource("movieDatabase");
-        unit.setNonJtaDataSource("movieDatabaseUnmanaged");
-        unit.getClazz().add(Movie.class.getName());
-        unit.setProperty("openjpa.jdbc.SynchronizeMappings", "buildSchema(ForeignKeys=true)");
-        return unit;
-    }
-
-    @Module
-    public EjbJar beans() {
-        EjbJar ejbJar = new EjbJar("movie-beans");
-        ejbJar.addEnterpriseBean(new StatefulBean(MoviesImpl.class));
-        return ejbJar;
-    }
-
-    @Configuration
-    public Properties config() throws Exception {
-        Properties p = new Properties();
-        p.put("movieDatabase", "new://Resource?type=DataSource");
-        p.put("movieDatabase.JdbcDriver", "org.hsqldb.jdbcDriver");
-        p.put("movieDatabase.JdbcUrl", "jdbc:hsqldb:mem:moviedb");
-        return p;
-    }
-
-    @Test
-    public void test() throws Exception {
-
-        userTransaction.begin();
-
-        try {
-            entityManager.persist(new Movie("Quentin Tarantino", "Reservoir Dogs", 1992));
-            entityManager.persist(new Movie("Joel Coen", "Fargo", 1996));
-            entityManager.persist(new Movie("Joel Coen", "The Big Lebowski", 1998));
-
-            List<Movie> list = movies.getMovies();
-            assertEquals("List.size()", 3, list.size());
-
-            for (Movie movie : list) {
-                movies.deleteMovie(movie);
-            }
-
-            assertEquals("Movies.getMovies()", 0, movies.getMovies().size());
-
-        } finally {
-            userTransaction.commit();
-        }
-    }
-}
-//END SNIPPET: code
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.composed;
+
+import junit.framework.TestCase;
+import org.apache.openejb.jee.EjbJar;
+import org.apache.openejb.jee.StatefulBean;
+import org.apache.openejb.jee.jpa.unit.PersistenceUnit;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.testing.Configuration;
+import org.apache.openejb.testing.Module;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import javax.annotation.Resource;
+import javax.ejb.EJB;
+import javax.persistence.EntityManager;
+import javax.persistence.PersistenceContext;
+import javax.transaction.UserTransaction;
+import java.util.List;
+import java.util.Properties;
+
+//START SNIPPET: code
+@RunWith(ApplicationComposer.class)
+public class MoviesTest extends TestCase {
+
+    @EJB
+    private Movies movies;
+
+    @Resource
+    private UserTransaction userTransaction;
+
+    @PersistenceContext
+    private EntityManager entityManager;
+
+    @Module
+    public PersistenceUnit persistence() {
+        PersistenceUnit unit = new PersistenceUnit("movie-unit");
+        unit.setJtaDataSource("movieDatabase");
+        unit.setNonJtaDataSource("movieDatabaseUnmanaged");
+        unit.getClazz().add(Movie.class.getName());
+        unit.setProperty("openjpa.jdbc.SynchronizeMappings", "buildSchema(ForeignKeys=true)");
+        return unit;
+    }
+
+    @Module
+    public EjbJar beans() {
+        EjbJar ejbJar = new EjbJar("movie-beans");
+        ejbJar.addEnterpriseBean(new StatefulBean(MoviesImpl.class));
+        return ejbJar;
+    }
+
+    @Configuration
+    public Properties config() throws Exception {
+        Properties p = new Properties();
+        p.put("movieDatabase", "new://Resource?type=DataSource");
+        p.put("movieDatabase.JdbcDriver", "org.hsqldb.jdbcDriver");
+        p.put("movieDatabase.JdbcUrl", "jdbc:hsqldb:mem:moviedb");
+        return p;
+    }
+
+    @Test
+    public void test() throws Exception {
+
+        userTransaction.begin();
+
+        try {
+            entityManager.persist(new Movie("Quentin Tarantino", "Reservoir Dogs", 1992));
+            entityManager.persist(new Movie("Joel Coen", "Fargo", 1996));
+            entityManager.persist(new Movie("Joel Coen", "The Big Lebowski", 1998));
+
+            List<Movie> list = movies.getMovies();
+            assertEquals("List.size()", 3, list.size());
+
+            for (Movie movie : list) {
+                movies.deleteMovie(movie);
+            }
+
+            assertEquals("Movies.getMovies()", 0, movies.getMovies().size());
+
+        } finally {
+            userTransaction.commit();
+        }
+    }
+}
+//END SNIPPET: code

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/Agenda.java
----------------------------------------------------------------------
diff --git a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/Agenda.java b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/Agenda.java
index 219395e..3beda2a 100644
--- a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/Agenda.java
+++ b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/Agenda.java
@@ -1,23 +1,23 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.example.jaxws;
-
-import java.util.Date;
-
-public interface Agenda {
-    boolean isBookable(Date d);
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.example.jaxws;
+
+import java.util.Date;
+
+public interface Agenda {
+    boolean isBookable(Date d);
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/LazyAgenda.java
----------------------------------------------------------------------
diff --git a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/LazyAgenda.java b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/LazyAgenda.java
index d989da5..c0f6b2e 100644
--- a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/LazyAgenda.java
+++ b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/LazyAgenda.java
@@ -1,26 +1,26 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.example.jaxws;
-
-import java.util.Date;
-
-public class LazyAgenda implements Agenda {
-    @Override
-    public boolean isBookable(final Date d) {
-        return d.after(new Date());
-    }
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.example.jaxws;
+
+import java.util.Date;
+
+public class LazyAgenda implements Agenda {
+    @Override
+    public boolean isBookable(final Date d) {
+        return d.after(new Date());
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlanner.java
----------------------------------------------------------------------
diff --git a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlanner.java b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlanner.java
index 005f4a7..a71404d 100644
--- a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlanner.java
+++ b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlanner.java
@@ -1,25 +1,25 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.example.jaxws;
-
-import javax.jws.WebService;
-import java.util.Date;
-
-@WebService
-public interface MeetingPlanner {
-    boolean book(final Date date);
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.example.jaxws;
+
+import javax.jws.WebService;
+import java.util.Date;
+
+@WebService
+public interface MeetingPlanner {
+    boolean book(final Date date);
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlannerImpl.java
----------------------------------------------------------------------
diff --git a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlannerImpl.java b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlannerImpl.java
index 243c21b..fcc08bd 100644
--- a/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlannerImpl.java
+++ b/examples/applicationcomposer-jaxws-cdi/src/main/java/org/superbiz/example/jaxws/MeetingPlannerImpl.java
@@ -1,32 +1,32 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.example.jaxws;
-
-import javax.inject.Inject;
-import javax.jws.WebService;
-import java.util.Date;
-
-@WebService
-public class MeetingPlannerImpl implements MeetingPlanner {
-    @Inject
-    private Agenda agenda;
-
-    @Override
-    public boolean book(final Date date) {
-        return agenda.isBookable(date);
-    }
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.example.jaxws;
+
+import javax.inject.Inject;
+import javax.jws.WebService;
+import java.util.Date;
+
+@WebService
+public class MeetingPlannerImpl implements MeetingPlanner {
+    @Inject
+    private Agenda agenda;
+
+    @Override
+    public boolean book(final Date date) {
+        return agenda.isBookable(date);
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationcomposer-jaxws-cdi/src/test/java/org/superbiz/example/jaxws/MeetingPlannerTest.java
----------------------------------------------------------------------
diff --git a/examples/applicationcomposer-jaxws-cdi/src/test/java/org/superbiz/example/jaxws/MeetingPlannerTest.java b/examples/applicationcomposer-jaxws-cdi/src/test/java/org/superbiz/example/jaxws/MeetingPlannerTest.java
index bc43041..e862038 100644
--- a/examples/applicationcomposer-jaxws-cdi/src/test/java/org/superbiz/example/jaxws/MeetingPlannerTest.java
+++ b/examples/applicationcomposer-jaxws-cdi/src/test/java/org/superbiz/example/jaxws/MeetingPlannerTest.java
@@ -1,65 +1,65 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.example.jaxws;
-
-import org.apache.openejb.jee.WebApp;
-import org.apache.openejb.junit.ApplicationComposer;
-import org.apache.openejb.testing.Classes;
-import org.apache.openejb.testing.Configuration;
-import org.apache.openejb.testing.EnableServices;
-import org.apache.openejb.testing.Module;
-import org.apache.openejb.testng.PropertiesBuilder;
-import org.apache.openejb.util.NetworkUtil;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-
-import javax.xml.namespace.QName;
-import javax.xml.ws.Service;
-import java.net.MalformedURLException;
-import java.net.URL;
-import java.util.Date;
-import java.util.Properties;
-
-import static org.junit.Assert.assertTrue;
-
-@EnableServices("jax-ws")
-@RunWith(ApplicationComposer.class)
-public class MeetingPlannerTest {
-    private static final int JAX_WS_PORT = NetworkUtil.getNextAvailablePort();
-
-    @Configuration
-    public Properties configuration() {
-        return new PropertiesBuilder().p("httpejbd.port", Integer.toString(JAX_WS_PORT)).build();
-    }
-
-    @Module
-    @Classes(cdi = true, value = {MeetingPlannerImpl.class, LazyAgenda.class})
-    public WebApp war() {
-        return new WebApp()
-                .contextRoot("/demo")
-                .addServlet("jaxws", MeetingPlannerImpl.class.getName(), "/meeting-planner");
-    }
-
-    @Test
-    public void book() throws MalformedURLException {
-        final Service service = Service.create(
-                new URL("http://127.0.0.1:" + JAX_WS_PORT + "/demo/meeting-planner?wsdl"),
-                new QName("http://jaxws.example.superbiz.org/", "MeetingPlannerImplService"));
-        final MeetingPlanner planner = service.getPort(MeetingPlanner.class);
-        assertTrue(planner.book(new Date(System.currentTimeMillis() + 1000000)));
-    }
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.example.jaxws;
+
+import org.apache.openejb.jee.WebApp;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.testing.Classes;
+import org.apache.openejb.testing.Configuration;
+import org.apache.openejb.testing.EnableServices;
+import org.apache.openejb.testing.Module;
+import org.apache.openejb.testng.PropertiesBuilder;
+import org.apache.openejb.util.NetworkUtil;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import javax.xml.namespace.QName;
+import javax.xml.ws.Service;
+import java.net.MalformedURLException;
+import java.net.URL;
+import java.util.Date;
+import java.util.Properties;
+
+import static org.junit.Assert.assertTrue;
+
+@EnableServices("jax-ws")
+@RunWith(ApplicationComposer.class)
+public class MeetingPlannerTest {
+    private static final int JAX_WS_PORT = NetworkUtil.getNextAvailablePort();
+
+    @Configuration
+    public Properties configuration() {
+        return new PropertiesBuilder().p("httpejbd.port", Integer.toString(JAX_WS_PORT)).build();
+    }
+
+    @Module
+    @Classes(cdi = true, value = {MeetingPlannerImpl.class, LazyAgenda.class})
+    public WebApp war() {
+        return new WebApp()
+                .contextRoot("/demo")
+                .addServlet("jaxws", MeetingPlannerImpl.class.getName(), "/meeting-planner");
+    }
+
+    @Test
+    public void book() throws MalformedURLException {
+        final Service service = Service.create(
+                new URL("http://127.0.0.1:" + JAX_WS_PORT + "/demo/meeting-planner?wsdl"),
+                new QName("http://jaxws.example.superbiz.org/", "MeetingPlannerImplService"));
+        final MeetingPlanner planner = service.getPort(MeetingPlanner.class);
+        assertTrue(planner.book(new Date(System.currentTimeMillis() + 1000000)));
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationexception/src/main/java/org/superbiz/appexception/BusinessException.java
----------------------------------------------------------------------
diff --git a/examples/applicationexception/src/main/java/org/superbiz/appexception/BusinessException.java b/examples/applicationexception/src/main/java/org/superbiz/appexception/BusinessException.java
index 14b68cb..fe61515 100755
--- a/examples/applicationexception/src/main/java/org/superbiz/appexception/BusinessException.java
+++ b/examples/applicationexception/src/main/java/org/superbiz/appexception/BusinessException.java
@@ -1,27 +1,27 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.appexception;
-
-import javax.ejb.ApplicationException;
-
-/**
- * @version $Rev$ $Date$
- */
-@ApplicationException(rollback = true)
-public abstract class BusinessException extends RuntimeException {
-
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.appexception;
+
+import javax.ejb.ApplicationException;
+
+/**
+ * @version $Rev$ $Date$
+ */
+@ApplicationException(rollback = true)
+public abstract class BusinessException extends RuntimeException {
+
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessException.java
----------------------------------------------------------------------
diff --git a/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessException.java b/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessException.java
index 4fd3c43..272f8c1 100755
--- a/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessException.java
+++ b/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessException.java
@@ -1,33 +1,33 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.appexception;
-
-import javax.ejb.Remote;
-
-/**
- * This is an EJB 3 remote business interface
- * A remote business interface must be annotated with the @Remote
- * annotation
- */
-//START SNIPPET: code
-@Remote
-public interface ThrowBusinessException {
-
-    public void throwValueRequiredException() throws BusinessException;
-
-}
-//END SNIPPET: code
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.appexception;
+
+import javax.ejb.Remote;
+
+/**
+ * This is an EJB 3 remote business interface
+ * A remote business interface must be annotated with the @Remote
+ * annotation
+ */
+//START SNIPPET: code
+@Remote
+public interface ThrowBusinessException {
+
+    public void throwValueRequiredException() throws BusinessException;
+
+}
+//END SNIPPET: code

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessExceptionImpl.java
----------------------------------------------------------------------
diff --git a/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessExceptionImpl.java b/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessExceptionImpl.java
index 02a6edd..f0613f0 100755
--- a/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessExceptionImpl.java
+++ b/examples/applicationexception/src/main/java/org/superbiz/appexception/ThrowBusinessExceptionImpl.java
@@ -1,30 +1,30 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.appexception;
-
-import javax.ejb.Stateless;
-
-//START SNIPPET: code
-@Stateless
-public class ThrowBusinessExceptionImpl implements ThrowBusinessException {
-
-    public void throwValueRequiredException() throws BusinessException {
-        throw new ValueRequiredException();
-    }
-
-}
-//END SNIPPET: code
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.appexception;
+
+import javax.ejb.Stateless;
+
+//START SNIPPET: code
+@Stateless
+public class ThrowBusinessExceptionImpl implements ThrowBusinessException {
+
+    public void throwValueRequiredException() throws BusinessException {
+        throw new ValueRequiredException();
+    }
+
+}
+//END SNIPPET: code

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationexception/src/main/java/org/superbiz/appexception/ValueRequiredException.java
----------------------------------------------------------------------
diff --git a/examples/applicationexception/src/main/java/org/superbiz/appexception/ValueRequiredException.java b/examples/applicationexception/src/main/java/org/superbiz/appexception/ValueRequiredException.java
index 3f68ae2..bb7b82b 100755
--- a/examples/applicationexception/src/main/java/org/superbiz/appexception/ValueRequiredException.java
+++ b/examples/applicationexception/src/main/java/org/superbiz/appexception/ValueRequiredException.java
@@ -1,24 +1,24 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.appexception;
-
-/**
- * @version $Rev$ $Date$
- */
-public class ValueRequiredException extends BusinessException {
-
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.appexception;
+
+/**
+ * @version $Rev$ $Date$
+ */
+public class ValueRequiredException extends BusinessException {
+
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/applicationexception/src/test/java/org/superbiz/appexception/ThrowBusinessExceptionImplTest.java
----------------------------------------------------------------------
diff --git a/examples/applicationexception/src/test/java/org/superbiz/appexception/ThrowBusinessExceptionImplTest.java b/examples/applicationexception/src/test/java/org/superbiz/appexception/ThrowBusinessExceptionImplTest.java
index df0c5d7..da9756b 100755
--- a/examples/applicationexception/src/test/java/org/superbiz/appexception/ThrowBusinessExceptionImplTest.java
+++ b/examples/applicationexception/src/test/java/org/superbiz/appexception/ThrowBusinessExceptionImplTest.java
@@ -1,61 +1,61 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.appexception;
-
-import org.junit.Assert;
-import org.junit.Before;
-import org.junit.Test;
-
-import javax.naming.Context;
-import javax.naming.InitialContext;
-import java.util.Properties;
-
-// TODO This test case does not actually show that the bean was not destroyed.  The effect of @ApplicationException is not demonstrated
-// Maybe have two methods that throw runtime exceptions and compare the behavior of both
-// TODO Remote the business interface and show only POJO usage
-public class ThrowBusinessExceptionImplTest {
-
-    //START SNIPPET: setup
-    private InitialContext initialContext;
-
-    @Before
-    public void setUp() throws Exception {
-        Properties properties = new Properties();
-        properties.setProperty(Context.INITIAL_CONTEXT_FACTORY, "org.apache.openejb.core.LocalInitialContextFactory");
-
-        initialContext = new InitialContext(properties);
-    }
-    //END SNIPPET: setup	
-
-    /**
-     * Lookup the Counter bean via its remote home interface
-     *
-     * @throws Exception
-     */
-    //START SNIPPET: remote
-    @Test(expected = ValueRequiredException.class)
-    public void testCounterViaRemoteInterface() throws Exception {
-        Object object = initialContext.lookup("ThrowBusinessExceptionImplRemote");
-
-        Assert.assertNotNull(object);
-        Assert.assertTrue(object instanceof ThrowBusinessException);
-        ThrowBusinessException bean = (ThrowBusinessException) object;
-        bean.throwValueRequiredException();
-    }
-    //END SNIPPET: remote
-
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.appexception;
+
+import org.junit.Assert;
+import org.junit.Before;
+import org.junit.Test;
+
+import javax.naming.Context;
+import javax.naming.InitialContext;
+import java.util.Properties;
+
+// TODO This test case does not actually show that the bean was not destroyed.  The effect of @ApplicationException is not demonstrated
+// Maybe have two methods that throw runtime exceptions and compare the behavior of both
+// TODO Remote the business interface and show only POJO usage
+public class ThrowBusinessExceptionImplTest {
+
+    //START SNIPPET: setup
+    private InitialContext initialContext;
+
+    @Before
+    public void setUp() throws Exception {
+        Properties properties = new Properties();
+        properties.setProperty(Context.INITIAL_CONTEXT_FACTORY, "org.apache.openejb.core.LocalInitialContextFactory");
+
+        initialContext = new InitialContext(properties);
+    }
+    //END SNIPPET: setup	
+
+    /**
+     * Lookup the Counter bean via its remote home interface
+     *
+     * @throws Exception
+     */
+    //START SNIPPET: remote
+    @Test(expected = ValueRequiredException.class)
+    public void testCounterViaRemoteInterface() throws Exception {
+        Object object = initialContext.lookup("ThrowBusinessExceptionImplRemote");
+
+        Assert.assertNotNull(object);
+        Assert.assertTrue(object instanceof ThrowBusinessException);
+        ThrowBusinessException bean = (ThrowBusinessException) object;
+        bean.throwValueRequiredException();
+    }
+    //END SNIPPET: remote
+
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/arquillian-jpa/README.md
----------------------------------------------------------------------
diff --git a/examples/arquillian-jpa/README.md b/examples/arquillian-jpa/README.md
index 1bc2e9f..d318839 100644
--- a/examples/arquillian-jpa/README.md
+++ b/examples/arquillian-jpa/README.md
@@ -1,169 +1,169 @@
-Title: Arquillian Persistence Extension
-
-A sample showing how to use TomEE, Arquillian and its Persistence Extension.
-
-Note that it doesn't work with embedded containers (openejb, tomee-embedded)
-if you don't use workarounds like https://github.com/rmannibucau/persistence-with-openejb-and-arquillian
-(see src/test/resources folder).
-
-# Running (output)
-
-    -------------------------------------------------------
-     T E S T S
-    -------------------------------------------------------
-    Running org.superbiz.arquillian.test.persistence.PersistenceTest
-    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.Setup findHome
-    INFOS: Unable to find home in: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote
-    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.MavenCache getArtifact
-    INFOS: Downloading org.apache.openejb:apache-tomee:7.0.0-SNAPSHOT:zip:webprofile please wait...
-    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.Zips unzip
-    INFOS: Extracting '/home/rmannibucau/.m2/repository/org/apache/openejb/apache-tomee/7.0.0-SNAPSHOT/apache-tomee-7.0.0-SNAPSHOT-webprofile.zip' to '/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote'
-    oct. 01, 2014 6:30:24 PM org.apache.tomee.arquillian.remote.RemoteTomEEContainer configure
-    INFOS: Downloaded container to: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
-    INFOS - Server version: Apache Tomcat/8.0.14
-    INFOS - Server built:   Sep 24 2014 09:01:51
-    INFOS - Server number:  8.0.14.0
-    INFOS - OS Name:        Linux
-    INFOS - OS Version:     3.13.0-35-generic
-    INFOS - Architecture:   amd64
-    INFOS - JVM Version:    1.7.0_67-b01
-    INFOS - JVM Vendor:     Oracle Corporation
-    INFOS - The APR based Apache Tomcat Native library which allows optimal performance in production environments was not found on the java.library.path: /usr/java/packages/lib/amd64:/usr/lib64:/lib64:/lib:/usr/lib
-    INFOS - Initializing ProtocolHandler ["http-nio-52256"]
-    INFOS - Using a shared selector for servlet write/read
-    INFOS - Initializing ProtocolHandler ["ajp-nio-40071"]
-    INFOS - Using a shared selector for servlet write/read
-    INFOS - Using 'openejb.jdbc.datasource-creator=org.apache.tomee.jdbc.TomEEDataSourceCreator'
-    INFOS - ********************************************************************************
-    INFOS - OpenEJB http://tomee.apache.org/
-    INFOS - Startup: Wed Oct 01 18:30:26 CEST 2014
-    INFOS - Copyright 1999-2013 (C) Apache OpenEJB Project, All Rights Reserved.
-    INFOS - Version: 7.0.0-SNAPSHOT
-    INFOS - Build date: 20141001
-    INFOS - Build time: 04:53
-    INFOS - ********************************************************************************
-    INFOS - openejb.home = /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
-    INFOS - openejb.base = /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
-    INFOS - Created new singletonService org.apache.openejb.cdi.ThreadSingletonServiceImpl@13158bbd
-    INFOS - Succeeded in installing singleton service
-    INFOS - openejb configuration file is '/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT/conf/tomee.xml'
-    INFOS - Configuring Service(id=Tomcat Security Service, type=SecurityService, provider-id=Tomcat Security Service)
-    INFOS - Configuring Service(id=Default Transaction Manager, type=TransactionManager, provider-id=Default Transaction Manager)
-    INFOS - Configuring Service(id=demoDataSource, type=Resource, provider-id=Default JDBC Database)
-    INFOS - Using 'openejb.system.apps=true'
-    INFOS - Configuring enterprise application: openejb
-    INFOS - Using openejb.deploymentId.format '{ejbName}'
-    INFOS - Auto-deploying ejb openejb/Deployer: EjbDeployment(deployment-id=openejb/Deployer)
-    INFOS - Auto-deploying ejb openejb/ConfigurationInfo: EjbDeployment(deployment-id=openejb/ConfigurationInfo)
-    INFOS - Auto-deploying ejb MEJB: EjbDeployment(deployment-id=MEJB)
-    INFOS - Configuring Service(id=Default Stateless Container, type=Container, provider-id=Default Stateless Container)
-    INFOS - Auto-creating a container for bean openejb/Deployer: Container(type=STATELESS, id=Default Stateless Container)
-    INFOS - Enterprise application "openejb" loaded.
-    INFOS - Creating TransactionManager(id=Default Transaction Manager)
-    INFOS - Creating SecurityService(id=Tomcat Security Service)
-    INFOS - Creating Resource(id=demoDataSource)
-    INFOS - Disabling testOnBorrow since no validation query is provided
-    INFOS - Creating Container(id=Default Stateless Container)
-    INFOS - Not creating another application classloader for openejb
-    INFOS - Assembling app: openejb
-    INFOS - Using 'openejb.jndiname.format={deploymentId}{interfaceType.openejbLegacyName}'
-    INFOS - Jndi(name=openejb/DeployerBusinessRemote) --> Ejb(deployment-id=openejb/Deployer)
-    INFOS - Jndi(name=global/openejb/openejb/Deployer!org.apache.openejb.assembler.Deployer) --> Ejb(deployment-id=openejb/Deployer)
-    INFOS - Jndi(name=global/openejb/openejb/Deployer) --> Ejb(deployment-id=openejb/Deployer)
-    INFOS - Jndi(name=openejb/ConfigurationInfoBusinessRemote) --> Ejb(deployment-id=openejb/ConfigurationInfo)
-    INFOS - Jndi(name=global/openejb/openejb/ConfigurationInfo!org.apache.openejb.assembler.classic.cmd.ConfigurationInfo) --> Ejb(deployment-id=openejb/ConfigurationInfo)
-    INFOS - Jndi(name=global/openejb/openejb/ConfigurationInfo) --> Ejb(deployment-id=openejb/ConfigurationInfo)
-    INFOS - Jndi(name=MEJB) --> Ejb(deployment-id=MEJB)
-    INFOS - Jndi(name=global/openejb/MEJB!javax.management.j2ee.ManagementHome) --> Ejb(deployment-id=MEJB)
-    INFOS - Jndi(name=global/openejb/MEJB) --> Ejb(deployment-id=MEJB)
-    INFOS - Created Ejb(deployment-id=openejb/Deployer, ejb-name=openejb/Deployer, container=Default Stateless Container)
-    INFOS - Created Ejb(deployment-id=MEJB, ejb-name=MEJB, container=Default Stateless Container)
-    INFOS - Created Ejb(deployment-id=openejb/ConfigurationInfo, ejb-name=openejb/ConfigurationInfo, container=Default Stateless Container)
-    INFOS - Started Ejb(deployment-id=openejb/Deployer, ejb-name=openejb/Deployer, container=Default Stateless Container)
-    INFOS - Started Ejb(deployment-id=MEJB, ejb-name=MEJB, container=Default Stateless Container)
-    INFOS - Started Ejb(deployment-id=openejb/ConfigurationInfo, ejb-name=openejb/ConfigurationInfo, container=Default Stateless Container)
-    INFOS - Deployed MBean(openejb.user.mbeans:application=openejb,group=org.apache.openejb.assembler.monitoring,name=JMXDeployer)
-    INFOS - Deployed Application(path=openejb)
-    INFOS - Creating ServerService(id=cxf-rs)
-    INFOS -   ** Bound Services **
-    INFOS -   NAME                 IP              PORT  
-    INFOS - -------
-    INFOS - Ready!
-    INFOS - Initialization processed in 2589 ms
-    INFOS - Importing a Tomcat Resource with id 'UserDatabase' of type 'org.apache.catalina.UserDatabase'.
-    INFOS - Creating Resource(id=UserDatabase)
-    INFOS - Démarrage du service Catalina
-    INFOS - Starting Servlet Engine: Apache Tomcat (TomEE)/8.0.14 (7.0.0-SNAPSHOT)
-    INFOS - Starting ProtocolHandler ["http-nio-52256"]
-    INFOS - Starting ProtocolHandler ["ajp-nio-40071"]
-    INFOS - Server startup in 140 ms
-    oct. 01, 2014 6:30:30 PM org.apache.openejb.client.EventLogger log
-    INFOS: RemoteInitialContextCreated{providerUri=http://localhost:52256/tomee/ejb}
-    INFOS - Extracting jar: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest.war
-    INFOS - Extracted path: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
-    INFOS - using default host: localhost
-    INFOS - ------------------------- localhost -> /UserPersistenceTest
-    INFOS - Using 'openejb.session.manager=org.apache.tomee.catalina.session.QuickSessionManager'
-    INFOS - Configuring enterprise application: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
-    INFOS - Configuring Service(id=Default Managed Container, type=Container, provider-id=Default Managed Container)
-    INFOS - Auto-creating a container for bean UserPersistenceTest_org.superbiz.arquillian.test.persistence.PersistenceTest: Container(type=MANAGED, id=Default Managed Container)
-    INFOS - Creating Container(id=Default Managed Container)
-    INFOS - Using directory /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT/temp for stateful session passivation
-    INFOS - Configuring PersistenceUnit(name=demoApplicationPU)
-    INFOS - Auto-creating a Resource with id 'demoDataSourceNonJta' of type 'DataSource for 'demoApplicationPU'.
-    INFOS - Configuring Service(id=demoDataSourceNonJta, type=Resource, provider-id=demoDataSource)
-    INFOS - Creating Resource(id=demoDataSourceNonJta)
-    INFOS - Disabling testOnBorrow since no validation query is provided
-    INFOS - Adjusting PersistenceUnit demoApplicationPU <non-jta-data-source> to Resource ID 'demoDataSourceNonJta' from 'null'
-    INFOS - Enterprise application "/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest" loaded.
-    INFOS - Assembling app: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
-    INFOS - OpenJPA dynamically loaded a validation provider.
-    INFOS - Starting OpenJPA 2.4.0-nonfinal-1598334
-    INFOS - Using dictionary class "org.apache.openjpa.jdbc.sql.HSQLDictionary" (HSQL Database Engine 2.3.2 ,HSQL Database Engine Driver 2.3.2).
-    INFOS - Connected to HSQL Database Engine version 2.2 using JDBC driver HSQL Database Engine Driver version 2.3.2. 
-    INFOS - SELECT SEQUENCE_SCHEMA, SEQUENCE_NAME FROM INFORMATION_SCHEMA.SYSTEM_SEQUENCES --> 0ms
-    INFOS - CREATE TABLE User (id BIGINT NOT NULL, name VARCHAR(255), PRIMARY KEY (id)) --> 0ms
-    INFOS - PersistenceUnit(name=demoApplicationPU, provider=org.apache.openjpa.persistence.PersistenceProviderImpl) - provider time 1075ms
-    INFOS - Existing thread singleton service in SystemInstance(): org.apache.openejb.cdi.ThreadSingletonServiceImpl@13158bbd
-    INFOS - OpenWebBeans Container is starting...
-    INFOS - Adding OpenWebBeansPlugin : [CdiPlugin]
-    INFOS - Adding OpenWebBeansPlugin : [OpenWebBeansJsfPlugin]
-    INFOS - All injection points were validated successfully.
-    INFOS - OpenWebBeans Container has started, it took 224 ms.
-    INFOS - Deployed Application(path=/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest)
-    INFOS - At least one JAR was scanned for TLDs yet contained no TLDs. Enable debug logging for this logger for a complete list of JARs that were scanned but no TLDs were found in them. Skipping unneeded JARs during scanning can improve startup time and JSP compilation time.
-    AVERTISSEMENT - Potential problem found: The configured data type factory 'class org.dbunit.dataset.datatype.DefaultDataTypeFactory' might cause problems with the current database 'HSQL Database Engine' (e.g. some datatypes may not be supported properly). In rare cases you might see this message because the list of supported database products is incomplete (list=[derby]). If so please request a java-class update via the forums.If you are using your own IDataTypeFactory extending DefaultDataTypeFactory, ensure that you override getValidDbProducts() to specify the supported database products.
-    INFOS - insert into USER (ID, NAME) values (1, TomEE) --> 1ms
-    INFOS - insert into USER (ID, NAME) values (1, 2)TomEE,Old) --> 0ms
-    INFOS - SELECT COUNT(t0.id) FROM User t0 --> 0ms
-    INFOS - SELECT t0.name FROM User t0 WHERE t0.id = 2 --> 0ms
-    INFOS - UPDATE User SET name = OpenEJB WHERE id = 2 --> 1ms
-    INFOS - select ID, NAME from USER order by ID --> 0ms
-    INFOS - select ID, NAME from USER order by ID --> 0ms
-    INFOS - select ID, NAME from USER order by ID --> 0ms
-    INFOS - select ID, NAME from USER order by ID --> 0ms
-    INFOS - delete from USER --> 0ms
-    oct. 01, 2014 6:30:34 PM org.apache.openejb.client.EventLogger log
-    INFOS: RemoteInitialContextCreated{providerUri=http://localhost:52256/tomee/ejb}
-    INFOS - Undeploying app: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
-    oct. 01, 2014 6:30:34 PM org.apache.openejb.arquillian.common.TomEEContainer undeploy
-    INFOS: cleaning /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0
-    Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 11.242 sec
-    INFOS - A valid shutdown command was received via the shutdown port. Stopping the Server instance.
-    INFOS - Pausing ProtocolHandler ["http-nio-52256"]
-    INFOS - Pausing ProtocolHandler ["ajp-nio-40071"]
-    INFOS - Arrêt du service Catalina
-    INFOS - Stopping ProtocolHandler ["http-nio-52256"]
-    INFOS - Stopping ProtocolHandler ["ajp-nio-40071"]
-    INFOS - Stopping server services
-    INFOS - Undeploying app: openejb
-    INFOS - Closing DataSource: demoDataSource
-    INFOS - Closing DataSource: demoDataSourceNonJta
-    INFOS - Destroying ProtocolHandler ["http-nio-52256"]
-    INFOS - Destroying ProtocolHandler ["ajp-nio-40071"]
-    
-    Results :
-    
-    Tests run: 1, Failures: 0, Errors: 0, Skipped: 0
-
-
+Title: Arquillian Persistence Extension
+
+A sample showing how to use TomEE, Arquillian and its Persistence Extension.
+
+Note that it doesn't work with embedded containers (openejb, tomee-embedded)
+if you don't use workarounds like https://github.com/rmannibucau/persistence-with-openejb-and-arquillian
+(see src/test/resources folder).
+
+# Running (output)
+
+    -------------------------------------------------------
+     T E S T S
+    -------------------------------------------------------
+    Running org.superbiz.arquillian.test.persistence.PersistenceTest
+    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.Setup findHome
+    INFOS: Unable to find home in: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote
+    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.MavenCache getArtifact
+    INFOS: Downloading org.apache.openejb:apache-tomee:7.0.0-SNAPSHOT:zip:webprofile please wait...
+    oct. 01, 2014 6:30:23 PM org.apache.openejb.arquillian.common.Zips unzip
+    INFOS: Extracting '/home/rmannibucau/.m2/repository/org/apache/openejb/apache-tomee/7.0.0-SNAPSHOT/apache-tomee-7.0.0-SNAPSHOT-webprofile.zip' to '/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote'
+    oct. 01, 2014 6:30:24 PM org.apache.tomee.arquillian.remote.RemoteTomEEContainer configure
+    INFOS: Downloaded container to: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
+    INFOS - Server version: Apache Tomcat/8.0.14
+    INFOS - Server built:   Sep 24 2014 09:01:51
+    INFOS - Server number:  8.0.14.0
+    INFOS - OS Name:        Linux
+    INFOS - OS Version:     3.13.0-35-generic
+    INFOS - Architecture:   amd64
+    INFOS - JVM Version:    1.7.0_67-b01
+    INFOS - JVM Vendor:     Oracle Corporation
+    INFOS - The APR based Apache Tomcat Native library which allows optimal performance in production environments was not found on the java.library.path: /usr/java/packages/lib/amd64:/usr/lib64:/lib64:/lib:/usr/lib
+    INFOS - Initializing ProtocolHandler ["http-nio-52256"]
+    INFOS - Using a shared selector for servlet write/read
+    INFOS - Initializing ProtocolHandler ["ajp-nio-40071"]
+    INFOS - Using a shared selector for servlet write/read
+    INFOS - Using 'openejb.jdbc.datasource-creator=org.apache.tomee.jdbc.TomEEDataSourceCreator'
+    INFOS - ********************************************************************************
+    INFOS - OpenEJB http://tomee.apache.org/
+    INFOS - Startup: Wed Oct 01 18:30:26 CEST 2014
+    INFOS - Copyright 1999-2013 (C) Apache OpenEJB Project, All Rights Reserved.
+    INFOS - Version: 7.0.0-SNAPSHOT
+    INFOS - Build date: 20141001
+    INFOS - Build time: 04:53
+    INFOS - ********************************************************************************
+    INFOS - openejb.home = /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
+    INFOS - openejb.base = /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT
+    INFOS - Created new singletonService org.apache.openejb.cdi.ThreadSingletonServiceImpl@13158bbd
+    INFOS - Succeeded in installing singleton service
+    INFOS - openejb configuration file is '/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT/conf/tomee.xml'
+    INFOS - Configuring Service(id=Tomcat Security Service, type=SecurityService, provider-id=Tomcat Security Service)
+    INFOS - Configuring Service(id=Default Transaction Manager, type=TransactionManager, provider-id=Default Transaction Manager)
+    INFOS - Configuring Service(id=demoDataSource, type=Resource, provider-id=Default JDBC Database)
+    INFOS - Using 'openejb.system.apps=true'
+    INFOS - Configuring enterprise application: openejb
+    INFOS - Using openejb.deploymentId.format '{ejbName}'
+    INFOS - Auto-deploying ejb openejb/Deployer: EjbDeployment(deployment-id=openejb/Deployer)
+    INFOS - Auto-deploying ejb openejb/ConfigurationInfo: EjbDeployment(deployment-id=openejb/ConfigurationInfo)
+    INFOS - Auto-deploying ejb MEJB: EjbDeployment(deployment-id=MEJB)
+    INFOS - Configuring Service(id=Default Stateless Container, type=Container, provider-id=Default Stateless Container)
+    INFOS - Auto-creating a container for bean openejb/Deployer: Container(type=STATELESS, id=Default Stateless Container)
+    INFOS - Enterprise application "openejb" loaded.
+    INFOS - Creating TransactionManager(id=Default Transaction Manager)
+    INFOS - Creating SecurityService(id=Tomcat Security Service)
+    INFOS - Creating Resource(id=demoDataSource)
+    INFOS - Disabling testOnBorrow since no validation query is provided
+    INFOS - Creating Container(id=Default Stateless Container)
+    INFOS - Not creating another application classloader for openejb
+    INFOS - Assembling app: openejb
+    INFOS - Using 'openejb.jndiname.format={deploymentId}{interfaceType.openejbLegacyName}'
+    INFOS - Jndi(name=openejb/DeployerBusinessRemote) --> Ejb(deployment-id=openejb/Deployer)
+    INFOS - Jndi(name=global/openejb/openejb/Deployer!org.apache.openejb.assembler.Deployer) --> Ejb(deployment-id=openejb/Deployer)
+    INFOS - Jndi(name=global/openejb/openejb/Deployer) --> Ejb(deployment-id=openejb/Deployer)
+    INFOS - Jndi(name=openejb/ConfigurationInfoBusinessRemote) --> Ejb(deployment-id=openejb/ConfigurationInfo)
+    INFOS - Jndi(name=global/openejb/openejb/ConfigurationInfo!org.apache.openejb.assembler.classic.cmd.ConfigurationInfo) --> Ejb(deployment-id=openejb/ConfigurationInfo)
+    INFOS - Jndi(name=global/openejb/openejb/ConfigurationInfo) --> Ejb(deployment-id=openejb/ConfigurationInfo)
+    INFOS - Jndi(name=MEJB) --> Ejb(deployment-id=MEJB)
+    INFOS - Jndi(name=global/openejb/MEJB!javax.management.j2ee.ManagementHome) --> Ejb(deployment-id=MEJB)
+    INFOS - Jndi(name=global/openejb/MEJB) --> Ejb(deployment-id=MEJB)
+    INFOS - Created Ejb(deployment-id=openejb/Deployer, ejb-name=openejb/Deployer, container=Default Stateless Container)
+    INFOS - Created Ejb(deployment-id=MEJB, ejb-name=MEJB, container=Default Stateless Container)
+    INFOS - Created Ejb(deployment-id=openejb/ConfigurationInfo, ejb-name=openejb/ConfigurationInfo, container=Default Stateless Container)
+    INFOS - Started Ejb(deployment-id=openejb/Deployer, ejb-name=openejb/Deployer, container=Default Stateless Container)
+    INFOS - Started Ejb(deployment-id=MEJB, ejb-name=MEJB, container=Default Stateless Container)
+    INFOS - Started Ejb(deployment-id=openejb/ConfigurationInfo, ejb-name=openejb/ConfigurationInfo, container=Default Stateless Container)
+    INFOS - Deployed MBean(openejb.user.mbeans:application=openejb,group=org.apache.openejb.assembler.monitoring,name=JMXDeployer)
+    INFOS - Deployed Application(path=openejb)
+    INFOS - Creating ServerService(id=cxf-rs)
+    INFOS -   ** Bound Services **
+    INFOS -   NAME                 IP              PORT  
+    INFOS - -------
+    INFOS - Ready!
+    INFOS - Initialization processed in 2589 ms
+    INFOS - Importing a Tomcat Resource with id 'UserDatabase' of type 'org.apache.catalina.UserDatabase'.
+    INFOS - Creating Resource(id=UserDatabase)
+    INFOS - Démarrage du service Catalina
+    INFOS - Starting Servlet Engine: Apache Tomcat (TomEE)/8.0.14 (7.0.0-SNAPSHOT)
+    INFOS - Starting ProtocolHandler ["http-nio-52256"]
+    INFOS - Starting ProtocolHandler ["ajp-nio-40071"]
+    INFOS - Server startup in 140 ms
+    oct. 01, 2014 6:30:30 PM org.apache.openejb.client.EventLogger log
+    INFOS: RemoteInitialContextCreated{providerUri=http://localhost:52256/tomee/ejb}
+    INFOS - Extracting jar: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest.war
+    INFOS - Extracted path: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
+    INFOS - using default host: localhost
+    INFOS - ------------------------- localhost -> /UserPersistenceTest
+    INFOS - Using 'openejb.session.manager=org.apache.tomee.catalina.session.QuickSessionManager'
+    INFOS - Configuring enterprise application: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
+    INFOS - Configuring Service(id=Default Managed Container, type=Container, provider-id=Default Managed Container)
+    INFOS - Auto-creating a container for bean UserPersistenceTest_org.superbiz.arquillian.test.persistence.PersistenceTest: Container(type=MANAGED, id=Default Managed Container)
+    INFOS - Creating Container(id=Default Managed Container)
+    INFOS - Using directory /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/apache-tomee-remote/apache-tomee-webprofile-7.0.0-SNAPSHOT/temp for stateful session passivation
+    INFOS - Configuring PersistenceUnit(name=demoApplicationPU)
+    INFOS - Auto-creating a Resource with id 'demoDataSourceNonJta' of type 'DataSource for 'demoApplicationPU'.
+    INFOS - Configuring Service(id=demoDataSourceNonJta, type=Resource, provider-id=demoDataSource)
+    INFOS - Creating Resource(id=demoDataSourceNonJta)
+    INFOS - Disabling testOnBorrow since no validation query is provided
+    INFOS - Adjusting PersistenceUnit demoApplicationPU <non-jta-data-source> to Resource ID 'demoDataSourceNonJta' from 'null'
+    INFOS - Enterprise application "/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest" loaded.
+    INFOS - Assembling app: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
+    INFOS - OpenJPA dynamically loaded a validation provider.
+    INFOS - Starting OpenJPA 2.4.0-nonfinal-1598334
+    INFOS - Using dictionary class "org.apache.openjpa.jdbc.sql.HSQLDictionary" (HSQL Database Engine 2.3.2 ,HSQL Database Engine Driver 2.3.2).
+    INFOS - Connected to HSQL Database Engine version 2.2 using JDBC driver HSQL Database Engine Driver version 2.3.2. 
+    INFOS - SELECT SEQUENCE_SCHEMA, SEQUENCE_NAME FROM INFORMATION_SCHEMA.SYSTEM_SEQUENCES --> 0ms
+    INFOS - CREATE TABLE User (id BIGINT NOT NULL, name VARCHAR(255), PRIMARY KEY (id)) --> 0ms
+    INFOS - PersistenceUnit(name=demoApplicationPU, provider=org.apache.openjpa.persistence.PersistenceProviderImpl) - provider time 1075ms
+    INFOS - Existing thread singleton service in SystemInstance(): org.apache.openejb.cdi.ThreadSingletonServiceImpl@13158bbd
+    INFOS - OpenWebBeans Container is starting...
+    INFOS - Adding OpenWebBeansPlugin : [CdiPlugin]
+    INFOS - Adding OpenWebBeansPlugin : [OpenWebBeansJsfPlugin]
+    INFOS - All injection points were validated successfully.
+    INFOS - OpenWebBeans Container has started, it took 224 ms.
+    INFOS - Deployed Application(path=/home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest)
+    INFOS - At least one JAR was scanned for TLDs yet contained no TLDs. Enable debug logging for this logger for a complete list of JARs that were scanned but no TLDs were found in them. Skipping unneeded JARs during scanning can improve startup time and JSP compilation time.
+    AVERTISSEMENT - Potential problem found: The configured data type factory 'class org.dbunit.dataset.datatype.DefaultDataTypeFactory' might cause problems with the current database 'HSQL Database Engine' (e.g. some datatypes may not be supported properly). In rare cases you might see this message because the list of supported database products is incomplete (list=[derby]). If so please request a java-class update via the forums.If you are using your own IDataTypeFactory extending DefaultDataTypeFactory, ensure that you override getValidDbProducts() to specify the supported database products.
+    INFOS - insert into USER (ID, NAME) values (1, TomEE) --> 1ms
+    INFOS - insert into USER (ID, NAME) values (1, 2)TomEE,Old) --> 0ms
+    INFOS - SELECT COUNT(t0.id) FROM User t0 --> 0ms
+    INFOS - SELECT t0.name FROM User t0 WHERE t0.id = 2 --> 0ms
+    INFOS - UPDATE User SET name = OpenEJB WHERE id = 2 --> 1ms
+    INFOS - select ID, NAME from USER order by ID --> 0ms
+    INFOS - select ID, NAME from USER order by ID --> 0ms
+    INFOS - select ID, NAME from USER order by ID --> 0ms
+    INFOS - select ID, NAME from USER order by ID --> 0ms
+    INFOS - delete from USER --> 0ms
+    oct. 01, 2014 6:30:34 PM org.apache.openejb.client.EventLogger log
+    INFOS: RemoteInitialContextCreated{providerUri=http://localhost:52256/tomee/ejb}
+    INFOS - Undeploying app: /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0/UserPersistenceTest
+    oct. 01, 2014 6:30:34 PM org.apache.openejb.arquillian.common.TomEEContainer undeploy
+    INFOS: cleaning /home/rmannibucau/dev/Apache/tomee-trunk/examples/arquillian-jpa/target/arquillian-test-working-dir/0
+    Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 11.242 sec
+    INFOS - A valid shutdown command was received via the shutdown port. Stopping the Server instance.
+    INFOS - Pausing ProtocolHandler ["http-nio-52256"]
+    INFOS - Pausing ProtocolHandler ["ajp-nio-40071"]
+    INFOS - Arrêt du service Catalina
+    INFOS - Stopping ProtocolHandler ["http-nio-52256"]
+    INFOS - Stopping ProtocolHandler ["ajp-nio-40071"]
+    INFOS - Stopping server services
+    INFOS - Undeploying app: openejb
+    INFOS - Closing DataSource: demoDataSource
+    INFOS - Closing DataSource: demoDataSourceNonJta
+    INFOS - Destroying ProtocolHandler ["http-nio-52256"]
+    INFOS - Destroying ProtocolHandler ["ajp-nio-40071"]
+    
+    Results :
+    
+    Tests run: 1, Failures: 0, Errors: 0, Skipped: 0
+
+

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/arquillian-jpa/src/main/java/org/superbiz/arquillian/persistence/User.java
----------------------------------------------------------------------
diff --git a/examples/arquillian-jpa/src/main/java/org/superbiz/arquillian/persistence/User.java b/examples/arquillian-jpa/src/main/java/org/superbiz/arquillian/persistence/User.java
index 65c0c67..a51226f 100644
--- a/examples/arquillian-jpa/src/main/java/org/superbiz/arquillian/persistence/User.java
+++ b/examples/arquillian-jpa/src/main/java/org/superbiz/arquillian/persistence/User.java
@@ -1,43 +1,43 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.arquillian.persistence;
-
-import javax.persistence.Entity;
-import javax.persistence.Id;
-
-@Entity
-public class User {
-    @Id
-    private long id;
-    private String name;
-
-    public long getId() {
-        return id;
-    }
-
-    public void setId(final long id) {
-        this.id = id;
-    }
-
-    public String getName() {
-        return name;
-    }
-
-    public void setName(final String name) {
-        this.name = name;
-    }
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.arquillian.persistence;
+
+import javax.persistence.Entity;
+import javax.persistence.Id;
+
+@Entity
+public class User {
+    @Id
+    private long id;
+    private String name;
+
+    public long getId() {
+        return id;
+    }
+
+    public void setId(final long id) {
+        this.id = id;
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public void setName(final String name) {
+        this.name = name;
+    }
+}

http://git-wip-us.apache.org/repos/asf/tomee/blob/6e2a4f7c/examples/arquillian-jpa/src/test/java/org/superbiz/arquillian/test/persistence/PersistenceTest.java
----------------------------------------------------------------------
diff --git a/examples/arquillian-jpa/src/test/java/org/superbiz/arquillian/test/persistence/PersistenceTest.java b/examples/arquillian-jpa/src/test/java/org/superbiz/arquillian/test/persistence/PersistenceTest.java
index 4b68131..2cb01e3 100644
--- a/examples/arquillian-jpa/src/test/java/org/superbiz/arquillian/test/persistence/PersistenceTest.java
+++ b/examples/arquillian-jpa/src/test/java/org/superbiz/arquillian/test/persistence/PersistenceTest.java
@@ -1,63 +1,63 @@
-/**
- * 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * 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.superbiz.arquillian.test.persistence;
-
-import org.jboss.arquillian.container.test.api.Deployment;
-import org.jboss.arquillian.junit.Arquillian;
-import org.jboss.arquillian.persistence.ShouldMatchDataSet;
-import org.jboss.arquillian.persistence.UsingDataSet;
-import org.jboss.arquillian.transaction.api.annotation.TransactionMode;
-import org.jboss.arquillian.transaction.api.annotation.Transactional;
-import org.jboss.shrinkwrap.api.Archive;
-import org.jboss.shrinkwrap.api.ShrinkWrap;
-import org.jboss.shrinkwrap.api.asset.ClassLoaderAsset;
-import org.jboss.shrinkwrap.api.spec.WebArchive;
-import org.junit.Test;
-import org.junit.runner.RunWith;
-import org.superbiz.arquillian.persistence.User;
-
-import javax.persistence.EntityManager;
-import javax.persistence.PersistenceContext;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-
-@RunWith(Arquillian.class)
-public class PersistenceTest {
-    @Deployment
-    public static Archive<?> createDeploymentPackage() {
-        return ShrinkWrap.create(WebArchive.class, "UserPersistenceTest.war")
-                .addPackage(User.class.getPackage())
-                .addAsManifestResource(new ClassLoaderAsset("META-INF/persistence.xml"), "persistence.xml");
-    }
-
-    @PersistenceContext
-    private EntityManager em;
-
-    @Test
-    @Transactional(TransactionMode.COMMIT) // default with persistence extension
-    @UsingDataSet("datasets/users.yml")
-    @ShouldMatchDataSet("datasets/expected-users.yml")
-    public void seriouslyYouAlreadyForgotOpenEJB_questionMark() throws Exception {
-        assertEquals(2, em.createQuery("select count(e) from User e", Number.class).getSingleResult().intValue());
-
-        final User user = em.find(User.class, 2L);
-        assertNotNull(user);
-
-        user.setName("OpenEJB"); // @Transactional(TransactionMode.COMMIT) will commit it and datasets/expected-users.yml will check it
-    }
-}
+/**
+ * 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * 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.superbiz.arquillian.test.persistence;
+
+import org.jboss.arquillian.container.test.api.Deployment;
+import org.jboss.arquillian.junit.Arquillian;
+import org.jboss.arquillian.persistence.ShouldMatchDataSet;
+import org.jboss.arquillian.persistence.UsingDataSet;
+import org.jboss.arquillian.transaction.api.annotation.TransactionMode;
+import org.jboss.arquillian.transaction.api.annotation.Transactional;
+import org.jboss.shrinkwrap.api.Archive;
+import org.jboss.shrinkwrap.api.ShrinkWrap;
+import org.jboss.shrinkwrap.api.asset.ClassLoaderAsset;
+import org.jboss.shrinkwrap.api.spec.WebArchive;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+import org.superbiz.arquillian.persistence.User;
+
+import javax.persistence.EntityManager;
+import javax.persistence.PersistenceContext;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertNotNull;
+
+@RunWith(Arquillian.class)
+public class PersistenceTest {
+    @Deployment
+    public static Archive<?> createDeploymentPackage() {
+        return ShrinkWrap.create(WebArchive.class, "UserPersistenceTest.war")
+                .addPackage(User.class.getPackage())
+                .addAsManifestResource(new ClassLoaderAsset("META-INF/persistence.xml"), "persistence.xml");
+    }
+
+    @PersistenceContext
+    private EntityManager em;
+
+    @Test
+    @Transactional(TransactionMode.COMMIT) // default with persistence extension
+    @UsingDataSet("datasets/users.yml")
+    @ShouldMatchDataSet("datasets/expected-users.yml")
+    public void seriouslyYouAlreadyForgotOpenEJB_questionMark() throws Exception {
+        assertEquals(2, em.createQuery("select count(e) from User e", Number.class).getSingleResult().intValue());
+
+        final User user = em.find(User.class, 2L);
+        assertNotNull(user);
+
+        user.setName("OpenEJB"); // @Transactional(TransactionMode.COMMIT) will commit it and datasets/expected-users.yml will check it
+    }
+}