You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@whirr.apache.org by to...@apache.org on 2011/03/04 00:01:04 UTC

svn commit: r1076869 - in /incubator/whirr/trunk: ./ core/src/main/java/ core/src/main/java/org/apache/whirr/cluster/actions/ core/src/main/java/org/apache/whirr/net/ core/src/main/java/org/apache/whirr/service/ core/src/main/java/org/apache/whirr/serv...

Author: tomwhite
Date: Thu Mar  3 23:01:03 2011
New Revision: 1076869

URL: http://svn.apache.org/viewvc?rev=1076869&view=rev
Log:
WHIRR-244. Add package-level javadoc.

Added:
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java   (with props)
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java   (with props)
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java   (with props)
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java   (with props)
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java   (with props)
    incubator/whirr/trunk/core/src/main/javadoc/
    incubator/whirr/trunk/core/src/main/javadoc/overview.html   (with props)
Removed:
    incubator/whirr/trunk/core/src/main/java/overview.html
Modified:
    incubator/whirr/trunk/CHANGES.txt
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/BootstrapClusterAction.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/DnsUtil.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionEvent.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionHandlerSupport.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterSpec.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/RolePredicates.java
    incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ServiceFactory.java
    incubator/whirr/trunk/core/src/test/java/org/apache/whirr/cluster/actions/BootstrapClusterActionTest.java
    incubator/whirr/trunk/core/src/test/java/org/apache/whirr/service/ClusterSpecTest.java
    incubator/whirr/trunk/services/hadoop/src/main/java/org/apache/whirr/service/hadoop/HadoopDataNodeClusterActionHandler.java

Modified: incubator/whirr/trunk/CHANGES.txt
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/CHANGES.txt?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/CHANGES.txt (original)
+++ incubator/whirr/trunk/CHANGES.txt Thu Mar  3 23:01:03 2011
@@ -2,6 +2,14 @@ Apache Whirr Change Log
 
 Trunk (unreleased changes)
 
+  NEW FEATURES
+
+  IMPROVEMENTS
+
+    WHIRR-244. Add package-level javadoc. (tomwhite)
+
+  BUG FIXES
+
 Release 0.4.0 - 2011-02-28
 
   NEW FEATURES

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/BootstrapClusterAction.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/BootstrapClusterAction.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/BootstrapClusterAction.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/BootstrapClusterAction.java Thu Mar  3 23:01:03 2011
@@ -56,7 +56,6 @@ import org.jclouds.compute.RunNodesExcep
 import org.jclouds.compute.domain.NodeMetadata;
 import org.jclouds.compute.domain.Template;
 import org.jclouds.compute.domain.TemplateBuilder;
-import org.jclouds.io.Payload;
 import org.jclouds.scriptbuilder.domain.AuthorizeRSAPublicKey;
 import org.jclouds.scriptbuilder.domain.InstallRSAPrivateKey;
 import org.jclouds.scriptbuilder.domain.OsFamily;
@@ -348,7 +347,7 @@ class NodeStarter implements Callable<Se
     LOG.info("Starting {} node(s) with roles {}", num,
         roles);
     Set<NodeMetadata> nodes = (Set<NodeMetadata>)computeService
-    	.createNodesInGroup(clusterName, num, template);
+      .createNodesInGroup(clusterName, num, template);
     LOG.info("Nodes started: {}", nodes);
     return nodes;
   }

Added: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java (added)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java Thu Mar  3 23:01:03 2011
@@ -0,0 +1,24 @@
+/*
+ * 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.
+ * 
+ */ 
+/** 
+ * <p>
+ * A collection of {@link org.apache.whirr.service.ClusterAction} implementations.
+ * </p> 
+ */
+package org.apache.whirr.cluster.actions;

Propchange: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/cluster/actions/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/DnsUtil.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/DnsUtil.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/DnsUtil.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/DnsUtil.java Thu Mar  3 23:01:03 2011
@@ -30,13 +30,16 @@ import org.xbill.DNS.ReverseMap;
 import org.xbill.DNS.Section;
 import org.xbill.DNS.Type;
 
+/**
+ * Utility functions for DNS.
+ */
 public class DnsUtil {
 
   /**
    * resolve the reverse dns name for the given IP address
    * 
    * @param hostIp
-   * @return
+   * @return The resolved DNS name.
    * @throws IOException
    */
   public static String resolveAddress(String hostIp) throws IOException {

Added: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java (added)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java Thu Mar  3 23:01:03 2011
@@ -0,0 +1,24 @@
+/*
+ * 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.
+ * 
+ */ 
+/** 
+ * <p>
+ * Network-related classes.
+ * </p> 
+ */
+package org.apache.whirr.net;

Propchange: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/net/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionEvent.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionEvent.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionEvent.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionEvent.java Thu Mar  3 23:01:03 2011
@@ -21,6 +21,9 @@ package org.apache.whirr.service;
 import org.apache.whirr.service.jclouds.StatementBuilder;
 import org.apache.whirr.service.jclouds.TemplateBuilderStrategy;
 
+/**
+ * An event object which is fired when a {@link ClusterAction} occurs. 
+ */
 public class ClusterActionEvent {
   
   private String action;

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionHandlerSupport.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionHandlerSupport.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionHandlerSupport.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterActionHandlerSupport.java Thu Mar  3 23:01:03 2011
@@ -23,6 +23,11 @@ import java.io.IOException;
 import org.apache.whirr.service.jclouds.RunUrlStatement;
 import org.jclouds.scriptbuilder.domain.Statement;
 
+/**
+ * This is a utility class to make it easier to implement
+ * {@link ClusterActionHandler}. For each 'before' and 'after' action type there
+ * is a corresponding method that implementations may override.
+ */
 public abstract class ClusterActionHandlerSupport extends ClusterActionHandler {
 
   @Override

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterSpec.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterSpec.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterSpec.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ClusterSpec.java Thu Mar  3 23:01:03 2011
@@ -32,7 +32,6 @@ import java.net.URLEncoder;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
-import java.util.Map.Entry;
 import java.util.Set;
 
 import com.jcraft.jsch.JSch;

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/RolePredicates.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/RolePredicates.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/RolePredicates.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/RolePredicates.java Thu Mar  3 23:01:03 2011
@@ -26,6 +26,9 @@ import java.util.Set;
 
 import org.apache.whirr.service.Cluster.Instance;
 
+/**
+ * {@link Predicate}s for matching {@link Instance}s with certain cluster roles.
+ */
 public class RolePredicates {
 
   /**

Modified: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ServiceFactory.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ServiceFactory.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ServiceFactory.java (original)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/ServiceFactory.java Thu Mar  3 23:01:03 2011
@@ -37,7 +37,8 @@ public class ServiceFactory {
 
   /**
    * Create an instance of a {@link Service} according to the given
-   * name.
+   * name. If the name is <code>null</code> then the default {@link Service}
+   * is returned.
    */
   public Service create(String serviceName) {
     if (serviceName == null) {
@@ -53,7 +54,7 @@ public class ServiceFactory {
 
   /**
    * Return a collection of available services.
-   * @return
+   * @return the available service names
    */
   public Set<String> availableServices() {
     Set<String> result = Sets.newLinkedHashSet();

Added: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java (added)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java Thu Mar  3 23:01:03 2011
@@ -0,0 +1,24 @@
+/*
+ * 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.
+ * 
+ */ 
+/** 
+ * <p>
+ * <a href="http://www.jclouds.org/">jclouds</a>-specific classes.
+ * </p> 
+ */
+package org.apache.whirr.service.jclouds;

Propchange: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/jclouds/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java (added)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java Thu Mar  3 23:01:03 2011
@@ -0,0 +1,118 @@
+/*
+ * 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.
+ * 
+ */ 
+/** 
+ * <p>
+ * The Whirr Service API.
+ * </p> 
+ * 
+ * <h3>Terminology</h3>
+ * 
+ * <p>
+ * A <i>service</i> is an instance of a coherent system running on one or more
+ * machines.
+ * </p>
+ * <p>
+ * A <i>role</i> is a part of a service running on a single machine. A role
+ * typically corresponds to a single process or daemon, although this is not
+ * required.
+ * </p>
+ * <p>
+ * An <i>instance template</i> ({@link org.apache.whirr.service.ClusterSpec.InstanceTemplate}) is a specification of the role sets and
+ * cardinalities that make up a cluster. For example,
+ * <tt>1 role-a+role-b,4 role-c</tt>
+ * specifies a cluster in which one node is in roles <tt>role-a</tt> and
+ * <tt>role-b</tt>, and four nodes are in role <tt>role-c</tt>.
+ * </p>
+ * <p>
+ * A <i>cluster action</i> ({@link org.apache.whirr.service.ClusterAction}) is an action that is performed on a set of machines
+ * in a cluster. Examples of cluster actions include 'bootstrap' and 'configure'.
+ * </p>
+ * 
+ * <h3>Orchestration</h3>
+ * 
+ * <p>
+ * You can launch or destroy clusters using an instance of
+ * {@link org.apache.whirr.service.Service}.
+ * </p>
+ * 
+ * <p>
+ * Whirr {@link org.apache.whirr.service.Service#launchCluster(ClusterSpec) launches a cluster} by running the bootstrap action, followed by the
+ * configure action. For each of these actions Whirr follows these rules:
+ * </p>
+ * 
+ * <ol>
+ * <li>Instance templates are acted on independently.</li>
+ * <li>For each instance template Whirr will call the cluster action handlers
+ * for each role in the template.</li>
+ * </ol>
+ * 
+ * <p>
+ * The first rule implies that you can't rely on one template being processed
+ * first. In fact, Whirr will process them all in parallel. So to transfer
+ * information from one role to another (in a different template) you should use
+ * different actions. For example, use the configure phase to get information
+ * about another role that was set in its bootstrap phase.
+ * </p>
+ * 
+ * <p>
+ * The second rule implies that a cluster action handler for a given role
+ * will be run more than once if it appears in more than one template.
+ * </p>
+ * 
+ * <p>
+ * A cluster is {@link org.apache.whirr.service.Service#destroyCluster(ClusterSpec) destroyed} by running the destroy action.
+ * </p>
+ * 
+ * <h3>Writing a New Service</h3>
+ * 
+ * <p>
+ * For each role in a service you must write a
+ * {@link org.apache.whirr.service.ClusterActionHandler}, which allows you to
+ * run code at various points in the lifecycle. For example, you can specify a
+ * script that must be run on bootstrap, and another at configuration time.
+ * </p>
+ * 
+ * <p>
+ * Roles for a service are discovered using Java's service-provider loading
+ * facility defined by {@link java.util.ServiceLoader}. It's very easy to
+ * register your service. Simply create a file with the following path (assuming
+ * a Maven directory structure):
+ * </p>
+ * 
+ * <p>
+ * <i>src/main/resources/META-INF/services/org.apache.whirr.service.ClusterActionHandler</i>
+ * </p>
+ * 
+ * <p>
+ * Then for each {@link org.apache.whirr.service.ClusterActionHandler} 
+ * implementation add its fully qualified name as a line in the file:
+ * </p>
+ * 
+ * <pre>
+ * org.example.MyClusterActionHandlerForRoleA
+ * org.example.MyClusterActionHandlerForRoleB
+ * </pre>
+ * 
+ * <p>
+ * If you service is not a part of Whirr, then you can install it by first
+ * installing Whirr, then dropping the JAR file for your service into
+ * Whirr's <i>lib</i> directory.
+ * </p>
+ */
+package org.apache.whirr.service;

Propchange: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/service/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java (added)
+++ incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java Thu Mar  3 23:01:03 2011
@@ -0,0 +1,24 @@
+/*
+ * 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.
+ * 
+ */ 
+/** 
+ * <p>
+ * SSH-related classes.
+ * </p> 
+ */
+package org.apache.whirr.ssh;

Propchange: incubator/whirr/trunk/core/src/main/java/org/apache/whirr/ssh/package-info.java
------------------------------------------------------------------------------
    svn:eol-style = native

Added: incubator/whirr/trunk/core/src/main/javadoc/overview.html
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/main/javadoc/overview.html?rev=1076869&view=auto
==============================================================================
--- incubator/whirr/trunk/core/src/main/javadoc/overview.html (added)
+++ incubator/whirr/trunk/core/src/main/javadoc/overview.html Thu Mar  3 23:01:03 2011
@@ -0,0 +1,26 @@
+<!--
+   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.
+-->
+<html>
+
+<body>
+
+<p>
+Whirr is a library of cloud services.
+</p>
+
+</body>
+</html>
\ No newline at end of file

Propchange: incubator/whirr/trunk/core/src/main/javadoc/overview.html
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/whirr/trunk/core/src/test/java/org/apache/whirr/cluster/actions/BootstrapClusterActionTest.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/test/java/org/apache/whirr/cluster/actions/BootstrapClusterActionTest.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/test/java/org/apache/whirr/cluster/actions/BootstrapClusterActionTest.java (original)
+++ incubator/whirr/trunk/core/src/test/java/org/apache/whirr/cluster/actions/BootstrapClusterActionTest.java Thu Mar  3 23:01:03 2011
@@ -283,7 +283,7 @@ public class BootstrapClusterActionTest 
       Map<String, String> userMetadata = Maps.newHashMap();
       Map<String, Object> locationMetadata = Maps.newHashMap();
       Location location = new LocationImpl(LocationScope.ZONE, "loc", "test location", 
-	      null, new ArrayList<String>(), locationMetadata);
+        null, new ArrayList<String>(), locationMetadata);
       Set<String> addresses = Sets.newHashSet();
       addresses.add("10.0.0.1");
       Credentials loginCredentials = new Credentials("id", "cred");

Modified: incubator/whirr/trunk/core/src/test/java/org/apache/whirr/service/ClusterSpecTest.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/core/src/test/java/org/apache/whirr/service/ClusterSpecTest.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/core/src/test/java/org/apache/whirr/service/ClusterSpecTest.java (original)
+++ incubator/whirr/trunk/core/src/test/java/org/apache/whirr/service/ClusterSpecTest.java Thu Mar  3 23:01:03 2011
@@ -41,10 +41,7 @@ import java.util.Set;
 import org.apache.commons.configuration.CompositeConfiguration;
 import org.apache.commons.configuration.Configuration;
 import org.apache.commons.configuration.ConfigurationException;
-import org.apache.commons.configuration.ConfigurationUtils;
-import org.apache.commons.configuration.HierarchicalConfiguration;
 import org.apache.commons.configuration.PropertiesConfiguration;
-import org.apache.commons.configuration.SubnodeConfiguration;
 import org.apache.commons.io.IOUtils;
 import org.apache.whirr.service.ClusterSpec.InstanceTemplate;
 import org.apache.whirr.ssh.KeyPair;

Modified: incubator/whirr/trunk/services/hadoop/src/main/java/org/apache/whirr/service/hadoop/HadoopDataNodeClusterActionHandler.java
URL: http://svn.apache.org/viewvc/incubator/whirr/trunk/services/hadoop/src/main/java/org/apache/whirr/service/hadoop/HadoopDataNodeClusterActionHandler.java?rev=1076869&r1=1076868&r2=1076869&view=diff
==============================================================================
--- incubator/whirr/trunk/services/hadoop/src/main/java/org/apache/whirr/service/hadoop/HadoopDataNodeClusterActionHandler.java (original)
+++ incubator/whirr/trunk/services/hadoop/src/main/java/org/apache/whirr/service/hadoop/HadoopDataNodeClusterActionHandler.java Thu Mar  3 23:01:03 2011
@@ -28,7 +28,6 @@ import java.io.IOException;
 import java.net.InetAddress;
 
 import org.apache.commons.configuration.ConfigurationException;
-import org.apache.whirr.net.DnsUtil;
 import org.apache.whirr.service.Cluster;
 import org.apache.whirr.service.Cluster.Instance;
 import org.apache.whirr.service.ClusterActionEvent;