You are viewing a plain text version of this content. The canonical link for it is here.
Posted to scm@geronimo.apache.org by jg...@apache.org on 2006/09/18 21:57:00 UTC

svn commit: r447526 - in /geronimo/sandbox/gcache: ./ server/ server/src/main/java/org/apache/geronimo/gcache/server/ server/src/main/java/org/apache/geronimo/gcache/server/config/ server/src/main/java/org/apache/geronimo/gcache/server/core/ server/src...

Author: jgenender
Date: Mon Sep 18 12:56:59 2006
New Revision: 447526

URL: http://svn.apache.org/viewvc?view=rev&rev=447526
Log:
Begin integrating ehcache and listener interfaces

Added:
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java   (with props)
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java   (with props)
Modified:
    geronimo/sandbox/gcache/pom.xml
    geronimo/sandbox/gcache/server/pom.xml
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/GCacheServer.java
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/config/Configuration.java
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/core/GCacheThread.java
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/impl/DefaultThreadPoolImpl.java
    geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/spi/ThreadPool.java

Modified: geronimo/sandbox/gcache/pom.xml
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/pom.xml?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/pom.xml (original)
+++ geronimo/sandbox/gcache/pom.xml Mon Sep 18 12:56:59 2006
@@ -33,9 +33,16 @@
                 <artifactId>gcache-server</artifactId>
                 <version>${gcacheVersion}</version>
             </dependency>
+
             <dependency>
                 <groupId>org.apache.geronimo.gcache</groupId>
                 <artifactId>gcache-client</artifactId>
+                <version>${gcacheVersion}</version>
+            </dependency>
+            
+            <dependency>
+                <groupId>org.apache.geronimo.gcache</groupId>
+                <artifactId>openwire</artifactId>
                 <version>${gcacheVersion}</version>
             </dependency>
 

Modified: geronimo/sandbox/gcache/server/pom.xml
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/pom.xml?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/pom.xml (original)
+++ geronimo/sandbox/gcache/server/pom.xml Mon Sep 18 12:56:59 2006
@@ -31,6 +31,11 @@
             <artifactId>ehcache</artifactId>
         </dependency>
 
+        <dependency>
+            <groupId>org.apache.geronimo.gcache</groupId>
+            <artifactId>openwire</artifactId>
+        </dependency>
+
     </dependencies>
     <build>
         <plugins>

Modified: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/GCacheServer.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/GCacheServer.java?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/GCacheServer.java (original)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/GCacheServer.java Mon Sep 18 12:56:59 2006
@@ -1,16 +1,19 @@
 package org.apache.geronimo.gcache.server;
 
 import org.apache.geronimo.gcache.server.config.Configuration;
+import org.apache.geronimo.gcache.server.core.GCacheThread;
 
 /**
- * Copyright 2006 The Apache Software Foundation
- * <p/>
- * Licensed 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/>
+ *
+ * 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
- * <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.
@@ -20,9 +23,23 @@
 public class GCacheServer {
 
     private final Configuration config;
+    private GCacheThread gcache = null;
 
     public GCacheServer(Configuration config) {
-       this.config = config;
+        this.config = config;
+    }
+
+    public void start() {
+        if (gcache == null) {
+            gcache = new GCacheThread(config);
+            gcache.start();
+        }
+    }
+
+    public void stop() {
+        if (gcache != null)
+            gcache.halt();
+        gcache = null;
     }
 
     public static void main(String[] args) {

Modified: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/config/Configuration.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/config/Configuration.java?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/config/Configuration.java (original)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/config/Configuration.java Mon Sep 18 12:56:59 2006
@@ -3,14 +3,16 @@
 import org.apache.geronimo.gcache.server.spi.ThreadPool;
 
 /**
- * Copyright 2006 The Apache Software Foundation
- * <p/>
- * Licensed 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/>
+ *
+ * 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
- * <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.

Modified: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/core/GCacheThread.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/core/GCacheThread.java?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/core/GCacheThread.java (original)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/core/GCacheThread.java Mon Sep 18 12:56:59 2006
@@ -3,19 +3,20 @@
 import org.apache.geronimo.gcache.server.spi.ThreadPool;
 import org.apache.geronimo.gcache.server.config.Configuration;
 
-import java.io.IOException;
-import java.net.InetSocketAddress;
-import java.nio.channels.ServerSocketChannel;
+import net.sf.ehcache.CacheManager;
+import net.sf.ehcache.Cache;
 
 /**
- * Copyright 2006 The Apache Software Foundation
- * <p/>
- * Licensed 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/>
+ *
+ * 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
- * <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.
@@ -24,14 +25,21 @@
  */
 public class GCacheThread extends Thread{
 
+    protected static final String GCACHE_NAME = "gcache";
+
     private boolean stopped;
     private boolean running;
     private final ThreadPool pool;
+    private final CacheManager cacheManager;
 
     public GCacheThread(Configuration config) {
         stopped = true;
         running = false;
         this.pool = config.getThreadPool();
+
+        net.sf.ehcache.config.Configuration econfig = new net.sf.ehcache.config.Configuration();
+        cacheManager = new CacheManager(econfig);
+
     }
 
     public void run() {
@@ -39,12 +47,17 @@
         stopped = false;
         running = true;
 
+        //TODO configure the cache here
+        Cache cache = new Cache(GCACHE_NAME);
+
         while(!stopped){
 
             //Comm component goes here...openwire preferred
         }
 
         running = false;
+        cacheManager.removeCache(GCACHE_NAME);
+        cacheManager.shutdown();
     }
 
     public void halt(){

Modified: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/impl/DefaultThreadPoolImpl.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/impl/DefaultThreadPoolImpl.java?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/impl/DefaultThreadPoolImpl.java (original)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/impl/DefaultThreadPoolImpl.java Mon Sep 18 12:56:59 2006
@@ -4,14 +4,16 @@
 import edu.emory.mathcs.backport.java.util.concurrent.*;
 
 /**
- * Copyright 2006 The Apache Software Foundation
- * <p/>
- * Licensed 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/>
+ *
+ * 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
- * <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.

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,33 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.bootstrap.BootstrapCacheLoader;
+import net.sf.ehcache.Ehcache;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPBootstrapCacheLoader implements BootstrapCacheLoader {
+    
+    public void load(Ehcache ehcache) {
+    }
+
+    public boolean isAsynchronous() {
+        return false;  //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public Object clone() throws CloneNotSupportedException {
+        return null;  //To change body of implemented methods use File | Settings | File Templates.
+    }
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoader.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,29 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.bootstrap.BootstrapCacheLoaderFactory;
+import net.sf.ehcache.bootstrap.BootstrapCacheLoader;
+
+import java.util.Properties;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPBootstrapCacheLoaderFactory extends BootstrapCacheLoaderFactory {
+
+    public BootstrapCacheLoader createBootstrapCacheLoader(Properties properties) {
+        return null;  //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPBootstrapCacheLoaderFactory.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,51 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.distribution.CacheManagerPeerListener;
+import net.sf.ehcache.CacheException;
+import net.sf.ehcache.Status;
+
+import java.util.List;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPCacheManagerPeerListener implements CacheManagerPeerListener {
+    public void init() throws CacheException {
+    }
+
+    public void dispose() throws CacheException {
+    }
+
+    public List getBoundCachePeers() {
+        return null;
+    }
+
+    public Status getStatus() {
+        return null;
+    }
+
+    public String getUniqueResourceIdentifier() {
+        return null;
+    }
+
+    public void attemptResolutionOfUniqueResourceConflict() throws IllegalStateException, CacheException {
+    }
+
+    public void notifyCacheAdded(String string) {
+    }
+
+    public void notifyCacheRemoved(String string) {
+    }
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListener.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,30 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.distribution.CacheManagerPeerListenerFactory;
+import net.sf.ehcache.distribution.CacheManagerPeerListener;
+import net.sf.ehcache.CacheManager;
+
+import java.util.Properties;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPCacheManagerPeerListenerFactory extends CacheManagerPeerListenerFactory {
+    
+    public CacheManagerPeerListener createCachePeerListener(CacheManager cacheManager, Properties properties) {
+        return null;
+    }
+
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerListenerFactory.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,48 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.distribution.CacheManagerPeerProvider;
+import net.sf.ehcache.Ehcache;
+import net.sf.ehcache.CacheException;
+
+import java.util.List;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPCacheManagerPeerProvider implements CacheManagerPeerProvider {
+    public void registerPeer(String string) {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public void unregisterPeer(String string) {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public List listRemoteCachePeers(Ehcache ehcache) throws CacheException {
+        return null;  //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public void init() {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public void dispose() throws CacheException {
+        //To change body of implemented methods use File | Settings | File Templates.
+    }
+
+    public long getTimeForClusterToForm() {
+        return 0;  //To change body of implemented methods use File | Settings | File Templates.
+    }
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProvider.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,31 @@
+/**
+ *
+ * Copyright 2006 The Apache Software Foundation
+ *
+ *  Licensed 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.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.distribution.CacheManagerPeerProviderFactory;
+import net.sf.ehcache.distribution.CacheManagerPeerProvider;
+import net.sf.ehcache.CacheManager;
+
+import java.util.Properties;
+
+public class TCPCacheManagerPeerProviderFactory extends CacheManagerPeerProviderFactory {
+
+    public CacheManagerPeerProvider createCachePeerProvider(CacheManager cacheManager, Properties properties) {
+        return null;
+    }
+    
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPCacheManagerPeerProviderFactory.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java?view=auto&rev=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java (added)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java Mon Sep 18 12:56:59 2006
@@ -0,0 +1,49 @@
+package org.apache.geronimo.gcache.server.listeners;
+
+import net.sf.ehcache.event.CacheEventListener;
+import net.sf.ehcache.Ehcache;
+import net.sf.ehcache.Element;
+import net.sf.ehcache.CacheException;
+
+/**
+ * Copyright 2006 The Apache Software Foundation
+ *
+ * Licensed 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.
+ */
+public class TCPSynchronousListener implements CacheEventListener {
+
+    public void notifyElementRemoved(Ehcache ehcache, Element element) throws CacheException {
+    }
+
+    public void notifyElementPut(Ehcache ehcache, Element element) throws CacheException {
+    }
+
+    public void notifyElementUpdated(Ehcache ehcache, Element element) throws CacheException {
+    }
+
+    public void notifyElementExpired(Ehcache ehcache, Element element) {
+    }
+
+    public void notifyElementEvicted(Ehcache ehcache, Element element) {
+    }
+
+    public void notifyRemoveAll(Ehcache ehcache) {
+    }
+
+    public void dispose() {
+    }
+
+    public Object clone() throws CloneNotSupportedException {
+        return null;
+    }
+}

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java
------------------------------------------------------------------------------
    svn:keywords = Date Revision

Propchange: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/listeners/TCPSynchronousListener.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Modified: geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/spi/ThreadPool.java
URL: http://svn.apache.org/viewvc/geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/spi/ThreadPool.java?view=diff&rev=447526&r1=447525&r2=447526
==============================================================================
--- geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/spi/ThreadPool.java (original)
+++ geronimo/sandbox/gcache/server/src/main/java/org/apache/geronimo/gcache/server/spi/ThreadPool.java Mon Sep 18 12:56:59 2006
@@ -1,14 +1,16 @@
 package org.apache.geronimo.gcache.server.spi;
 
 /**
- * Copyright 2006 The Apache Software Foundation
- * <p/>
- * Licensed 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/>
+ *
+ * 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
- * <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.