You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by kl...@apache.org on 2016/02/09 02:17:57 UTC

[1/4] incubator-geode git commit: GEODE-12: Switch to AvailablePortHelper for ephemeral ports

Repository: incubator-geode
Updated Branches:
  refs/heads/feature/GEODE-773-2 36c3ab4d7 -> 3504a05ff


GEODE-12: Switch to AvailablePortHelper for ephemeral ports


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/41192cc9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/41192cc9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/41192cc9

Branch: refs/heads/feature/GEODE-773-2
Commit: 41192cc93f9ba8138383e026b2f045935cb8658d
Parents: 0089b85
Author: Jens Deppe <jd...@pivotal.io>
Authored: Mon Feb 8 11:57:56 2016 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Feb 8 11:57:56 2016 -0800

----------------------------------------------------------------------
 extensions/gemfire-modules/build.gradle         |  1 +
 .../gemfire/modules/session/DualCacheTest.java  | 72 --------------------
 .../modules/session/TestSessionsBase.java       | 32 +++++----
 3 files changed, 19 insertions(+), 86 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/41192cc9/extensions/gemfire-modules/build.gradle
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules/build.gradle b/extensions/gemfire-modules/build.gradle
index 68197bf..cf22f2c 100644
--- a/extensions/gemfire-modules/build.gradle
+++ b/extensions/gemfire-modules/build.gradle
@@ -35,4 +35,5 @@ dependencies {
   testRuntime 'org.apache.tomcat:coyote:' + project.'tomcat6.version'
 
   provided project(path: ':gemfire-junit')
+  provided project(path: ':gemfire-core', configuration: 'testOutput')
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/41192cc9/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/DualCacheTest.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/DualCacheTest.java b/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/DualCacheTest.java
deleted file mode 100644
index dbe4b54..0000000
--- a/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/DualCacheTest.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/*
-* 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.
-*/
-/*
- * To change this template, choose Tools | Templates
- * and open the template in the editor.
- */
-
-package com.gemstone.gemfire.modules.session;
-
-import com.gemstone.gemfire.test.junit.categories.IntegrationTest;
-import com.meterware.httpunit.GetMethodWebRequest;
-import com.meterware.httpunit.WebConversation;
-import com.meterware.httpunit.WebRequest;
-import com.meterware.httpunit.WebResponse;
-import org.junit.Ignore;
-import org.junit.Test;
-import org.junit.experimental.categories.Category;
-
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertNotNull;
-import static org.junit.Assert.assertTrue;
-
-/**
- *
- */
-@Category(IntegrationTest.class)
-public class DualCacheTest {
-
-  /**
-   * Check that our session persists. The values we pass in as query params are used to set attributes on the session.
-   */
-  @Ignore("Ignored while refactoring")
-  @Test
-  public void testSessionFailover() throws Exception {
-    String key = "value_testSessionFailover";
-    String value = "Foo";
-
-    WebConversation wc = new WebConversation();
-    WebRequest req1 = new GetMethodWebRequest("http://localhost:7890/test");
-    req1.setParameter("cmd", QueryCommand.SET.name());
-    req1.setParameter("param", key);
-    req1.setParameter("value", value);
-    WebResponse response = wc.getResponse(req1);
-    String sessionId = response.getNewCookieValue("JSESSIONID");
-
-    assertNotNull("No apparent session cookie", sessionId);
-
-    WebRequest req2 = new GetMethodWebRequest("http://localhost:7891/test");
-    req2.setHeaderField("Cookie", "JSESSIONID=" + sessionId);
-    req2.setParameter("cmd", QueryCommand.GET.name());
-    req2.setParameter("param", key);
-    response = wc.getResponse(req2);
-    sessionId = response.getNewCookieValue("JSESSIONID");
-
-    assertEquals(value, response.getText());
-    assertTrue("The sessionId does not contain the correct JVM route value", sessionId.contains("JVM-2"));
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/41192cc9/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/TestSessionsBase.java
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/TestSessionsBase.java b/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/TestSessionsBase.java
index 4b7ab87..544658e 100644
--- a/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/TestSessionsBase.java
+++ b/extensions/gemfire-modules/src/test/java/com/gemstone/gemfire/modules/session/TestSessionsBase.java
@@ -17,6 +17,7 @@
 package com.gemstone.gemfire.modules.session;
 
 import com.gemstone.gemfire.cache.Region;
+import com.gemstone.gemfire.internal.AvailablePortHelper;
 import com.gemstone.gemfire.modules.session.catalina.DeltaSessionManager;
 import com.gemstone.gemfire.modules.session.catalina.PeerToPeerCacheLifecycleListener;
 import com.meterware.httpunit.GetMethodWebRequest;
@@ -49,9 +50,12 @@ public abstract class TestSessionsBase {
 
   private static DeltaSessionManager sessionManager;
 
+  private static int port;
+
   // Set up the servers we need
   public static void setupServer(DeltaSessionManager manager) throws Exception {
-    server = new EmbeddedTomcat("/test", 7890, "JVM-1");
+    port = AvailablePortHelper.getRandomAvailableTCPPort();
+    server = new EmbeddedTomcat("/test", port, "JVM-1");
 
     PeerToPeerCacheLifecycleListener p2pListener = new PeerToPeerCacheLifecycleListener();
     p2pListener.setProperty("mcast-port", "0");
@@ -91,7 +95,7 @@ public abstract class TestSessionsBase {
   @Test
   public void testSanity() throws Exception {
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
     req.setParameter("cmd", QueryCommand.GET.name());
     req.setParameter("param", "null");
     WebResponse response = wc.getResponse(req);
@@ -117,7 +121,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     req.setParameter("cmd", QueryCommand.CALLBACK.name());
     req.setParameter("param", "callback");
@@ -142,7 +146,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     req.setParameter("cmd", QueryCommand.CALLBACK.name());
     req.setParameter("param", "callback");
@@ -163,7 +167,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
     req.setParameter("cmd", QueryCommand.SET.name());
     req.setParameter("param", key);
     req.setParameter("value", value);
@@ -220,7 +224,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Set an attribute
     req.setParameter("cmd", QueryCommand.SET.name());
@@ -254,7 +258,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Set an attribute
     req.setParameter("cmd", QueryCommand.SET.name());
@@ -295,7 +299,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Set an attribute
     req.setParameter("cmd", QueryCommand.SET.name());
@@ -326,7 +330,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Set an attribute
     req.setParameter("cmd", QueryCommand.SET.name());
@@ -347,7 +351,7 @@ public abstract class TestSessionsBase {
     String value = "Foo";
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Set an attribute
     req.setParameter("cmd", QueryCommand.SET.name());
@@ -384,7 +388,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Execute the callback
     req.setParameter("cmd", QueryCommand.CALLBACK.name());
@@ -412,7 +416,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Execute the callback
     req.setParameter("cmd", QueryCommand.CALLBACK.name());
@@ -437,7 +441,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Execute the callback
     req.setParameter("cmd", QueryCommand.CALLBACK.name());
@@ -472,7 +476,7 @@ public abstract class TestSessionsBase {
     servlet.getServletContext().setAttribute("callback", c);
 
     WebConversation wc = new WebConversation();
-    WebRequest req = new GetMethodWebRequest("http://localhost:7890/test");
+    WebRequest req = new GetMethodWebRequest(String.format("http://localhost:%d/test", port));
 
     // Execute the callback
     req.setParameter("cmd", QueryCommand.CALLBACK.name());


[3/4] incubator-geode git commit: Merge remote-tracking branch 'origin/develop' into feature/GEODE-773-2

Posted by kl...@apache.org.
Merge remote-tracking branch 'origin/develop' into feature/GEODE-773-2


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/474d28de
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/474d28de
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/474d28de

Branch: refs/heads/feature/GEODE-773-2
Commit: 474d28de4a70ff1af2105d30b8062ea520e59775
Parents: 36c3ab4 c8c26e6
Author: Kirk Lund <kl...@pivotal.io>
Authored: Mon Feb 8 13:59:07 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Feb 8 13:59:07 2016 -0800

----------------------------------------------------------------------
 extensions/gemfire-modules-tomcat7/build.gradle |  1 +
 extensions/gemfire-modules/build.gradle         |  1 +
 .../gemfire/modules/session/DualCacheTest.java  | 72 --------------------
 .../modules/session/TestSessionsBase.java       | 32 +++++----
 4 files changed, 20 insertions(+), 86 deletions(-)
----------------------------------------------------------------------



[2/4] incubator-geode git commit: GEODE-14: Fix broken build for gemfire-modules-tomcat7

Posted by kl...@apache.org.
GEODE-14: Fix broken build for gemfire-modules-tomcat7


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/c8c26e61
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/c8c26e61
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/c8c26e61

Branch: refs/heads/feature/GEODE-773-2
Commit: c8c26e610e1c691628a2226bc66f77248a4b3284
Parents: 41192cc
Author: Jens Deppe <jd...@pivotal.io>
Authored: Mon Feb 8 12:49:01 2016 -0800
Committer: Jens Deppe <jd...@pivotal.io>
Committed: Mon Feb 8 12:49:01 2016 -0800

----------------------------------------------------------------------
 extensions/gemfire-modules-tomcat7/build.gradle | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/c8c26e61/extensions/gemfire-modules-tomcat7/build.gradle
----------------------------------------------------------------------
diff --git a/extensions/gemfire-modules-tomcat7/build.gradle b/extensions/gemfire-modules-tomcat7/build.gradle
index 5a4c28e..9d2219d 100644
--- a/extensions/gemfire-modules-tomcat7/build.gradle
+++ b/extensions/gemfire-modules-tomcat7/build.gradle
@@ -50,4 +50,5 @@ dependencies {
     exclude group: 'org.apache.tomcat', module: 'juli'
   }
   provided project(path: ':gemfire-junit')
+  provided project(path: ':gemfire-core', configuration: 'testOutput')
 }
\ No newline at end of file


[4/4] incubator-geode git commit: Fixup

Posted by kl...@apache.org.
Fixup


Project: http://git-wip-us.apache.org/repos/asf/incubator-geode/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-geode/commit/3504a05f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-geode/tree/3504a05f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-geode/diff/3504a05f

Branch: refs/heads/feature/GEODE-773-2
Commit: 3504a05ffc28566326f32c53a9ecacedd8e96ef5
Parents: 474d28d
Author: Kirk Lund <kl...@pivotal.io>
Authored: Mon Feb 8 14:46:36 2016 -0800
Committer: Kirk Lund <kl...@pivotal.io>
Committed: Mon Feb 8 14:46:36 2016 -0800

----------------------------------------------------------------------
 .../cache/ClientServerTransactionDUnitTest.java | 64 +++++++++++++-------
 1 file changed, 43 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/3504a05f/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
----------------------------------------------------------------------
diff --git a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
index 85f9e01..add43a0 100644
--- a/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
+++ b/gemfire-core/src/test/java/com/gemstone/gemfire/internal/cache/ClientServerTransactionDUnitTest.java
@@ -16,8 +16,9 @@
  */
 package com.gemstone.gemfire.internal.cache;
 
+import static com.gemstone.gemfire.test.dunit.LogWriterUtils.*;
+
 import java.util.ArrayList;
-import java.util.Arrays;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Iterator;
@@ -31,16 +32,38 @@ import java.util.concurrent.TimeUnit;
 import javax.naming.Context;
 import javax.transaction.UserTransaction;
 
-import com.gemstone.gemfire.LogWriter;
-import com.gemstone.gemfire.cache.*;
-import org.junit.Ignore;
-
+import com.gemstone.gemfire.cache.AttributesFactory;
+import com.gemstone.gemfire.cache.Cache;
+import com.gemstone.gemfire.cache.CacheFactory;
+import com.gemstone.gemfire.cache.CacheListener;
+import com.gemstone.gemfire.cache.CacheLoader;
+import com.gemstone.gemfire.cache.CacheLoaderException;
+import com.gemstone.gemfire.cache.CacheTransactionManager;
+import com.gemstone.gemfire.cache.CacheWriterException;
+import com.gemstone.gemfire.cache.CommitConflictException;
+import com.gemstone.gemfire.cache.DataPolicy;
+import com.gemstone.gemfire.cache.EntryEvent;
+import com.gemstone.gemfire.cache.InterestPolicy;
+import com.gemstone.gemfire.cache.LoaderHelper;
+import com.gemstone.gemfire.cache.Region;
 import com.gemstone.gemfire.cache.Region.Entry;
+import com.gemstone.gemfire.cache.RegionFactory;
+import com.gemstone.gemfire.cache.RegionShortcut;
+import com.gemstone.gemfire.cache.Scope;
+import com.gemstone.gemfire.cache.SubscriptionAttributes;
+import com.gemstone.gemfire.cache.TransactionDataNodeHasDepartedException;
+import com.gemstone.gemfire.cache.TransactionDataNotColocatedException;
+import com.gemstone.gemfire.cache.TransactionEvent;
+import com.gemstone.gemfire.cache.TransactionException;
+import com.gemstone.gemfire.cache.TransactionId;
+import com.gemstone.gemfire.cache.TransactionInDoubtException;
+import com.gemstone.gemfire.cache.TransactionWriter;
+import com.gemstone.gemfire.cache.TransactionWriterException;
+import com.gemstone.gemfire.cache.UnsupportedOperationInTransactionException;
 import com.gemstone.gemfire.cache.client.ClientCache;
 import com.gemstone.gemfire.cache.client.ClientCacheFactory;
 import com.gemstone.gemfire.cache.client.ClientRegionFactory;
 import com.gemstone.gemfire.cache.client.ClientRegionShortcut;
-import com.gemstone.gemfire.cache.client.Pool;
 import com.gemstone.gemfire.cache.client.PoolFactory;
 import com.gemstone.gemfire.cache.client.PoolManager;
 import com.gemstone.gemfire.cache.execute.Execution;
@@ -67,7 +90,6 @@ import com.gemstone.gemfire.internal.cache.execute.util.RollbackFunction;
 import com.gemstone.gemfire.internal.cache.tx.ClientTXStateStub;
 import com.gemstone.gemfire.test.dunit.Host;
 import com.gemstone.gemfire.test.dunit.IgnoredException;
-import com.gemstone.gemfire.test.dunit.LogWriterUtils;
 import com.gemstone.gemfire.test.dunit.SerializableCallable;
 import com.gemstone.gemfire.test.dunit.SerializableRunnable;
 import com.gemstone.gemfire.test.dunit.VM;
@@ -171,7 +193,7 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
         ClientCacheFactory ccf = new ClientCacheFactory();
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         // these settings were used to manually check that tx operation stats were being updated
         //ccf.set(DistributionConfig.STATISTIC_SAMPLING_ENABLED_NAME, "true");
         //ccf.set(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME, "clientStats.gfs");
@@ -231,7 +253,7 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
     ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
     ccf.setPoolSubscriptionEnabled(false);
 
-    ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+    ccf.set("log-level", getDUnitLogLevel());
 
     ClientCache cCache = getClientCache(ccf);
     
@@ -302,7 +324,7 @@ public class ClientServerTransactionDUnitTest extends RemoteTransactionDUnitTest
     ClientCacheFactory ccf = new ClientCacheFactory();
     ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
     ccf.setPoolSubscriptionEnabled(false);
-    ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+    ccf.set("log-level", getDUnitLogLevel());
     ClientCache cCache = getClientCache(ccf);
     ClientRegionFactory<CustId, Customer> custrf = cCache
       .createClientRegionFactory(cachingProxy ? ClientRegionShortcut.CACHING_PROXY : ClientRegionShortcut.PROXY);
@@ -1337,7 +1359,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ClientCacheFactory ccf = new ClientCacheFactory();
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.PROXY);
@@ -1433,7 +1455,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost", port2);
         ccf.setPoolLoadConditioningInterval(1);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.PROXY);
@@ -1550,7 +1572,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         if (port2 != 0) ccf.addPoolServer("localhost", port2);
         if (port3 != 0) ccf.addPoolServer("localhost", port3);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(cachingProxy ? ClientRegionShortcut.CACHING_PROXY : ClientRegionShortcut.PROXY);
@@ -2062,7 +2084,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost", port2);
         ccf.setPoolSubscriptionEnabled(false);
         ccf.setPoolLoadConditioningInterval(1);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.PROXY);
@@ -2455,7 +2477,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.setPoolMinConnections(5);
         ccf.setPoolLoadConditioningInterval(-1);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         Region r1 = cCache.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create("r1");
         Region r2 = cCache.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create("r2");
@@ -2688,7 +2710,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
           ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port);
           ccf.addPoolServer("localhost", port2);
           ccf.setPoolSubscriptionEnabled(false);
-          ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+          ccf.set("log-level", getDUnitLogLevel());
           // these settings were used to manually check that tx operation stats were being updated
           //ccf.set(DistributionConfig.STATISTIC_SAMPLING_ENABLED_NAME, "true");
           //ccf.set(DistributionConfig.STATISTIC_ARCHIVE_FILE_NAME, "clientStats.gfs");
@@ -2990,7 +3012,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
         if (port2 != 0) ccf.addPoolServer("localhost", port2);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY);
@@ -3131,7 +3153,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost", port2);
         ccf.setPoolMinConnections(0);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY);
@@ -3219,7 +3241,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
         ccf.setPoolMinConnections(0);
         ccf.setPoolSubscriptionEnabled(false);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         ClientRegionFactory<CustId, Customer> custrf = cCache
             .createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY);
@@ -3309,7 +3331,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.setPoolMinConnections(0);
         ccf.setPoolSubscriptionEnabled(true);
         ccf.setPoolSubscriptionRedundancy(0);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         Region r = cCache.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).addCacheListener(new ClientListener()).create(regionName);
         r.registerInterestRegex(".*");
@@ -3325,7 +3347,7 @@ public void testClientCommitAndDataStoreGetsEvent() throws Exception {
         ccf.addPoolServer("localhost"/*getServerHostName(Host.getHost(0))*/, port1);
         ccf.setPoolMinConnections(0);
         ccf.setPoolSubscriptionEnabled(true);
-        ccf.set("log-level", LogWriterUtils.getDUnitLogLevel());
+        ccf.set("log-level", getDUnitLogLevel());
         ClientCache cCache = getClientCache(ccf);
         Region r = cCache.createClientRegionFactory(ClientRegionShortcut.CACHING_PROXY).create(regionName);
         getCache().getCacheTransactionManager().begin();