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 2012/11/14 12:03:29 UTC

git commit: WHIRR-679. Switch to HBase 0.94.2. Contributed by Andrew Bayer.

Updated Branches:
  refs/heads/trunk d9f302f2e -> d7392d0e2


WHIRR-679. Switch to HBase 0.94.2. Contributed by Andrew Bayer.


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

Branch: refs/heads/trunk
Commit: d7392d0e2ebb781580c676847bffd50b8ba62241
Parents: d9f302f
Author: Tom White <to...@apache.org>
Authored: Wed Nov 14 11:02:46 2012 +0000
Committer: Tom White <to...@apache.org>
Committed: Wed Nov 14 11:02:46 2012 +0000

----------------------------------------------------------------------
 CHANGES.txt                                        |    2 +
 pom.xml                                            |    2 +-
 .../integration/AbstractHBaseServiceTest.java      |   89 +++++++++++++++
 .../hbase/integration/HBase092ServiceTest.java     |   29 -----
 .../integration/HBase092SingleNodeServiceTest.java |   29 -----
 .../hbase/integration/HBaseServiceController.java  |    2 +-
 .../hbase/integration/HBaseServiceTest.java        |   72 +-----------
 .../integration/HBaseSingleNodeServiceTest.java    |   29 +++++
 .../whirr-hbase-0.92-singlenode-test.properties    |   28 -----
 .../resources/whirr-hbase-0.92-test.properties     |   28 -----
 .../whirr-hbase-singlenode-test.properties         |   28 +++++
 .../src/test/resources/whirr-hbase-test.properties |   28 +++++
 12 files changed, 184 insertions(+), 182 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index 0abe5b0..b1edfdc 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -12,6 +12,8 @@ Release 0.8.2 (unreleased changes)
 
     WHIRR-671. Create Kerberos Service. (Graham Gear via tomwhite)
 
+    WHIRR-679. Switch to HBase 0.94.2. (abayer via tomwhite)
+
 Release 0.8.1 - 2012-10-19
 
   NEW FEATURES

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 02eadda..9da26ec 100644
--- a/pom.xml
+++ b/pom.xml
@@ -71,7 +71,7 @@
     <hadoop.version>0.20.205.0</hadoop.version>
     <hamcrest.version>1.1</hamcrest.version>
     <hama.version>0.4.0-incubating</hama.version>
-    <hbase.version>0.92.0</hbase.version>
+    <hbase.version>0.94.1</hbase.version>
     <jackson.version>1.5.2</jackson.version>
     <jclouds.version>1.5.1</jclouds.version>
     <jdom.version>1.1</jdom.version>

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/AbstractHBaseServiceTest.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/AbstractHBaseServiceTest.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/AbstractHBaseServiceTest.java
new file mode 100644
index 0000000..54df100
--- /dev/null
+++ b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/AbstractHBaseServiceTest.java
@@ -0,0 +1,89 @@
+/**
+ * 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.
+ */
+
+package org.apache.whirr.service.hbase.integration;
+
+import com.google.common.collect.Lists;
+import org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor;
+import org.apache.hadoop.hbase.thrift.generated.Hbase;
+import org.apache.hadoop.hbase.thrift.generated.Mutation;
+import org.apache.hadoop.hbase.thrift.generated.TRowResult;
+import org.apache.hadoop.hbase.util.Bytes;
+import org.apache.whirr.TestConstants;
+import org.junit.AfterClass;
+import org.junit.Test;
+
+import java.nio.ByteBuffer;
+import java.util.ArrayList;
+import java.util.List;
+
+import static org.hamcrest.Matchers.is;
+import static org.junit.Assert.assertThat;
+import static org.junit.Assert.assertTrue;
+
+public abstract class AbstractHBaseServiceTest {
+
+  private static final ByteBuffer FIRST = toBytes("");
+  private static final ByteBuffer TABLE = toBytes("testtable");
+  private static final ByteBuffer ROW = toBytes("testRow");
+  private static final ByteBuffer FAMILY1 = toBytes("testFamily1");
+  private static final ByteBuffer FAMILY2 = toBytes("testFamily2");
+  private static final ByteBuffer COLUMN = toBytes("testFamily1:testColumn");
+  private static final ByteBuffer VALUE = toBytes("testValue");
+  
+  static ByteBuffer toBytes(String val) {
+    return ByteBuffer.wrap(Bytes.toBytes(val));
+  }
+
+  protected static HBaseServiceController controller;
+
+  @AfterClass
+  public static void tearDown() throws Exception {
+    controller.shutdown();
+  }
+
+  @Test(timeout = TestConstants.ITEST_TIMEOUT)
+  public void test() throws Exception {
+    ArrayList<ColumnDescriptor> columns = new ArrayList<ColumnDescriptor>();
+    ColumnDescriptor cd = new ColumnDescriptor();
+    cd.name = FAMILY1;
+    columns.add(cd);
+    cd = new ColumnDescriptor();
+    cd.name = FAMILY2;
+    columns.add(cd);
+
+    Hbase.Client client = controller.getThriftClient();
+    client.createTable(TABLE, columns);
+
+    ArrayList<Mutation> mutations = new ArrayList<Mutation>();
+    mutations.add(new Mutation(false, COLUMN, VALUE, true));
+    client.mutateRow(TABLE, ROW, mutations, null);
+    
+    int scan1 = client.scannerOpen(TABLE, FIRST, Lists.newArrayList(FAMILY1), null);
+    List<TRowResult> rows = client.scannerGet(scan1);
+    assertThat(rows.size(), is(1));
+    assertThat(Bytes.toString(rows.get(0).getRow()), is("testRow"));
+    assertTrue("No more rows", client.scannerGet(scan1).isEmpty());
+    client.scannerClose(scan1);
+
+    int scan2 = client.scannerOpen(TABLE, FIRST, Lists.newArrayList(FAMILY2), null);
+    assertTrue("No more rows", client.scannerGet(scan2).isEmpty());
+    client.scannerClose(scan2);
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092ServiceTest.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092ServiceTest.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092ServiceTest.java
deleted file mode 100644
index 33064d9..0000000
--- a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092ServiceTest.java
+++ /dev/null
@@ -1,29 +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.
- */
-
-package org.apache.whirr.service.hbase.integration;
-
-import org.junit.BeforeClass;
-
-public class HBase092ServiceTest extends HBaseServiceTest {
-  @BeforeClass
-  public static void setUp() throws Exception {
-    controller = HBaseServiceController.getInstance("whirr-hbase-0.92-test.properties");
-    controller.ensureClusterRunning();
-  }
-}

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092SingleNodeServiceTest.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092SingleNodeServiceTest.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092SingleNodeServiceTest.java
deleted file mode 100644
index 3ec3d5e..0000000
--- a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBase092SingleNodeServiceTest.java
+++ /dev/null
@@ -1,29 +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.
- */
-
-package org.apache.whirr.service.hbase.integration;
-
-import org.junit.BeforeClass;
-
-public class HBase092SingleNodeServiceTest extends HBaseServiceTest {
-  @BeforeClass
-  public static void setUp() throws Exception {
-    controller = HBaseServiceController.getInstance("whirr-hbase-0.92-singlenode-test.properties");
-    controller.ensureClusterRunning();
-  }
-}

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceController.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceController.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceController.java
index 98d54f3..82ad53f 100644
--- a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceController.java
+++ b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceController.java
@@ -145,7 +145,7 @@ public class HBaseServiceController {
     TProtocol protocol = new TBinaryProtocol(transport, true, true);
     Hbase.Client client = new Hbase.Client(protocol);
     int scannerId = client.scannerOpen(ByteBuffer.wrap(HConstants.META_TABLE_NAME),
-        ByteBuffer.wrap(Bytes.toBytes("")), null);
+                                       ByteBuffer.wrap(Bytes.toBytes("")), null, null);
     client.scannerClose(scannerId);
     thriftClient = client;
   }

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceTest.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceTest.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceTest.java
index a703b01..d92bd31 100644
--- a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceTest.java
+++ b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseServiceTest.java
@@ -18,72 +18,12 @@
 
 package org.apache.whirr.service.hbase.integration;
 
-import com.google.common.collect.Lists;
-import org.apache.hadoop.hbase.thrift.generated.ColumnDescriptor;
-import org.apache.hadoop.hbase.thrift.generated.Hbase;
-import org.apache.hadoop.hbase.thrift.generated.Mutation;
-import org.apache.hadoop.hbase.thrift.generated.TRowResult;
-import org.apache.hadoop.hbase.util.Bytes;
-import org.apache.whirr.TestConstants;
-import org.junit.AfterClass;
-import org.junit.Test;
+import org.junit.BeforeClass;
 
-import java.nio.ByteBuffer;
-import java.util.ArrayList;
-import java.util.List;
-
-import static org.hamcrest.Matchers.is;
-import static org.junit.Assert.assertThat;
-import static org.junit.Assert.assertTrue;
-
-public abstract class HBaseServiceTest {
-
-  private static final ByteBuffer FIRST = toBytes("");
-  private static final ByteBuffer TABLE = toBytes("testtable");
-  private static final ByteBuffer ROW = toBytes("testRow");
-  private static final ByteBuffer FAMILY1 = toBytes("testFamily1");
-  private static final ByteBuffer FAMILY2 = toBytes("testFamily2");
-  private static final ByteBuffer COLUMN = toBytes("testFamily1:testColumn");
-  private static final ByteBuffer VALUE = toBytes("testValue");
-  
-  static ByteBuffer toBytes(String val) {
-    return ByteBuffer.wrap(Bytes.toBytes(val));
-  }
-
-  protected static HBaseServiceController controller;
-
-  @AfterClass
-  public static void tearDown() throws Exception {
-    controller.shutdown();
+public class HBaseServiceTest extends AbstractHBaseServiceTest {
+  @BeforeClass
+  public static void setUp() throws Exception {
+    controller = HBaseServiceController.getInstance("whirr-hbase-test.properties");
+    controller.ensureClusterRunning();
   }
-
-  @Test(timeout = TestConstants.ITEST_TIMEOUT)
-  public void test() throws Exception {
-    ArrayList<ColumnDescriptor> columns = new ArrayList<ColumnDescriptor>();
-    ColumnDescriptor cd = new ColumnDescriptor();
-    cd.name = FAMILY1;
-    columns.add(cd);
-    cd = new ColumnDescriptor();
-    cd.name = FAMILY2;
-    columns.add(cd);
-
-    Hbase.Client client = controller.getThriftClient();
-    client.createTable(TABLE, columns);
-
-    ArrayList<Mutation> mutations = new ArrayList<Mutation>();
-    mutations.add(new Mutation(false, COLUMN, VALUE));
-    client.mutateRow(TABLE, ROW, mutations);
-    
-    int scan1 = client.scannerOpen(TABLE, FIRST, Lists.newArrayList(FAMILY1));
-    List<TRowResult> rows = client.scannerGet(scan1);
-    assertThat(rows.size(), is(1));
-    assertThat(Bytes.toString(rows.get(0).getRow()), is("testRow"));
-    assertTrue("No more rows", client.scannerGet(scan1).isEmpty());
-    client.scannerClose(scan1);
-
-    int scan2 = client.scannerOpen(TABLE, FIRST, Lists.newArrayList(FAMILY2));
-    assertTrue("No more rows", client.scannerGet(scan2).isEmpty());
-    client.scannerClose(scan2);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseSingleNodeServiceTest.java
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseSingleNodeServiceTest.java b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseSingleNodeServiceTest.java
new file mode 100644
index 0000000..0f00227
--- /dev/null
+++ b/services/hbase/src/test/java/org/apache/whirr/service/hbase/integration/HBaseSingleNodeServiceTest.java
@@ -0,0 +1,29 @@
+/**
+ * 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.
+ */
+
+package org.apache.whirr.service.hbase.integration;
+
+import org.junit.BeforeClass;
+
+public class HBaseSingleNodeServiceTest extends AbstractHBaseServiceTest {
+  @BeforeClass
+  public static void setUp() throws Exception {
+    controller = HBaseServiceController.getInstance("whirr-hbase-singlenode-test.properties");
+    controller.ensureClusterRunning();
+  }
+}

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/resources/whirr-hbase-0.92-singlenode-test.properties
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/resources/whirr-hbase-0.92-singlenode-test.properties b/services/hbase/src/test/resources/whirr-hbase-0.92-singlenode-test.properties
deleted file mode 100644
index c03aace..0000000
--- a/services/hbase/src/test/resources/whirr-hbase-0.92-singlenode-test.properties
+++ /dev/null
@@ -1,28 +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.
-#
-whirr.cluster-name=hbase-0-92-single-node-itest-${sys:whirr.test.provider}-${sys:user.name}
-whirr.instance-templates=1 hadoop-namenode+hadoop-jobtracker+zookeeper+hbase-master+hbase-thriftserver+hadoop-datanode+hadoop-tasktracker+hbase-regionserver
-
-whirr.provider=${sys:whirr.test.provider}
-whirr.identity=${sys:whirr.test.identity}
-whirr.credential=${sys:whirr.test.credential}
-
-whirr.hardware-min-ram=4096
-
-whirr.hbase.tarball.url=http://apache.osuosl.org/hbase/hbase-0.92.1/hbase-0.92.1.tar.gz
-whirr.hadoop.tarball.url=http://apache.osuosl.org/hadoop/common/hadoop-1.0.3/hadoop-1.0.3.tar.gz

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/resources/whirr-hbase-0.92-test.properties
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/resources/whirr-hbase-0.92-test.properties b/services/hbase/src/test/resources/whirr-hbase-0.92-test.properties
deleted file mode 100644
index 3b12446..0000000
--- a/services/hbase/src/test/resources/whirr-hbase-0.92-test.properties
+++ /dev/null
@@ -1,28 +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.
-#
-whirr.cluster-name=hbase-0-92-itest-${sys:whirr.test.provider}-${sys:user.name}
-whirr.instance-templates=1 hadoop-namenode+hadoop-jobtracker+zookeeper+hbase-master+hbase-thriftserver,1 hadoop-datanode+hadoop-tasktracker+hbase-regionserver
-
-whirr.provider=${sys:whirr.test.provider}
-whirr.identity=${sys:whirr.test.identity}
-whirr.credential=${sys:whirr.test.credential}
-
-whirr.hbase.tarball.url=http://apache.osuosl.org/hbase/hbase-0.92.1/hbase-0.92.1.tar.gz
-whirr.hadoop.tarball.url=http://apache.osuosl.org/hadoop/common/hadoop-1.0.3/hadoop-1.0.3.tar.gz
-
-

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/resources/whirr-hbase-singlenode-test.properties
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/resources/whirr-hbase-singlenode-test.properties b/services/hbase/src/test/resources/whirr-hbase-singlenode-test.properties
new file mode 100644
index 0000000..9848fac
--- /dev/null
+++ b/services/hbase/src/test/resources/whirr-hbase-singlenode-test.properties
@@ -0,0 +1,28 @@
+#
+# 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.
+#
+whirr.cluster-name=hbase-single-node-itest-${sys:whirr.test.provider}-${sys:user.name}
+whirr.instance-templates=1 hadoop-namenode+hadoop-jobtracker+zookeeper+hbase-master+hbase-thriftserver+hadoop-datanode+hadoop-tasktracker+hbase-regionserver
+
+whirr.provider=${sys:whirr.test.provider}
+whirr.identity=${sys:whirr.test.identity}
+whirr.credential=${sys:whirr.test.credential}
+
+whirr.hardware-min-ram=4096
+
+whirr.hbase.tarball.url=http://archive.apache.org/dist/hbase/hbase-0.94.1/hbase-0.94.1.tar.gz
+whirr.hadoop.tarball.url=http://archive.apache.org/dist/hadoop/common/hadoop-1.0.3/hadoop-1.0.3.tar.gz

http://git-wip-us.apache.org/repos/asf/whirr/blob/d7392d0e/services/hbase/src/test/resources/whirr-hbase-test.properties
----------------------------------------------------------------------
diff --git a/services/hbase/src/test/resources/whirr-hbase-test.properties b/services/hbase/src/test/resources/whirr-hbase-test.properties
new file mode 100644
index 0000000..7986716
--- /dev/null
+++ b/services/hbase/src/test/resources/whirr-hbase-test.properties
@@ -0,0 +1,28 @@
+#
+# 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.
+#
+whirr.cluster-name=hbase-itest-${sys:whirr.test.provider}-${sys:user.name}
+whirr.instance-templates=1 hadoop-namenode+hadoop-jobtracker+zookeeper+hbase-master+hbase-thriftserver,1 hadoop-datanode+hadoop-tasktracker+hbase-regionserver
+
+whirr.provider=${sys:whirr.test.provider}
+whirr.identity=${sys:whirr.test.identity}
+whirr.credential=${sys:whirr.test.credential}
+
+whirr.hbase.tarball.url=http://archive.apache.org/dist/hbase/hbase-0.94.1/hbase-0.94.1.tar.gz
+whirr.hadoop.tarball.url=http://archive.apache.org/dist/hadoop/common/hadoop-1.0.3/hadoop-1.0.3.tar.gz
+
+