You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tomee.apache.org by jg...@apache.org on 2017/10/30 09:37:23 UTC

[1/2] tomee git commit: TOMEE-1574 TOMEE-1573 @Module Resources for app composer + containers in resources.xml

Repository: tomee
Updated Branches:
  refs/heads/tomee-1.7.x 4736446a3 -> 6fa744189


TOMEE-1574 TOMEE-1573 @Module Resources for app composer + containers in resources.xml


Project: http://git-wip-us.apache.org/repos/asf/tomee/repo
Commit: http://git-wip-us.apache.org/repos/asf/tomee/commit/6b2f1bd4
Tree: http://git-wip-us.apache.org/repos/asf/tomee/tree/6b2f1bd4
Diff: http://git-wip-us.apache.org/repos/asf/tomee/diff/6b2f1bd4

Branch: refs/heads/tomee-1.7.x
Commit: 6b2f1bd485fb8596d93dfe4e7029ba102b723178
Parents: e473e68
Author: Romain Manni-Bucau <rm...@apache.org>
Authored: Mon May 4 19:53:04 2015 +0200
Committer: Jonathan Gallimore <jo...@jrg.me.uk>
Committed: Fri Oct 27 20:50:39 2017 +0100

----------------------------------------------------------------------
 .../openejb/assembler/classic/AppInfo.java      |  1 +
 .../openejb/assembler/classic/Assembler.java    |  6 ++
 .../apache/openejb/config/AppInfoBuilder.java   | 14 ++++
 .../org/apache/openejb/config/AppModule.java    |  6 ++
 .../org/apache/openejb/config/AutoConfig.java   | 58 ++++++++++++--
 .../apache/openejb/config/DeploymentLoader.java | 17 ++++
 .../java/org/apache/openejb/config/Module.java  |  1 +
 .../openejb/testing/ApplicationComposers.java   | 18 +++--
 .../apache/openejb/config/AppContainerTest.java | 83 ++++++++++++++++++++
 9 files changed, 192 insertions(+), 12 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/AppInfo.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/AppInfo.java b/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/AppInfo.java
index 1212c8e..e72dd59 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/AppInfo.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/AppInfo.java
@@ -45,6 +45,7 @@ public class AppInfo extends InfoObject {
     public List<ServiceInfo> services = new ArrayList<ServiceInfo>();
     public final List<String> libs = new ArrayList<String>();
     public final Set<String> watchedResources = new TreeSet<String>();
+    public final Set<String> containerIds = new TreeSet<String>();
     public final Set<String> resourceIds = new TreeSet<String>();
     public final Set<String> resourceAliases = new TreeSet<String>();
     public final JndiEncInfo globalJndiEnc = new JndiEncInfo();

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/Assembler.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/Assembler.java b/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/Assembler.java
index f2b7cbf..7dc2e31 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/Assembler.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/assembler/classic/Assembler.java
@@ -2298,6 +2298,10 @@ public class Assembler extends AssemblerTool implements org.apache.openejb.spi.A
                     Thread.currentThread().setContextClassLoader(old);
                 }
             }
+			
+            for (final String id : appInfo.containerIds) {
+                removeContainer(id);
+            }
 
             containerSystem.removeAppContext(appInfo.appId);
 
@@ -2547,6 +2551,8 @@ public class Assembler extends AssemblerTool implements org.apache.openejb.spi.A
 
         final Object service = serviceRecipe.create();
 
+        serviceRecipe.getUnsetProperties().remove("id"); // we forced it
+        serviceRecipe.getUnsetProperties().remove("securityService"); // we forced it
         logUnusedProperties(serviceRecipe, serviceInfo);
 
         final Class interfce = serviceInterfaces.get(serviceInfo.service);

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/config/AppInfoBuilder.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/config/AppInfoBuilder.java b/container/openejb-core/src/main/java/org/apache/openejb/config/AppInfoBuilder.java
index 3b9c86f..73d781c 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/config/AppInfoBuilder.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/config/AppInfoBuilder.java
@@ -163,6 +163,7 @@ class AppInfoBuilder {
                 containerIds.add(containerInfo.id);
             }
         }
+        containerIds.addAll(appInfo.containerIds);
 
         //
         //  EJB Jars
@@ -177,6 +178,14 @@ class AppInfoBuilder {
 
                 for (final EnterpriseBeanInfo bean : ejbJarInfo.enterpriseBeans) {
                     final EjbDeployment d = deploymentsByEjbName.get(bean.ejbName);
+                    if (d.getContainerId() != null && !containerIds.contains(d.getContainerId())) {
+                        for (final String cId : appInfo.containerIds) {
+                            if (cId.endsWith("/" + d.getContainerId())) {
+                                d.setContainerId(cId);
+                                break;
+                            }
+                        }
+                    }
 
                     /*
                      * JRG - there's probably a better way of handling this, but this code handles the case when:
@@ -349,6 +358,11 @@ class AppInfoBuilder {
                 info.resourceAliases.addAll(def.getAliases());
             }
         }
+        for (final Container def : module.getContainers()) {
+            if (!def.getProperties().containsKey("ApplicationWide")) {
+                info.containerIds.add(def.getId());
+            }
+        }
     }
 
     private void buildClientModules(final AppModule appModule, final AppInfo appInfo, final JndiEncInfoBuilder jndiEncInfoBuilder) throws OpenEJBException {

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/config/AppModule.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/config/AppModule.java b/container/openejb-core/src/main/java/org/apache/openejb/config/AppModule.java
index ffa3e4e..517be0a 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/config/AppModule.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/config/AppModule.java
@@ -17,6 +17,7 @@
 
 package org.apache.openejb.config;
 
+import org.apache.openejb.config.sys.Container;
 import org.apache.openejb.config.sys.Resource;
 import org.apache.openejb.config.sys.Service;
 import org.apache.openejb.core.ParentClassLoaderFinder;
@@ -61,6 +62,7 @@ public class AppModule implements DeploymentModule {
     private final Map<String, TransactionType> txTypeByUnit = new HashMap<String, TransactionType>();
     // TODO We could turn this into the Resources JAXB object and support containers and other things as well
     private final Collection<Resource> resources = new LinkedHashSet<Resource>();
+    private final Collection<Container> containers = new LinkedHashSet<Container>();
     private final Collection<Service> services = new HashSet<Service>();
     private final ClassLoader classLoader;
     private EntityMappings cmpMappings;
@@ -360,6 +362,10 @@ public class AppModule implements DeploymentModule {
         return resources;
     }
 
+    public Collection<Container> getContainers() {
+        return containers;
+    }
+
     public Collection<Service> getServices() {
         return services;
     }

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/config/AutoConfig.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/config/AutoConfig.java b/container/openejb-core/src/main/java/org/apache/openejb/config/AutoConfig.java
index 23e9a08..edcc05a 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/config/AutoConfig.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/config/AutoConfig.java
@@ -21,6 +21,7 @@ import org.apache.openejb.JndiConstants;
 import org.apache.openejb.OpenEJBException;
 import org.apache.openejb.assembler.classic.ContainerInfo;
 import org.apache.openejb.assembler.classic.ResourceInfo;
+import org.apache.openejb.config.sys.Container;
 import org.apache.openejb.config.sys.Resource;
 import org.apache.openejb.jee.ActivationConfig;
 import org.apache.openejb.jee.ActivationConfigProperty;
@@ -64,6 +65,7 @@ import org.apache.openejb.util.SuperProperties;
 import org.apache.openejb.util.URISupport;
 import org.apache.openejb.util.URLs;
 
+import java.util.HashSet;
 import javax.annotation.ManagedBean;
 import javax.ejb.TimerService;
 import javax.enterprise.inject.spi.BeanManager;
@@ -109,6 +111,8 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
     public static final String ORIGIN_FLAG = "Origin";
     public static final String ORIGINAL_ID = "OriginalId";
 
+    private static final AppResources EMPTY_APP_RESOURCES = new AppResources();
+
     public static Logger logger = Logger.getInstance(LogCategory.OPENEJB_STARTUP_CONFIG, AutoConfig.class);
 
     private static final int MAX_IMPLICIT_POOL_SIZE = 5;
@@ -184,6 +188,7 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
         appResources.dump();
 
         processApplicationResources(appModule);
+        processApplicationContainers(appModule, appResources);
 
         for (final EjbModule ejbModule : appModule.getEjbModules()) {
             processActivationConfig(ejbModule);
@@ -884,6 +889,25 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
         }
     }
 
+    private void processApplicationContainers(final AppModule module, final AppResources appResources) throws OpenEJBException {
+        if (module.getContainers().isEmpty()) {
+            return;
+        }
+
+        final String prefix = module.getModuleId() + "/";
+        for (final Container container : module.getContainers()) {
+            if (container.getId() == null) {
+                throw new IllegalStateException("a container can't get a null id: " + container.getType() + " from " + module.getModuleId());
+            }
+            if (!container.getId().startsWith(prefix)) {
+                container.setId(prefix + container.getId());
+            }
+            final ContainerInfo containerInfo = configFactory.createContainerInfo(container);
+            configFactory.install(containerInfo);
+            appResources.addContainer(containerInfo);
+        }
+    }
+
     private void processApplicationResources(final AppModule module) throws OpenEJBException {
         final Collection<Resource> resources = module.getResources();
 
@@ -1937,7 +1961,7 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
         }
 
         if (appResources == null) {
-            appResources = new AppResources();
+            appResources = EMPTY_APP_RESOURCES;
         }
 
         // skip references such as URL which are automatically handled by the server
@@ -2140,7 +2164,7 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
             return null;
         }
         if (appResources == null) {
-            appResources = new AppResources();
+            appResources = EMPTY_APP_RESOURCES;
         }
 
         // skip references such as URLs which are automatically handled by the server
@@ -2192,7 +2216,7 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
     }
 
     private String getUsableContainer(final Class<? extends ContainerInfo> containerInfoType, final Object bean, final AppResources appResources) {
-        if (bean instanceof MessageDrivenBean) {
+        if (MessageDrivenBean.class.isInstance(bean)) {
             final MessageDrivenBean messageDrivenBean = (MessageDrivenBean) bean;
             final String messagingType = messageDrivenBean.getMessagingType();
             final List<String> containerIds = appResources.containerIdsByType.get(messagingType);
@@ -2201,10 +2225,22 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
             }
         }
 
-        for (final ContainerInfo containerInfo : configFactory.getContainerInfos()) {
+        String containerInfo = matchContainer(containerInfoType, bean, appResources.getContainerInfos());
+        if (containerInfo == null) { // avoid to build configFactory.getContainerInfos() if not needed
+            containerInfo = matchContainer(containerInfoType, bean, configFactory.getContainerInfos());
+        }
+        if (containerInfo != null) {
+            return containerInfo;
+        }
+
+        return null;
+    }
+
+    private String matchContainer(final Class<? extends ContainerInfo> containerInfoType, final Object bean, final Collection<ContainerInfo> list) {
+        for (final ContainerInfo containerInfo : list) {
             if (containerInfo.getClass().equals(containerInfoType)) {
                 // MDBs must match message listener interface type
-                if (bean instanceof MessageDrivenBean) {
+                if (MessageDrivenBean.class.isInstance(bean)) {
                     final MessageDrivenBean messageDrivenBean = (MessageDrivenBean) bean;
                     final String messagingType = messageDrivenBean.getMessagingType();
                     if (containerInfo.properties.get("MessageListenerInterface").equals(messagingType)) {
@@ -2215,7 +2251,6 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
                 }
             }
         }
-
         return null;
     }
 
@@ -2228,6 +2263,7 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
         private final Map<String, List<String>> resourceIdsByType = new TreeMap<String, List<String>>();
         private final Map<String, List<String>> resourceEnvIdsByType = new TreeMap<String, List<String>>();
         private final Map<String, List<String>> containerIdsByType = new TreeMap<String, List<String>>();
+        private final Collection<ContainerInfo> containerInfos = new HashSet<ContainerInfo>();
 
         public void dump() {
             if (!logger.isDebugEnabled()) {
@@ -2391,6 +2427,16 @@ public class AutoConfig implements DynamicDeployer, JndiConstants {
             //            }
         }
 
+        public Collection<ContainerInfo> getContainerInfos() {
+            return containerInfos;
+        }
+
+        // needs to be called after merge otherwise we get wrong/missing data
+        private void addContainer(final ContainerInfo container) {
+            containerInfos.add(container);
+            // no need to enrich containerIdsByType here, TODO: see if we can remove containerIdsByType
+        }
+
         public List<String> getResourceIds(final String type) {
             if (type == null) {
                 final List<String> allResourceIds = new ArrayList<String>();

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/config/DeploymentLoader.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/config/DeploymentLoader.java b/container/openejb-core/src/main/java/org/apache/openejb/config/DeploymentLoader.java
index 0a7514b..8cdb8f1 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/config/DeploymentLoader.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/config/DeploymentLoader.java
@@ -25,6 +25,7 @@ import org.apache.openejb.api.RemoteClient;
 import org.apache.openejb.classloader.ClassLoaderConfigurer;
 import org.apache.openejb.classloader.WebAppEnricher;
 import org.apache.openejb.config.event.BeforeDeploymentEvent;
+import org.apache.openejb.config.sys.Resources;
 import org.apache.openejb.core.EmptyResourcesClassLoader;
 import org.apache.openejb.core.ParentClassLoaderFinder;
 import org.apache.openejb.jee.Application;
@@ -520,6 +521,22 @@ public class DeploymentLoader implements DeploymentFilterable {
             if (applicationXmlUrl != null) {
                 appModule.getWatchedResources().add(URLs.toFilePath(applicationXmlUrl));
             }
+            if (appDescriptors.containsKey(RESOURCES_XML)) {
+                final Map<String, Object> altDd = new HashMap<String, Object>(appDescriptors);
+                ReadDescriptors.readResourcesXml(new org.apache.openejb.config.Module(false) {
+                    @Override
+                    public Map<String, Object> getAltDDs() {
+                        return altDd;
+                    }
+
+                    @Override
+                    public void initResources(final Resources resources) {
+                        appModule.getContainers().addAll(resources.getContainer());
+                        appModule.getResources().addAll(resources.getResource());
+                        appModule.getServices().addAll(resources.getService());
+                    }
+                });
+            }
 
             // EJB modules
             for (final String moduleName : ejbModules.keySet()) {

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/config/Module.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/config/Module.java b/container/openejb-core/src/main/java/org/apache/openejb/config/Module.java
index 30667f3..bdf1dad 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/config/Module.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/config/Module.java
@@ -100,6 +100,7 @@ public class Module {
         this.appModule = appModule;
         if (resources != null) {
             this.appModule.getResources().addAll(resources.getResource());
+            this.appModule.getContainers().addAll(resources.getContainer());
             this.appModule.getServices().addAll(resources.getService());
         }
     }

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/main/java/org/apache/openejb/testing/ApplicationComposers.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/main/java/org/apache/openejb/testing/ApplicationComposers.java b/container/openejb-core/src/main/java/org/apache/openejb/testing/ApplicationComposers.java
index ce28cb5..1ac788a 100644
--- a/container/openejb-core/src/main/java/org/apache/openejb/testing/ApplicationComposers.java
+++ b/container/openejb-core/src/main/java/org/apache/openejb/testing/ApplicationComposers.java
@@ -43,6 +43,7 @@ import org.apache.openejb.config.WebModule;
 import org.apache.openejb.config.sys.JSonConfigReader;
 import org.apache.openejb.config.sys.JaxbOpenejb;
 import org.apache.openejb.config.sys.Openejb;
+import org.apache.openejb.config.sys.Resources;
 import org.apache.openejb.core.LocalInitialContextFactory;
 import org.apache.openejb.core.Operation;
 import org.apache.openejb.core.ThreadContext;
@@ -126,12 +127,13 @@ public final class ApplicationComposers {
 
     public static final String OPENEJB_APPLICATION_COMPOSER_CONTEXT = "openejb.application.composer.context";
     private static final Class[] MODULE_TYPES = {IAnnotationFinder.class, ClassesArchive.class,
-            AppModule.class, WebModule.class, EjbModule.class,
-            Application.class,
-            WebApp.class, EjbJar.class, EnterpriseBean.class,
-            Persistence.class, PersistenceUnit.class,
-            Connector.class, Beans.class,
-            Class[].class, Class.class
+        AppModule.class, WebModule.class, EjbModule.class,
+        Application.class,
+        WebApp.class, EjbJar.class, EnterpriseBean.class,
+        Persistence.class, PersistenceUnit.class,
+        Connector.class, Beans.class,
+        Class[].class, Class.class,
+        Resources.class
     };
 
     static {
@@ -710,6 +712,10 @@ public final class ApplicationComposers {
                     ejbModule.setFinder(new AnnotationFinder((Archive) obj).link());
                     ejbModule.setBeans(new Beans());
                     appModule.getEjbModules().add(ejbModule);
+                } else if (obj instanceof Resources) {
+                    final Resources asResources = Resources.class.cast(obj);
+                    appModule.getResources().addAll(asResources.getResource());
+                    appModule.getContainers().addAll(asResources.getContainer());
                 } else if (obj instanceof AppModule) {
                     // we can probably go further here
                     final AppModule module = (AppModule) obj;

http://git-wip-us.apache.org/repos/asf/tomee/blob/6b2f1bd4/container/openejb-core/src/test/java/org/apache/openejb/config/AppContainerTest.java
----------------------------------------------------------------------
diff --git a/container/openejb-core/src/test/java/org/apache/openejb/config/AppContainerTest.java b/container/openejb-core/src/test/java/org/apache/openejb/config/AppContainerTest.java
new file mode 100644
index 0000000..abec2da
--- /dev/null
+++ b/container/openejb-core/src/test/java/org/apache/openejb/config/AppContainerTest.java
@@ -0,0 +1,83 @@
+/**
+ * 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.config;
+
+import org.apache.openejb.InterfaceType;
+import org.apache.openejb.OpenEJBException;
+import org.apache.openejb.config.sys.Container;
+import org.apache.openejb.config.sys.Resources;
+import org.apache.openejb.core.singleton.SingletonContainer;
+import org.apache.openejb.jee.EjbJar;
+import org.apache.openejb.junit.ApplicationComposer;
+import org.apache.openejb.testing.Classes;
+import org.apache.openejb.testing.Module;
+import org.apache.openejb.testing.SimpleLog;
+import org.junit.Test;
+import org.junit.runner.RunWith;
+
+import java.lang.reflect.Method;
+import javax.ejb.EJB;
+import javax.ejb.Singleton;
+
+import static org.junit.Assert.assertEquals;
+
+@SimpleLog
+@RunWith(ApplicationComposer.class)
+public class AppContainerTest {
+
+    @Module
+    @Classes(AppContainerTest.Singleton1.class)
+    public EjbModule module() {
+        final Resources resources = new Resources();
+        final Container container = new Container();
+        container.setId("theMine");
+        container.setType("SINGLETON");
+        container.setClassName("org.apache.openejb.config.AppContainerTest$MySingletonContainer");
+        resources.getContainer().add(container);
+
+        final EjbModule ejbModule = new EjbModule(new EjbJar());
+        ejbModule.initResources(resources);
+        return ejbModule;
+    }
+
+    @Singleton
+    public static class Singleton1 {
+        public String ok() {
+            throw new UnsupportedOperationException("my container mocks it");
+        }
+    }
+
+    @EJB
+    private Singleton1 s1;
+
+    @Test
+    public void run() {
+        assertEquals("yeah!", s1.ok());
+    }
+
+    public static class MySingletonContainer extends SingletonContainer {
+        public MySingletonContainer() throws OpenEJBException {
+            super("mine", null);
+        }
+
+        @Override
+        public Object invoke(final Object deployID, final InterfaceType type, final Class callInterface,
+                             final Method callMethod, final Object[] args, final Object primKey) throws OpenEJBException {
+            return callMethod.getDeclaringClass() == Singleton1.class ? "yeah!" : super.invoke(deployID, type, callInterface, callMethod, args, primKey);
+        }
+    }
+}


[2/2] tomee git commit: Merge remote-tracking branch 'apache/tomee-1.7.x' into tomee-1.7.x

Posted by jg...@apache.org.
Merge remote-tracking branch 'apache/tomee-1.7.x' into tomee-1.7.x


Project: http://git-wip-us.apache.org/repos/asf/tomee/repo
Commit: http://git-wip-us.apache.org/repos/asf/tomee/commit/6fa74418
Tree: http://git-wip-us.apache.org/repos/asf/tomee/tree/6fa74418
Diff: http://git-wip-us.apache.org/repos/asf/tomee/diff/6fa74418

Branch: refs/heads/tomee-1.7.x
Commit: 6fa744189281a3285b28ac563b480c37c33da8fc
Parents: 6b2f1bd 4736446
Author: Jonathan Gallimore <jo...@jrg.me.uk>
Authored: Mon Oct 30 09:37:05 2017 +0000
Committer: Jonathan Gallimore <jo...@jrg.me.uk>
Committed: Mon Oct 30 09:37:05 2017 +0000

----------------------------------------------------------------------
 .../openejb/monitoring/StatsInterceptor.java      | 10 ++++++++++
 .../java/org/apache/openejb/util/LogCategory.java |  1 +
 .../apache/openejb/monitoring/Messages.properties | 18 ++++++++++++++++++
 3 files changed, 29 insertions(+)
----------------------------------------------------------------------