You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@commons.apache.org by ol...@apache.org on 2014/04/28 01:48:57 UTC

svn commit: r1590533 - in /commons/proper/jcs/trunk: ./ src/java/org/apache/commons/jcs/auxiliary/disk/block/ src/java/org/apache/commons/jcs/auxiliary/disk/file/ src/java/org/apache/commons/jcs/auxiliary/disk/indexed/ src/java/org/apache/commons/jcs/a...

Author: olamy
Date: Sun Apr 27 23:48:56 2014
New Revision: 1590533

URL: http://svn.apache.org/r1590533
Log:
setup to get cdi tests failling

Added:
    commons/proper/jcs/trunk/src/tck-java/
    commons/proper/jcs/trunk/src/tck-java/org/
    commons/proper/jcs/trunk/src/tck-java/org/apache/
    commons/proper/jcs/trunk/src/tck-java/org/apache/commons/
    commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/
    commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/
    commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java   (with props)
    commons/proper/jcs/trunk/src/tck-resources/META-INF/
    commons/proper/jcs/trunk/src/tck-resources/META-INF/services/
    commons/proper/jcs/trunk/src/tck-resources/META-INF/services/javax.cache.annotation.BeanProvider
Modified:
    commons/proper/jcs/trunk/pom.xml
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/block/BlockDiskCacheManager.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/file/FileDiskCacheManager.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/indexed/IndexedDiskCacheManager.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/jdbc/JDBCDiskCacheManagerAbstractTemplate.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/remote/server/RemoteCacheServer.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/CacheListeners.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/control/CompositeCacheManager.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/memory/AbstractDoubleLinkedListMemoryCache.java
    commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/utils/struct/LRUMap.java
    commons/proper/jcs/trunk/tck.xml

Modified: commons/proper/jcs/trunk/pom.xml
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/pom.xml?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/pom.xml (original)
+++ commons/proper/jcs/trunk/pom.xml Sun Apr 27 23:48:56 2014
@@ -132,6 +132,18 @@
         <version>1.0.0</version>
         <scope>provided</scope>
     </dependency>
+    <dependency>
+        <groupId>org.apache.geronimo.specs</groupId>
+        <artifactId>geronimo-jcdi_1.0_spec</artifactId>
+        <version>1.0</version>
+        <scope>provided</scope>
+    </dependency>
+    <dependency>
+        <groupId>org.apache.geronimo.specs</groupId>
+        <artifactId>geronimo-interceptor_1.1_spec</artifactId>
+        <version>1.0</version>
+        <scope>provided</scope>
+    </dependency>
 
     <!-- to debug tcks -->
     <dependency>

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/block/BlockDiskCacheManager.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/block/BlockDiskCacheManager.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/block/BlockDiskCacheManager.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/block/BlockDiskCacheManager.java Sun Apr 27 23:48:56 2014
@@ -20,7 +20,8 @@ package org.apache.commons.jcs.auxiliary
  */
 
 import java.io.Serializable;
-import java.util.Hashtable;
+import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.auxiliary.disk.AbstractDiskCacheManager;
 import org.apache.commons.jcs.engine.behavior.IElementSerializer;
@@ -44,8 +45,8 @@ public class BlockDiskCacheManager
     private static BlockDiskCacheManager instance;
 
     /** block disks for a region. */
-    private final Hashtable<String, BlockDiskCache<? extends Serializable, ? extends Serializable>> caches =
-        new Hashtable<String, BlockDiskCache<? extends Serializable, ? extends Serializable>>();
+    private final Map<String, BlockDiskCache<? extends Serializable, ? extends Serializable>> caches =
+        new ConcurrentHashMap<String, BlockDiskCache<? extends Serializable, ? extends Serializable>>();
 
     /** Attributes. */
     private final BlockDiskCacheAttributes defaultCacheAttributes;

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/file/FileDiskCacheManager.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/file/FileDiskCacheManager.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/file/FileDiskCacheManager.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/file/FileDiskCacheManager.java Sun Apr 27 23:48:56 2014
@@ -20,7 +20,8 @@ package org.apache.commons.jcs.auxiliary
  */
 
 import java.io.Serializable;
-import java.util.Hashtable;
+import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.auxiliary.disk.AbstractDiskCacheManager;
 import org.apache.commons.jcs.engine.behavior.IElementSerializer;
@@ -41,8 +42,8 @@ public class FileDiskCacheManager
     private static final Log log = LogFactory.getLog( FileDiskCacheManager.class );
 
     /** Each region has an entry here. */
-    private final Hashtable<String, FileDiskCache<? extends Serializable, ? extends Serializable>> caches =
-        new Hashtable<String, FileDiskCache<? extends Serializable, ? extends Serializable>>();
+    private final Map<String, FileDiskCache<? extends Serializable, ? extends Serializable>> caches =
+        new ConcurrentHashMap<String, FileDiskCache<? extends Serializable, ? extends Serializable>>();
 
     /** User configurable attributes */
     private final FileDiskCacheAttributes defaultCacheAttributes;

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/indexed/IndexedDiskCacheManager.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/indexed/IndexedDiskCacheManager.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/indexed/IndexedDiskCacheManager.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/indexed/IndexedDiskCacheManager.java Sun Apr 27 23:48:56 2014
@@ -20,7 +20,8 @@ package org.apache.commons.jcs.auxiliary
  */
 
 import java.io.Serializable;
-import java.util.Hashtable;
+import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.auxiliary.disk.AbstractDiskCacheManager;
 import org.apache.commons.jcs.engine.behavior.IElementSerializer;
@@ -44,8 +45,8 @@ public class IndexedDiskCacheManager
     private static IndexedDiskCacheManager instance;
 
     /** Each region has an entry here. */
-    private final Hashtable<String, IndexedDiskCache<? extends Serializable, ? extends Serializable>> caches =
-        new Hashtable<String, IndexedDiskCache<? extends Serializable, ? extends Serializable>>();
+    private final Map<String, IndexedDiskCache<? extends Serializable, ? extends Serializable>> caches =
+        new ConcurrentHashMap<String, IndexedDiskCache<? extends Serializable, ? extends Serializable>>();
 
     /** User configurable attributes */
     private final IndexedDiskCacheAttributes defaultCacheAttributes;

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/jdbc/JDBCDiskCacheManagerAbstractTemplate.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/jdbc/JDBCDiskCacheManagerAbstractTemplate.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/jdbc/JDBCDiskCacheManagerAbstractTemplate.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/disk/jdbc/JDBCDiskCacheManagerAbstractTemplate.java Sun Apr 27 23:48:56 2014
@@ -21,8 +21,8 @@ package org.apache.commons.jcs.auxiliary
 
 import java.io.IOException;
 import java.io.Serializable;
-import java.util.Hashtable;
 import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.Executors;
 import java.util.concurrent.ScheduledExecutorService;
 import java.util.concurrent.ThreadFactory;
@@ -52,14 +52,14 @@ public abstract class JDBCDiskCacheManag
     protected static int clients; // TODO needs to be made private and synchronised and/or turned into AtomicInt
 
     /** A map of JDBCDiskCache objects to region names. */
-    private static Hashtable<String, JDBCDiskCache<? extends Serializable, ? extends Serializable>> caches =
-        new Hashtable<String, JDBCDiskCache<? extends Serializable, ? extends Serializable>>();
+    private static Map<String, JDBCDiskCache<? extends Serializable, ? extends Serializable>> caches =
+        new ConcurrentHashMap<String, JDBCDiskCache<? extends Serializable, ? extends Serializable>>();
 
     /**
      * A map of TableState objects to table names. Each cache has a table state object, which is
      * used to determine if any long processes such as deletes or optimizations are running.
      */
-    protected static Hashtable<String, TableState> tableStates = new Hashtable<String, TableState>();
+    protected static Map<String, TableState> tableStates = new ConcurrentHashMap<String, TableState>();
 
     /** The background disk shrinker, one for all regions. */
     private ScheduledExecutorService shrinkerDaemon; // TODO this is not accessed in a threadsafe way. Perhaps use IODH idiom?
@@ -68,7 +68,7 @@ public abstract class JDBCDiskCacheManag
      * A map of table name to shrinker threads. This allows each table to have a different setting.
      * It assumes that there is only one jdbc disk cache auxiliary defined per table.
      */
-    private final Map<String, ShrinkerThread> shrinkerThreadMap = new Hashtable<String, ShrinkerThread>();
+    private final Map<String, ShrinkerThread> shrinkerThreadMap = new ConcurrentHashMap<String, ShrinkerThread>();
 
     /**
      * Children must implement this method.

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/remote/server/RemoteCacheServer.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/remote/server/RemoteCacheServer.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/remote/server/RemoteCacheServer.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/auxiliary/remote/server/RemoteCacheServer.java Sun Apr 27 23:48:56 2014
@@ -28,10 +28,10 @@ import java.rmi.server.RMISocketFactory;
 import java.rmi.server.UnicastRemoteObject;
 import java.rmi.server.Unreferenced;
 import java.util.Collections;
-import java.util.Hashtable;
 import java.util.Iterator;
 import java.util.Map;
 import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.access.exception.CacheException;
 import org.apache.commons.jcs.auxiliary.remote.behavior.IRemoteCacheListener;
@@ -85,21 +85,21 @@ public class RemoteCacheServer<K extends
     private int puts = 0;
 
     /** Maps cache name to CacheListeners object. association of listeners (regions). */
-    private final Hashtable<String, CacheListeners<K, V>> cacheListenersMap =
-        new Hashtable<String, CacheListeners<K, V>>();
+    private final Map<String, CacheListeners<K, V>> cacheListenersMap =
+        new ConcurrentHashMap<String, CacheListeners<K, V>>();
 
     /** maps cluster listeners to regions. */
-    private final Hashtable<String, CacheListeners<K, V>> clusterListenersMap =
-        new Hashtable<String, CacheListeners<K, V>>();
+    private final Map<String, CacheListeners<K, V>> clusterListenersMap =
+        new ConcurrentHashMap<String, CacheListeners<K, V>>();
 
     /** The central hub */
     private transient CompositeCacheManager cacheManager;
 
     /** relates listener id with a type */
-    private final Hashtable<Long, RemoteType> idTypeMap = new Hashtable<Long, RemoteType>();
+    private final Map<Long, RemoteType> idTypeMap = new ConcurrentHashMap<Long, RemoteType>();
 
     /** relates listener id with an ip address */
-    private final Hashtable<Long, String> idIPMap = new Hashtable<Long, String>();
+    private final Map<Long, String> idIPMap = new ConcurrentHashMap<Long, String>();
 
     /** Used to get the next listener id. */
     private final int[] listenerId = new int[1];

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/CacheListeners.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/CacheListeners.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/CacheListeners.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/CacheListeners.java Sun Apr 27 23:48:56 2014
@@ -20,9 +20,9 @@ package org.apache.commons.jcs.engine;
  */
 
 import java.io.Serializable;
-import java.util.Hashtable;
 import java.util.Iterator;
 import java.util.Map;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.engine.behavior.ICache;
 import org.apache.commons.jcs.engine.behavior.ICacheEventQueue;
@@ -38,7 +38,7 @@ public class CacheListeners<K extends Se
 
     /** Map ICacheListener to ICacheEventQueue */
     public final Map<Long, ICacheEventQueue<K, V>> eventQMap =
-        new Hashtable<Long, ICacheEventQueue<K, V>>();
+        new ConcurrentHashMap<Long, ICacheEventQueue<K, V>>();
 
     /**
      * Constructs with the given cache.

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/control/CompositeCacheManager.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/control/CompositeCacheManager.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/control/CompositeCacheManager.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/control/CompositeCacheManager.java Sun Apr 27 23:48:56 2014
@@ -26,10 +26,11 @@ import java.lang.management.ManagementFa
 import java.security.AccessControlException;
 import java.util.ArrayList;
 import java.util.HashSet;
-import java.util.Hashtable;
 import java.util.Iterator;
+import java.util.Map;
 import java.util.Properties;
 import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.Executors;
 import java.util.concurrent.ScheduledExecutorService;
 import java.util.concurrent.ThreadFactory;
@@ -78,8 +79,8 @@ public class CompositeCacheManager
     private static final String JMX_OBJECT_NAME = "org.apache.commons.jcs:type=JCSAdminBean";
 
     /** Caches managed by this cache manager */
-    private final Hashtable<String, ICache<? extends Serializable, ? extends Serializable>> caches =
-        new Hashtable<String, ICache<? extends Serializable, ? extends Serializable>>();
+    private final Map<String, ICache<? extends Serializable, ? extends Serializable>> caches =
+        new ConcurrentHashMap<String, ICache<? extends Serializable, ? extends Serializable>>();
 
     /** Number of clients accessing this cache manager */
     private int clients;
@@ -91,12 +92,12 @@ public class CompositeCacheManager
     private IElementAttributes defaultElementAttr = new ElementAttributes();
 
     /** Used to keep track of configured auxiliaries */
-    private final Hashtable<String, AuxiliaryCacheFactory> auxiliaryFactoryRegistry =
-        new Hashtable<String, AuxiliaryCacheFactory>( 11 );
+    private final Map<String, AuxiliaryCacheFactory> auxiliaryFactoryRegistry =
+        new ConcurrentHashMap<String, AuxiliaryCacheFactory>( 11 );
 
     /** Used to keep track of attributes for auxiliaries. */
-    private final Hashtable<String, AuxiliaryCacheAttributes> auxiliaryAttributeRegistry =
-        new Hashtable<String, AuxiliaryCacheAttributes>( 11 );
+    private final Map<String, AuxiliaryCacheAttributes> auxiliaryAttributeRegistry =
+        new ConcurrentHashMap<String, AuxiliaryCacheAttributes>( 11 );
 
     /** Properties with which this manager was configured. This is exposed for other managers. */
     private Properties configurationProperties;

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/memory/AbstractDoubleLinkedListMemoryCache.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/memory/AbstractDoubleLinkedListMemoryCache.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/memory/AbstractDoubleLinkedListMemoryCache.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/engine/memory/AbstractDoubleLinkedListMemoryCache.java Sun Apr 27 23:48:56 2014
@@ -22,12 +22,12 @@ package org.apache.commons.jcs.engine.me
 import java.io.IOException;
 import java.io.Serializable;
 import java.util.ArrayList;
-import java.util.Hashtable;
 import java.util.Iterator;
 import java.util.LinkedHashSet;
 import java.util.Map;
 import java.util.Map.Entry;
 import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.engine.CacheConstants;
 import org.apache.commons.jcs.engine.behavior.ICacheElement;
@@ -92,7 +92,7 @@ public abstract class AbstractDoubleLink
     @Override
     public Map<K, MemoryElementDescriptor<K, V>> createMap()
     {
-        return new Hashtable<K, MemoryElementDescriptor<K, V>>();
+        return new ConcurrentHashMap<K, MemoryElementDescriptor<K, V>>();
     }
 
     /**

Modified: commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/utils/struct/LRUMap.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/utils/struct/LRUMap.java?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/utils/struct/LRUMap.java (original)
+++ commons/proper/jcs/trunk/src/java/org/apache/commons/jcs/utils/struct/LRUMap.java Sun Apr 27 23:48:56 2014
@@ -23,12 +23,12 @@ import java.io.Serializable;
 import java.util.ArrayList;
 import java.util.Collection;
 import java.util.HashSet;
-import java.util.Hashtable;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
 import java.util.NoSuchElementException;
 import java.util.Set;
+import java.util.concurrent.ConcurrentHashMap;
 
 import org.apache.commons.jcs.engine.control.group.GroupAttrName;
 import org.apache.commons.jcs.engine.stats.StatElement;
@@ -89,7 +89,7 @@ public class LRUMap<K, V>
 
         // normal hshtable is faster for
         // sequential keys.
-        map = new Hashtable<K, LRUElementDescriptor<K, V>>();
+        map = new ConcurrentHashMap<K, LRUElementDescriptor<K, V>>();
         // map = new ConcurrentHashMap();
     }
 

Added: commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java?rev=1590533&view=auto
==============================================================================
--- commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java (added)
+++ commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java Sun Apr 27 23:48:56 2014
@@ -0,0 +1,41 @@
+package org.apache.commons.jcs.jcache;
+
+import org.apache.webbeans.config.WebBeansContext;
+import org.apache.webbeans.container.BeanManagerImpl;
+import org.apache.webbeans.spi.ContainerLifecycle;
+
+import javax.cache.annotation.BeanProvider;
+import javax.enterprise.inject.spi.Bean;
+import java.util.Set;
+
+// TODO: move it over a tck module and remove owb dependency in main pom
+public class OWBBeanProvider implements BeanProvider {
+    private final BeanManagerImpl bm;
+
+    public OWBBeanProvider() {
+        final WebBeansContext webBeansContext = WebBeansContext.currentInstance();
+        final ContainerLifecycle lifecycle = webBeansContext.getService(ContainerLifecycle.class);
+        lifecycle.startApplication(null);
+        Runtime.getRuntime().addShutdownHook(new Thread() {
+            @Override
+            public void run() {
+                lifecycle.stopApplication(null);
+            }
+        });
+        bm = webBeansContext.getBeanManagerImpl();
+    }
+
+    @Override
+    public <T> T getBeanByType(final Class<T> tClass) {
+        if (tClass == null) {
+            throw new IllegalArgumentException("no bean class specified");
+        }
+
+        final Set<Bean<?>> beans = bm.getBeans(tClass);
+        if (beans.isEmpty()) {
+            throw new IllegalStateException("no bean of type " + tClass.getName());
+        }
+        final Bean<?> bean = bm.resolve(beans);
+        return (T) bm.getReference(bean, bean.getBeanClass(), bm.createCreationalContext(bean));
+    }
+}

Propchange: commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: commons/proper/jcs/trunk/src/tck-java/org/apache/commons/jcs/jcache/OWBBeanProvider.java
------------------------------------------------------------------------------
    svn:keywords = Author Date Id Revision

Added: commons/proper/jcs/trunk/src/tck-resources/META-INF/services/javax.cache.annotation.BeanProvider
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/src/tck-resources/META-INF/services/javax.cache.annotation.BeanProvider?rev=1590533&view=auto
==============================================================================
--- commons/proper/jcs/trunk/src/tck-resources/META-INF/services/javax.cache.annotation.BeanProvider (added)
+++ commons/proper/jcs/trunk/src/tck-resources/META-INF/services/javax.cache.annotation.BeanProvider Sun Apr 27 23:48:56 2014
@@ -0,0 +1 @@
+org.apache.commons.jcs.jcache.OWBBeanProvider

Modified: commons/proper/jcs/trunk/tck.xml
URL: http://svn.apache.org/viewvc/commons/proper/jcs/trunk/tck.xml?rev=1590533&r1=1590532&r2=1590533&view=diff
==============================================================================
--- commons/proper/jcs/trunk/tck.xml (original)
+++ commons/proper/jcs/trunk/tck.xml Sun Apr 27 23:48:56 2014
@@ -3,16 +3,10 @@
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
   <!--
-  NOTE: ENSURE TO hAVE BUILD commons-jcs BEFORE.
-
   TO RUN TCKs CALL:
 
   $ mvn -f tck.xml test
 
-  or one of the following profiles:
-  -P test-optional-cache
-  -P test-basic-cache
-
   to run from an IDE a JMX test add:
     -Dorg.jsr107.tck.management.agentId=MBeanServerJCS -Djavax.management.builder.initial=org.apache.commons.jcs.jcache.jmx.ConfigurableMBeanServerIdBuilder
   -->
@@ -33,7 +27,8 @@
     <CacheImpl>org.apache.commons.jcs.jcache.JCSCache</CacheImpl>
     <CacheEntryImpl>org.apache.commons.jcs.jcache.JCSEntry</CacheEntryImpl>
 
-    <javax.management.builder.initial>org.apache.commons.jcs.jcache.jmx.ConfigurableMBeanServerIdBuilder</javax.management.builder.initial>
+    <javax.management.builder.initial>org.apache.commons.jcs.jcache.jmx.ConfigurableMBeanServerIdBuilder
+    </javax.management.builder.initial>
     <org.jsr107.tck.management.agentId>MBeanServerJCS</org.jsr107.tck.management.agentId>
 
     <domain-lib-dir>${project.build.directory}/domainlib</domain-lib-dir>
@@ -97,9 +92,34 @@
       <version>1.1</version>
     </dependency>
 
+    <dependency>
+      <groupId>org.apache.geronimo.specs</groupId>
+      <artifactId>geronimo-jcdi_1.0_spec</artifactId>
+      <version>1.0</version>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.geronimo.specs</groupId>
+      <artifactId>geronimo-atinject_1.0_spec</artifactId>
+      <version>1.0</version>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.geronimo.specs</groupId>
+      <artifactId>geronimo-interceptor_1.1_spec</artifactId>
+      <version>1.0</version>
+      <scope>provided</scope>
+    </dependency>
+    <dependency>
+      <groupId>org.apache.openwebbeans</groupId>
+      <artifactId>openwebbeans-impl</artifactId>
+      <version>1.2.2</version>
+      <scope>test</scope>
+    </dependency>
   </dependencies>
 
   <build>
+    <testSourceDirectory>src/tck-java</testSourceDirectory>
     <testResources>
       <testResource>
         <directory>src/tck-resources</directory>
@@ -165,7 +185,8 @@
             <javax.cache.CacheManager>${CacheManagerImpl}</javax.cache.CacheManager>
             <javax.cache.Cache>${CacheImpl}</javax.cache.Cache>
             <javax.cache.Cache.Entry>${CacheEntryImpl}</javax.cache.Cache.Entry>
-            <javax.cache.annotation.CacheInvocationContext>${CacheInvocationContextImpl}</javax.cache.annotation.CacheInvocationContext>
+            <javax.cache.annotation.CacheInvocationContext>${CacheInvocationContextImpl}
+            </javax.cache.annotation.CacheInvocationContext>
           </systemPropertyVariables>
         </configuration>
       </plugin>