You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cxf.apache.org by am...@apache.org on 2013/07/04 11:17:33 UTC

svn commit: r1499700 - in /cxf/dosgi/trunk: discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/ discovery/distri...

Author: amichai
Date: Thu Jul  4 09:17:33 2013
New Revision: 1499700

URL: http://svn.apache.org/r1499700
Log:
Standardize ZooKeeper variable and log naming

Modified:
    cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ZooKeeperDiscovery.java
    cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListener.java
    cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListenerFactory.java
    cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitor.java
    cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitorManager.java
    cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/pom.xml
    cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/config/Activator.java
    cxf/dosgi/trunk/discovery/distributed/zookeeper-server/pom.xml
    cxf/dosgi/trunk/discovery/distributed/zookeeper-server/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/ZookeeperStarter.java
    cxf/dosgi/trunk/systests2/multi-bundle/src/test/java/org/apache/cxf/dosgi/systests2/multi/TestDiscoveryExport.java

Modified: cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ZooKeeperDiscovery.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ZooKeeperDiscovery.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ZooKeeperDiscovery.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/ZooKeeperDiscovery.java Thu Jul  4 09:17:33 2013
@@ -47,7 +47,7 @@ public class ZooKeeperDiscovery implemen
     private PublishingEndpointListenerFactory endpointListenerFactory;
     private ServiceTracker endpointListenerTracker;
     private InterfaceMonitorManager imManager;
-    private ZooKeeper zooKeeper;
+    private ZooKeeper zk;
     private boolean closed;
 
     @SuppressWarnings("rawtypes")
@@ -76,9 +76,9 @@ public class ZooKeeperDiscovery implemen
             return;
         }
         LOG.debug("starting ZookeeperDiscovery");
-        endpointListenerFactory = new PublishingEndpointListenerFactory(zooKeeper, bctx);
+        endpointListenerFactory = new PublishingEndpointListenerFactory(zk, bctx);
         endpointListenerFactory.start();
-        imManager = new InterfaceMonitorManager(bctx, zooKeeper);
+        imManager = new InterfaceMonitorManager(bctx, zk);
         EndpointListenerTrackerCustomizer customizer = new EndpointListenerTrackerCustomizer(imManager);
         endpointListenerTracker = new ServiceTracker(bctx, EndpointListener.class.getName(), customizer);
         endpointListenerTracker.open();
@@ -96,11 +96,11 @@ public class ZooKeeperDiscovery implemen
         if (imManager != null) {
             imManager.close();
         }
-        if (zooKeeper != null) {
+        if (zk != null) {
             try {
-                zooKeeper.close();
+                zk.close();
             } catch (InterruptedException e) {
-                LOG.error("Error closing zookeeper", e);
+                LOG.error("Error closing ZooKeeper", e);
             }
         }
     }
@@ -116,7 +116,7 @@ public class ZooKeeperDiscovery implemen
         LOG.debug("ZooKeeper configuration: connecting to {}:{} with timeout {}",
                 new Object[]{host, port, timeout});
         try {
-            zooKeeper = new ZooKeeper(host + ":" + port, timeout, this);
+            zk = new ZooKeeper(host + ":" + port, timeout, this);
         } catch (IOException e) {
             LOG.error("Failed to start the Zookeeper Discovery component.", e);
         }
@@ -126,12 +126,12 @@ public class ZooKeeperDiscovery implemen
     public void process(WatchedEvent event) {
         switch (event.getState()) {
         case SyncConnected:
-            LOG.info("Connection to zookeeper established");
+            LOG.info("Connection to ZooKeeper established");
             start();
             break;
 
         case Expired:
-            LOG.info("Connection to zookeeper expired. Trying to create a new connection");
+            LOG.info("Connection to ZooKeeper expired. Trying to create a new connection");
             stop(false);
             createZooKeeper(curConfiguration);
             break;

Modified: cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListener.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListener.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListener.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListener.java Thu Jul  4 09:17:33 2013
@@ -45,19 +45,19 @@ import static org.apache.zookeeper.Keepe
 import static org.apache.zookeeper.KeeperException.NodeExistsException;
 
 /**
- * Listens for local Endpoints and publishes them to Zookeeper
+ * Listens for local Endpoints and publishes them to ZooKeeper.
  */
 public class PublishingEndpointListener implements EndpointListener {
 
     private static final Logger LOG = LoggerFactory.getLogger(PublishingEndpointListener.class);
 
-    private final ZooKeeper zookeeper;
+    private final ZooKeeper zk;
     private final ServiceTracker discoveryPluginTracker;
     private final List<EndpointDescription> endpoints = new ArrayList<EndpointDescription>();
     private boolean closed;
 
-    public PublishingEndpointListener(ZooKeeper zooKeeper, BundleContext bctx) {
-        this.zookeeper = zooKeeper;
+    public PublishingEndpointListener(ZooKeeper zk, BundleContext bctx) {
+        this.zk = zk;
         discoveryPluginTracker = new ServiceTracker(bctx, DiscoveryPlugin.class.getName(), null);
         discoveryPluginTracker.open();
     }
@@ -103,14 +103,14 @@ public class PublishingEndpointListener 
             String path = Utils.getZooKeeperPath(name);
             String fullPath = path + '/' + endpointKey;
             LOG.debug("Creating ZooKeeper node: {}", fullPath);
-            ensurePath(path, zookeeper);
+            ensurePath(path, zk);
             createEphemeralNode(fullPath, getData(props));
         }
     }
 
     private void createEphemeralNode(String fullPath, byte[] data) throws KeeperException, InterruptedException {
         try {
-            zookeeper.create(fullPath, data, Ids.OPEN_ACL_UNSAFE, CreateMode.EPHEMERAL);
+            zk.create(fullPath, data, Ids.OPEN_ACL_UNSAFE, CreateMode.EPHEMERAL);
         } catch (NodeExistsException nee) {
             // this sometimes happens after a ZooKeeper node dies and the ephemeral node
             // that belonged to the old session was not yet deleted. We need to make our
@@ -118,11 +118,11 @@ public class PublishingEndpointListener 
             // we do this by deleting and recreating it ourselves.
             LOG.info("node for endpoint already exists, recreating: {}", fullPath);
             try {
-                zookeeper.delete(fullPath, -1);
+                zk.delete(fullPath, -1);
             } catch (NoNodeException nne) {
                 // it's a race condition, but as long as it got deleted - it's ok
             }
-            zookeeper.create(fullPath, data, Ids.OPEN_ACL_UNSAFE, CreateMode.EPHEMERAL);
+            zk.create(fullPath, data, Ids.OPEN_ACL_UNSAFE, CreateMode.EPHEMERAL);
         }
     }
 
@@ -155,7 +155,7 @@ public class PublishingEndpointListener 
             String fullPath = path + '/' + endpointKey;
             LOG.debug("Removing ZooKeeper node: {}", fullPath);
             try {
-                zookeeper.delete(fullPath, -1);
+                zk.delete(fullPath, -1);
             } catch (Exception e) {
                 LOG.debug("Error while removing endpoint");
             }

Modified: cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListenerFactory.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListenerFactory.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListenerFactory.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/publish/PublishingEndpointListenerFactory.java Thu Jul  4 09:17:33 2013
@@ -37,26 +37,26 @@ import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
 /**
- * Creates local EndpointListeners that publish to Zookeeper.
+ * Creates local EndpointListeners that publish to ZooKeeper.
  */
 public class PublishingEndpointListenerFactory implements ServiceFactory {
 
     private static final Logger LOG = LoggerFactory.getLogger(PublishingEndpointListenerFactory.class);
 
     private final BundleContext bctx;
-    private final ZooKeeper zookeeper;
+    private final ZooKeeper zk;
     private final List<PublishingEndpointListener> listeners = new ArrayList<PublishingEndpointListener>();
     private ServiceRegistration serviceRegistration;
 
-    public PublishingEndpointListenerFactory(ZooKeeper zooKeeper, BundleContext bctx) {
+    public PublishingEndpointListenerFactory(ZooKeeper zk, BundleContext bctx) {
         this.bctx = bctx;
-        this.zookeeper = zooKeeper;
+        this.zk = zk;
     }
 
     public Object getService(Bundle b, ServiceRegistration sr) {
         LOG.debug("new EndpointListener from factory");
         synchronized (listeners) {
-            PublishingEndpointListener epl = new PublishingEndpointListener(zookeeper, bctx);
+            PublishingEndpointListener epl = new PublishingEndpointListener(zk, bctx);
             listeners.add(epl);
             return epl;
         }

Modified: cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitor.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitor.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitor.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitor.java Thu Jul  4 09:17:33 2013
@@ -53,7 +53,7 @@ public class InterfaceMonitor implements
     private static final Logger LOG = LoggerFactory.getLogger(InterfaceMonitor.class);
 
     private final String znode;
-    private final ZooKeeper zookeeper;
+    private final ZooKeeper zk;
     private final EndpointListener endpointListener;
     private final boolean recursive;
     private volatile boolean closed;
@@ -62,7 +62,7 @@ public class InterfaceMonitor implements
     private Map<String, EndpointDescription> nodes = new HashMap<String, EndpointDescription>();
 
     public InterfaceMonitor(ZooKeeper zk, String objClass, EndpointListener endpointListener, String scope) {
-        this.zookeeper = zk;
+        this.zk = zk;
         this.znode = Utils.getZooKeeperPath(objClass);
         this.recursive = objClass == null || objClass.isEmpty();
         this.endpointListener = endpointListener;
@@ -84,8 +84,8 @@ public class InterfaceMonitor implements
     }
 
     private void watch() {
-        LOG.debug("registering a zookeeper.exists({}) callback", znode);
-        zookeeper.exists(znode, this, this, null);
+        LOG.debug("registering a ZooKeeper.exists({}) callback", znode);
+        zk.exists(znode, this, this, null);
     }
 
     /**
@@ -124,14 +124,14 @@ public class InterfaceMonitor implements
             return;
         }
 
-        if (zookeeper.getState() != ZooKeeper.States.CONNECTED) {
-            LOG.info("zookeeper connection was already closed! Not processing changed event.");
+        if (zk.getState() != ZooKeeper.States.CONNECTED) {
+            LOG.info("ZooKeeper connection was already closed! Not processing changed event.");
             return;
         }
 
         try {
-            if (zookeeper.exists(znode, false) != null) {
-                zookeeper.getChildren(znode, this);
+            if (zk.exists(znode, false) != null) {
+                zk.getChildren(znode, this);
                 refreshNodes();
             } else {
                 LOG.debug("znode {} doesn't exist -> not processing any changes", znode);
@@ -180,7 +180,7 @@ public class InterfaceMonitor implements
         List<String> children;
         try {
             LOG.debug("Processing the children of {}", zn);
-            children = zookeeper.getChildren(zn, false);
+            children = zk.getChildren(zn, false);
 
             boolean foundANode = false;
             for (String child : children) {
@@ -202,15 +202,15 @@ public class InterfaceMonitor implements
                     }
                 }
                 if (recursive && processChildren(childZNode, newNodes, prevNodes)) {
-                    zookeeper.getChildren(childZNode, this);
+                    zk.getChildren(childZNode, this);
                 }
             }
 
             return foundANode;
         } catch (KeeperException e) {
-            LOG.error("Problem processing Zookeeper node", e);
+            LOG.error("Problem processing ZooKeeper node", e);
         } catch (InterruptedException e) {
-            LOG.error("Problem processing Zookeeper node", e);
+            LOG.error("Problem processing ZooKeeper node", e);
         }
         return false;
     }
@@ -223,11 +223,11 @@ public class InterfaceMonitor implements
      */
     private EndpointDescription getEndpointDescriptionFromNode(String node) {
         try {
-            Stat s = zookeeper.exists(node, false);
-            if (s == null || s.getDataLength() <= 0) {
+            Stat stat = zk.exists(node, false);
+            if (stat == null || stat.getDataLength() <= 0) {
                 return null;
             }
-            byte[] data = zookeeper.getData(node, false, null);
+            byte[] data = zk.getData(node, false, null);
             LOG.debug("Got data for node: {}", node);
 
             EndpointDescription endpoint = EndpointUtils.getFirstEnpointDescription(data);

Modified: cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitorManager.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitorManager.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitorManager.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/cxf-discovery/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/subscribe/InterfaceMonitorManager.java Thu Jul  4 09:17:33 2013
@@ -48,7 +48,7 @@ public class InterfaceMonitorManager {
     private static final Logger LOG = LoggerFactory.getLogger(InterfaceMonitorManager.class);
 
     private final BundleContext bctx;
-    private final ZooKeeper zooKeeper;
+    private final ZooKeeper zk;
     // map of EndpointListeners and the scopes they are interested in
     private final Map<ServiceReference, List<String>> endpointListenerScopes =
             new HashMap<ServiceReference, List<String>>();
@@ -60,9 +60,9 @@ public class InterfaceMonitorManager {
         InterfaceMonitor monitor;
     }
 
-    public InterfaceMonitorManager(BundleContext bctx, ZooKeeper zooKeeper) {
+    public InterfaceMonitorManager(BundleContext bctx, ZooKeeper zk) {
         this.bctx = bctx;
-        this.zooKeeper = zooKeeper;
+        this.zk = zk;
     }
 
     public void addInterest(ServiceReference endpointListener) {
@@ -137,7 +137,7 @@ public class InterfaceMonitorManager {
                 notifyListeners(endpoint, scope, true, interest.endpointListeners);
             }
         };
-        return new InterfaceMonitor(zooKeeper, objClass, endpointListener, scope);
+        return new InterfaceMonitor(zk, objClass, endpointListener, scope);
     }
 
     private void notifyListeners(EndpointDescription endpoint, String currentScope, boolean isAdded,

Modified: cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/pom.xml
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/pom.xml?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/pom.xml (original)
+++ cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/pom.xml Thu Jul  4 09:17:33 2013
@@ -23,7 +23,7 @@
     <groupId>org.apache.cxf.dosgi</groupId>
     <artifactId>cxf-dosgi-ri-discovery-distributed-zookeeper-server-config</artifactId>
     <packaging>bundle</packaging>
-    <name>Distributed OSGI Distributed Discovery Zookeeper Server Control Configuration Bundle</name>
+    <name>Distributed OSGI Distributed Discovery ZooKeeper Server Control Configuration Bundle</name>
     <description>This bundle provides some default OSGi Configuration Admin data and is only useful for use in the OSGi CT suite</description>
     <version>1.6-SNAPSHOT</version>
 

Modified: cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/config/Activator.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/config/Activator.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/config/Activator.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/zookeeper-server-config/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/config/Activator.java Thu Jul  4 09:17:33 2013
@@ -46,7 +46,7 @@ public class Activator implements Bundle
             if (System.getProperty(ZOOKEEPER_PORT) == null) {
                 String port = getFreePort();
                 System.setProperty(ZOOKEEPER_PORT, port);
-                LOG.info("Global zookeeper port: {}", port);
+                LOG.info("Global ZooKeeper port: {}", port);
             }
         }
 
@@ -62,9 +62,9 @@ public class Activator implements Bundle
                         String zp = System.getProperty(ZOOKEEPER_PORT);
                         props.put("clientPort", zp);
                         cfg.update(props);
-                        LOG.debug("Set zookeeper client port to {}", zp);
+                        LOG.debug("Set ZooKeeper client port to {}", zp);
                     } catch (IOException e) {
-                        LOG.error("Failed to configure zookeeper server!", e);
+                        LOG.error("Failed to configure ZooKeeper server!", e);
                     }
                 }
                 return svc;
@@ -76,7 +76,7 @@ public class Activator implements Bundle
         ServiceReference[] refs = context.getServiceReferences(ManagedService.class.getName(),
                 "(service.pid=org.apache.cxf.dosgi.discovery.zookeeper)");
         if (refs == null || refs.length == 0) {
-            throw new RuntimeException("This bundle must be started after the bundle with the Zookeeper "
+            throw new RuntimeException("This bundle must be started after the bundle with the ZooKeeper "
                                        + "Discovery Managed Service was started.");
         }
 
@@ -92,7 +92,7 @@ public class Activator implements Bundle
                 context.ungetService(refs[0]);
             }
         }
-        LOG.debug("Passed the zookeeper.host property to the Zookeeper Client managed service.");
+        LOG.debug("Passed the zookeeper.host property to the ZooKeeper Client managed service.");
     }
 
     private String getFreePort() {

Modified: cxf/dosgi/trunk/discovery/distributed/zookeeper-server/pom.xml
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/zookeeper-server/pom.xml?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/zookeeper-server/pom.xml (original)
+++ cxf/dosgi/trunk/discovery/distributed/zookeeper-server/pom.xml Thu Jul  4 09:17:33 2013
@@ -22,7 +22,7 @@
     <modelVersion>4.0.0</modelVersion>
     <artifactId>cxf-dosgi-ri-discovery-distributed-zookeeper-server</artifactId>
     <packaging>bundle</packaging>
-    <name>Distributed OSGI Distributed Discovery Zookeeper Server Control Bundle</name>
+    <name>Distributed OSGI Distributed Discovery ZooKeeper Server Control Bundle</name>
 
     <parent>
       <groupId>org.apache.cxf.dosgi</groupId>
@@ -61,7 +61,7 @@
             </exclusions>
         </dependency>
 
-        <!--  We need the newer log4j as the one from zookeeper has some ugly dependencies -->
+        <!--  We need the newer log4j as the one from ZooKeeper has some ugly dependencies -->
         <dependency>
             <groupId>log4j</groupId>
             <artifactId>log4j</artifactId>

Modified: cxf/dosgi/trunk/discovery/distributed/zookeeper-server/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/ZookeeperStarter.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/discovery/distributed/zookeeper-server/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/ZookeeperStarter.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/discovery/distributed/zookeeper-server/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/ZookeeperStarter.java (original)
+++ cxf/dosgi/trunk/discovery/distributed/zookeeper-server/src/main/java/org/apache/cxf/dosgi/discovery/zookeeper/server/ZookeeperStarter.java Thu Jul  4 09:17:33 2013
@@ -150,7 +150,7 @@ public class ZookeeperStarter implements
             try {
                 super.shutdown();
             } catch (Exception e) {
-                LOG.error("Error shutting down zookeeper", e);
+                LOG.error("Error shutting down ZooKeeper", e);
             }
         }
     }

Modified: cxf/dosgi/trunk/systests2/multi-bundle/src/test/java/org/apache/cxf/dosgi/systests2/multi/TestDiscoveryExport.java
URL: http://svn.apache.org/viewvc/cxf/dosgi/trunk/systests2/multi-bundle/src/test/java/org/apache/cxf/dosgi/systests2/multi/TestDiscoveryExport.java?rev=1499700&r1=1499699&r2=1499700&view=diff
==============================================================================
--- cxf/dosgi/trunk/systests2/multi-bundle/src/test/java/org/apache/cxf/dosgi/systests2/multi/TestDiscoveryExport.java (original)
+++ cxf/dosgi/trunk/systests2/multi-bundle/src/test/java/org/apache/cxf/dosgi/systests2/multi/TestDiscoveryExport.java Thu Jul  4 09:17:33 2013
@@ -97,7 +97,7 @@ public class TestDiscoveryExport extends
                 // Ignore
             }
         }
-        Assert.assertNotNull("Zookeeper node " + zNode + " was not found", stat);
+        Assert.assertNotNull("ZooKeeper node " + zNode + " was not found", stat);
     }
 
     protected static InputStream getClientBundle() {
@@ -121,7 +121,7 @@ public class TestDiscoveryExport extends
     }
 
     protected void configureZookeeper(ConfigurationAdmin ca, int zkPort) throws IOException {
-        System.out.println("*** Port for Zookeeper Server: " + zkPort);
+        System.out.println("*** Port for ZooKeeper Server: " + zkPort);
         updateZkServerConfig(zkPort, ca);
         updateZkClientConfig(zkPort, ca);
     }