You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jclouds.apache.org by ab...@apache.org on 2013/05/10 23:53:13 UTC

[04/18] JCLOUDS-25. Remove oprhaned sandbox-* from repo

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/IBMSmartCloudClientLiveTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/IBMSmartCloudClientLiveTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/IBMSmartCloudClientLiveTest.java
deleted file mode 100644
index ef7c4ec..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/IBMSmartCloudClientLiveTest.java
+++ /dev/null
@@ -1,515 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud;
-
-import static com.google.common.collect.Iterables.filter;
-import static org.jclouds.ibm.smartcloud.options.CreateInstanceOptions.Builder.authorizePublicKey;
-import static org.jclouds.ibm.smartcloud.options.CreateInstanceOptions.Builder.secondaryIP;
-import static org.testng.Assert.assertEquals;
-import static org.testng.Assert.assertNotNull;
-import static org.testng.Assert.assertTrue;
-
-import java.io.IOException;
-import java.util.NoSuchElementException;
-import java.util.Set;
-import java.util.concurrent.TimeUnit;
-
-import org.jclouds.compute.domain.ExecResponse;
-import org.jclouds.domain.Credentials;
-import org.jclouds.http.HttpResponseException;
-import org.jclouds.http.handlers.BackoffLimitedRetryHandler;
-import org.jclouds.ibm.smartcloud.domain.Address;
-import org.jclouds.ibm.smartcloud.domain.Image;
-import org.jclouds.ibm.smartcloud.domain.Instance;
-import org.jclouds.ibm.smartcloud.domain.Instance.Software;
-import org.jclouds.ibm.smartcloud.domain.InstanceType;
-import org.jclouds.ibm.smartcloud.domain.Key;
-import org.jclouds.ibm.smartcloud.domain.Location;
-import org.jclouds.ibm.smartcloud.domain.Offering;
-import org.jclouds.ibm.smartcloud.domain.StorageOffering;
-import org.jclouds.ibm.smartcloud.domain.StorageOffering.Format;
-import org.jclouds.ibm.smartcloud.domain.Volume;
-import org.jclouds.ibm.smartcloud.predicates.AddressFree;
-import org.jclouds.ibm.smartcloud.predicates.InstanceActive;
-import org.jclouds.ibm.smartcloud.predicates.InstanceActiveOrFailed;
-import org.jclouds.ibm.smartcloud.predicates.InstanceRemovedOrNotFound;
-import org.jclouds.ibm.smartcloud.predicates.VolumeUnmounted;
-import org.jclouds.net.IPSocket;
-import org.jclouds.predicates.InetSocketAddressConnect;
-import org.jclouds.predicates.RetryablePredicate;
-import org.jclouds.ssh.SshClient;
-import org.jclouds.ssh.SshException;
-import org.jclouds.sshj.SshjSshClient;
-import org.testng.annotations.AfterTest;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Predicate;
-import com.google.common.collect.ComparisonChain;
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Iterables;
-import com.google.common.collect.Ordering;
-import com.google.common.collect.Sets;
-
-/**
- * Tests behavior of {@code IBMSmartCloudClient}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "live", singleThreaded = true, testName = "IBMSmartCloudClientLiveTest")
-public class IBMSmartCloudClientLiveTest extends BaseIBMSmartCloudClientLiveTest {
-   private static final String OS = "SUSE Linux Enterprise Server";
-   private static final String VERSION = "11 SP1";
-
-   private static final String PLATFORM = OS + "/" + VERSION;
-
-   private static final ImmutableSet<Software> SOFTWARE = ImmutableSet.<Software> of(new Software(OS, "OS", VERSION));
-
-   private static String FORMAT = "EXT3";
-
-   private Location location;
-   private Address ip;
-   private Key key;
-   private Volume volume;
-
-   private Instance instance2;
-   private Instance instance;
-   private InstanceType instanceType;
-   private Image image;
-
-   private StorageOffering cheapestStorage;
-
-   private static final String GROUP = System.getProperty("user.name");
-
-   @Test
-   public void testGetLocation() throws Exception {
-      Set<? extends Location> response = connection.listLocations();
-      assertNotNull(response);
-      if (response.size() > 0) {
-         location = Iterables.find(response, new Predicate<Location>() {
-
-            @Override
-            public boolean apply(Location arg0) {
-               // ontario is the least used
-               return "101".equals(arg0.getId());
-            }
-
-         });
-         assertEquals(connection.getLocation(location.getId()).getId(), location.getId());
-      }
-   }
-
-   @Test(dependsOnMethods = "testGetLocation")
-   public void testAddPublicKey() throws Exception {
-      try {
-         connection.addPublicKey(GROUP, keyPair.get("public"));
-         key = connection.getKey(GROUP);
-         try {
-            assert key.getInstanceIds().equals(ImmutableSet.<String> of()) : key;
-         } catch (AssertionError e) {
-            // inconsistency in the key api when recreating a key
-            // http://www-180.ibm.com/cloud/enterprise/beta/ram/community/discussionTopic.faces?guid={DA689AEE-783C-6FE7-6F9F-DFEE9763F806}&v=1&fid=1068&tid=1528
-         }
-      } catch (IllegalStateException e) {
-         // must have been found
-         connection.updatePublicKey(GROUP, keyPair.get("public"));
-         key = connection.getKey(GROUP);
-         for (String instanceId : key.getInstanceIds()) {
-            Instance instance = connection.getInstance(instanceId);
-            if (instance.getStatus() == Instance.Status.FAILED || instance.getStatus() == Instance.Status.ACTIVE) {
-               killInstance(instance.getId());
-            }
-         }
-      }
-      assertEquals(key.getName(), GROUP);
-      assert keyPair.get("public").indexOf(key.getKeyMaterial()) > 0;
-      assertNotNull(key.getLastModifiedTime());
-   }
-
-   @Test(dependsOnMethods = "resolveImageAndInstanceType")
-   public void testAllocateIpAddress() throws Exception {
-
-      Offering offering = Iterables.find(connection.listAddressOfferings(), new Predicate<Offering>() {
-
-         @Override
-         public boolean apply(Offering arg0) {
-            return arg0.getLocation().equals(location.getId());
-         }
-      });
-
-      try {
-         ip = connection.allocateAddressInLocation(location.getId(), offering.getId());
-         System.out.println(ip);
-         assertEquals(ip.getIP(), null);
-         // wait up to 30 seconds for this to become "free"
-         new RetryablePredicate<Address>(new AddressFree(connection), 30, 2, TimeUnit.SECONDS).apply(ip);
-         refreshIpAndReturnAllAddresses();
-         assertEquals(ip.getInstanceId(), null);
-      } catch (IllegalStateException e) {
-         if (HttpResponseException.class.cast(e.getCause()).getResponse().getStatusCode() == 409) {
-            ip = Iterables.find(connection.listAddresses(), new Predicate<Address>() {
-
-               @Override
-               public boolean apply(Address input) {
-                  return input.getState() == Address.State.FREE;
-               }
-
-            });
-         } else {
-            throw e;
-         }
-      }
-      assertEquals(ip.getInstanceId(), null);
-      assertEquals(ip.getLocation(), location.getId());
-
-      Set<? extends Address> allAddresses = refreshIpAndReturnAllAddresses();
-
-      assert (allAddresses.contains(ip)) : String.format("ip %s not in %s", ip, allAddresses);
-   }
-
-   @Test(dependsOnMethods = "testGetLocation")
-   public void testResolveVolumeOffering() throws Exception {
-
-      Ordering<StorageOffering> cheapestOrdering = new Ordering<StorageOffering>() {
-         public int compare(StorageOffering left, StorageOffering right) {
-            return ComparisonChain.start().compare(left.getPrice().getRate(), right.getPrice().getRate()).result();
-         }
-      }.reverse();
-
-      Iterable<? extends StorageOffering> storageOfferingsThatAreInOurLocationAndCorrectFormat = filter(connection
-               .listStorageOfferings(), new Predicate<StorageOffering>() {
-         @Override
-         public boolean apply(StorageOffering arg0) {
-
-            return arg0.getLocation().equals(location.getId())
-                     && Iterables.any(arg0.getFormats(), new Predicate<StorageOffering.Format>() {
-
-                        @Override
-                        public boolean apply(Format arg0) {
-                           return arg0.getId().equals(FORMAT);
-                        }
-
-                     });
-         }
-      });
-      cheapestStorage = cheapestOrdering.max(storageOfferingsThatAreInOurLocationAndCorrectFormat);
-      System.out.println(cheapestStorage);
-   }
-
-   @Test(dependsOnMethods = "testResolveVolumeOffering")
-   public void testCreateVolume() throws Exception {
-      try {
-         volume = connection.createVolumeInLocation(location.getId(), GROUP, FORMAT, cheapestStorage.getName(),
-                  cheapestStorage.getId());
-         // wait up to 5 minutes for this to become "unmounted"
-         assert new RetryablePredicate<Volume>(new VolumeUnmounted(connection), 300, 5, TimeUnit.SECONDS).apply(volume);
-      } catch (IllegalStateException e) {
-         int code = HttpResponseException.class.cast(e.getCause()).getResponse().getStatusCode();
-         if (code == 409 || code == 500) {
-            Set<? extends Volume> volumes = connection.listVolumes();
-            try {
-               volume = Iterables.find(volumes, new Predicate<Volume>() {
-
-                  @Override
-                  public boolean apply(Volume input) {
-                     return input.getState() == Volume.State.UNMOUNTED;
-                  }
-
-               });
-            } catch (NoSuchElementException ex) {
-               killInstance(GROUP + 1);
-            }
-         } else {
-            throw e;
-         }
-      }
-      assertEquals(volume.getInstanceId(), null);
-      assertEquals(volume.getLocation(), location.getId());
-
-      final String id = volume.getId();
-      Set<? extends Volume> allVolumes = connection.listVolumes();
-
-      // refresh volume as it may have been just created
-      volume = Iterables.find(allVolumes, new Predicate<Volume>() {
-
-         @Override
-         public boolean apply(Volume input) {
-            return input.getId().equals(id);
-         }
-
-      });
-
-      assert (allVolumes.contains(volume)) : String.format("volume %s not in %s", volume, volume);
-   }
-
-   @Test(dependsOnMethods = "testGetLocation")
-   public void resolveImageAndInstanceType() throws Exception {
-      Iterable<? extends Image> imagesThatAreInOurLocationAndNotBYOL = filter(connection.listImages(),
-               new Predicate<Image>() {
-                  @Override
-                  public boolean apply(Image arg0) {
-                     return arg0.getLocation().equals(location.getId()) && arg0.getPlatform().equals(PLATFORM)
-                              && arg0.getName().startsWith(OS);
-                  }
-               });
-
-      Ordering<InstanceType> cheapestOrdering = new Ordering<InstanceType>() {
-         public int compare(InstanceType left, InstanceType right) {
-            return ComparisonChain.start().compare(left.getPrice().getRate(), right.getPrice().getRate()).result();
-         }
-      }.reverse();
-
-      Set<InstanceType> instanceTypes = Sets.newLinkedHashSet();
-
-      for (Image image : imagesThatAreInOurLocationAndNotBYOL)
-         Iterables.addAll(instanceTypes, image.getSupportedInstanceTypes());
-
-      instanceType = cheapestOrdering.max(instanceTypes);
-
-      final InstanceType cheapestInstanceType = instanceType;
-      System.err.println(cheapestInstanceType);
-
-      image = Iterables.find(imagesThatAreInOurLocationAndNotBYOL, new Predicate<Image>() {
-
-         @Override
-         public boolean apply(Image arg0) {
-            return arg0.getSupportedInstanceTypes().contains(cheapestInstanceType);
-         }
-
-      });
-      System.err.println(image);
-      System.err.println(connection.getManifestOfImage(image.getId()));
-   }
-
-   @Test(dependsOnMethods = { "testAddPublicKey", "resolveImageAndInstanceType" })
-   public void testCreateInstance() throws Exception {
-      killInstance(GROUP);
-
-      instance = connection.createInstanceInLocation(location.getId(), GROUP, image.getId(), instanceType.getId(),
-               authorizePublicKey(key.getName()).isMiniEphemeral(true));
-
-      assertBeginState(instance, GROUP);
-      assertIpHostNullAndStatusNEW(instance);
-      blockUntilRunning(instance);
-      instance = assertRunning(instance, GROUP);
-      sshAndDf(new IPSocket(instance.getPrimaryIP().getIP(), 22), new Credentials("idcuser", key.getKeyMaterial()));
-   }
-
-   private void killInstance(final String nameToKill) {
-      Set<? extends Instance> instances = connection.listInstances();
-      try {
-         Instance instance = Iterables.find(instances, new Predicate<Instance>() {
-
-            @Override
-            public boolean apply(Instance input) {
-               return input.getName().equals(nameToKill);
-            }
-
-         });
-         if (instance.getStatus() != Instance.Status.DEPROVISIONING
-                  && instance.getStatus() != Instance.Status.DEPROVISION_PENDING) {
-            System.out.println("deleting instance: " + instance);
-            int timeout = (instance.getStatus() == Instance.Status.NEW || instance.getStatus() == Instance.Status.PROVISIONING) ? 300
-                     : 30;
-            assert new RetryablePredicate<Instance>(new InstanceActiveOrFailed(connection), timeout, 2,
-                     TimeUnit.SECONDS).apply(instance) : instance;
-            connection.deleteInstance(instance.getId());
-         }
-         assert new RetryablePredicate<Instance>(new InstanceRemovedOrNotFound(connection), 120, 2, TimeUnit.SECONDS)
-                  .apply(instance) : instance;
-      } catch (NoSuchElementException ex) {
-      }
-   }
-
-   private Instance assertRunning(Instance instance, String name) throws AssertionError {
-      instance = connection.getInstance(instance.getId());
-
-      try {
-         assertIpHostAndStatusACTIVE(instance);
-         assertConsistent(instance, name);
-      } catch (NullPointerException e) {
-         System.err.println(instance);
-         throw e;
-      } catch (AssertionError e) {
-         System.err.println(instance);
-         throw e;
-      }
-      System.err.println("RUNNING: " + instance);
-      return instance;
-   }
-
-   private void blockUntilRunning(Instance instance) {
-      long start = System.currentTimeMillis();
-      assert new RetryablePredicate<Instance>(new InstanceActive(connection), 15 * 60 * 1000).apply(instance) : connection
-               .getInstance(instance.getId());
-
-      System.out.println(((System.currentTimeMillis() - start) / 1000) + " seconds");
-   }
-
-   private void assertBeginState(Instance instance, String name) throws AssertionError {
-      try {
-         assertConsistent(instance, name);
-      } catch (NullPointerException e) {
-         System.err.println(instance);
-         throw e;
-      } catch (AssertionError e) {
-         killInstance(instance.getId());
-         throw e;
-      }
-   }
-
-   private void assertConsistent(Instance instance, String name) {
-      assert (instance.getId() != null) : instance;
-      assertEquals(instance.getName(), name);
-      assertEquals(instance.getInstanceType(), instanceType.getId());
-      assertEquals(instance.getLocation(), location.getId());
-      assertEquals(instance.getImageId(), image.getId());
-      assertEquals(instance.getSoftware(), SOFTWARE);
-      assertEquals(instance.getKeyName(), key.getName());
-      assertNotNull(instance.getLaunchTime());
-      assertNotNull(instance.getExpirationTime());
-      assertEquals(instance.getOwner(), identity);
-      assertEquals(instance.getProductCodes(), ImmutableSet.<String> of());
-      assertEquals(instance.getRequestName(), name);
-      assertNotNull(instance.getRequestId());
-   }
-
-   private void assertIpHostNullAndStatusNEW(Instance instance) {
-      assertEquals(instance.getPrimaryIP(), null);
-      assertEquals(instance.getStatus(), Instance.Status.NEW);
-   }
-
-   private void assertIpHostAndStatusNEW(Instance instance) {
-      assertNotNull(instance.getPrimaryIP());
-      assertEquals(instance.getStatus(), Instance.Status.NEW);
-   }
-
-   private void assertIpHostAndStatusACTIVE(Instance instance) {
-      assertNotNull(instance.getPrimaryIP());
-      assertEquals(instance.getStatus(), Instance.Status.ACTIVE);
-   }
-
-   @Test(dependsOnMethods = { "testAddPublicKey", "testAllocateIpAddress", "testCreateVolume",
-            "resolveImageAndInstanceType" })
-   public void testCreateInstanceWithIpAndVolume() throws Exception {
-      String name = GROUP + "1";
-      killInstance(name);
-
-      instance2 = connection.createInstanceInLocation(location.getId(), name, image.getId(), instanceType.getId(),
-               secondaryIP(ip.getId()).isMiniEphemeral(true).authorizePublicKey(key.getName()).mountVolume(
-                        volume.getId(), "/mnt"));
-
-      assertBeginState(instance2, name);
-      assertIpHostAndStatusNEW(instance2);
-      blockUntilRunning(instance2);
-      instance2 = assertRunning(instance2, name);
-
-      volume = connection.getVolume(volume.getId());
-      assertEquals(volume.getInstanceId(), instance2.getId());
-
-      refreshIpAndReturnAllAddresses();
-      assertEquals(ip.getInstanceId(), instance2.getId());
-      assertEquals(ip.getIP(), instance2.getPrimaryIP().getIP());
-      sshAndDf(new IPSocket(instance2.getPrimaryIP().getIP(), 22), new Credentials("idcuser", keyPair.get("private")));
-   }
-
-   private Set<? extends Address> refreshIpAndReturnAllAddresses() {
-      Set<? extends Address> allAddresses = connection.listAddresses();
-      final String id = ip.getId();
-      // refresh address as it may have been just created
-      ip = Iterables.find(allAddresses, new Predicate<Address>() {
-
-         @Override
-         public boolean apply(Address input) {
-            return input.getId().equals(id);
-         }
-
-      });
-      return allAddresses;
-   }
-
-   @AfterTest(groups = { "live" })
-   void tearDown() {
-      if (volume != null)
-         try {
-            connection.deleteVolume(volume.getId());
-         } catch (Exception e) {
-
-         }
-      if (ip != null)
-         try {
-            connection.releaseAddress(ip.getId());
-         } catch (Exception e) {
-
-         }
-      if (key != null)
-         try {
-            connection.deleteKey(key.getName());
-         } catch (Exception e) {
-
-         }
-      if (instance != null)
-         try {
-            connection.deleteInstance(instance.getId());
-         } catch (Exception e) {
-
-         }
-      if (instance2 != null)
-         try {
-            connection.deleteInstance(instance2.getId());
-         } catch (Exception e) {
-
-         }
-   }
-
-   private void sshAndDf(IPSocket socket, Credentials credentials) throws IOException {
-      for (int i = 0; i < 5; i++) {// retry loop TODO replace with predicate.
-         try {
-            _sshAndDf(socket, credentials);
-            return;
-         } catch (SshException e) {
-            try {
-               Thread.sleep(10 * 1000);
-            } catch (InterruptedException e1) {
-            }
-            continue;
-         }
-      }
-   }
-
-   private void _sshAndDf(IPSocket socket, Credentials credentials) {
-      RetryablePredicate<IPSocket> socketOpen = new RetryablePredicate<IPSocket>(new InetSocketAddressConnect(), 180,
-               5, TimeUnit.SECONDS);
-
-      socketOpen.apply(socket);
-
-      SshClient ssh = new SshjSshClient(new BackoffLimitedRetryHandler(), socket, 60000, credentials.identity, null,
-               credentials.credential.getBytes());
-      try {
-         ssh.connect();
-         ExecResponse hello = ssh.exec("echo hello");
-         assertEquals(hello.getOutput().trim(), "hello");
-         ExecResponse exec = ssh.exec("df");
-         assertTrue(exec.getOutput().contains("Filesystem"),
-                  "The output should've contained filesystem information, but it didn't. Output: " + exec);
-      } finally {
-         if (ssh != null)
-            ssh.disconnect();
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/ReadOnlyIBMSmartCloudClientLiveTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/ReadOnlyIBMSmartCloudClientLiveTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/ReadOnlyIBMSmartCloudClientLiveTest.java
deleted file mode 100644
index 44bab06..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/ReadOnlyIBMSmartCloudClientLiveTest.java
+++ /dev/null
@@ -1,125 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud;
-
-import static org.testng.Assert.assertEquals;
-import static org.testng.Assert.assertNotNull;
-
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.domain.Address;
-import org.jclouds.ibm.smartcloud.domain.Image;
-import org.jclouds.ibm.smartcloud.domain.Instance;
-import org.jclouds.ibm.smartcloud.domain.Key;
-import org.jclouds.ibm.smartcloud.domain.Location;
-import org.jclouds.ibm.smartcloud.domain.Volume;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.Iterables;
-
-/**
- * Tests behavior of {@code IBMSmartCloudClient}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "live", testName = "ReadOnlyIBMSmartCloudClientLiveTest")
-public class ReadOnlyIBMSmartCloudClientLiveTest extends BaseIBMSmartCloudClientLiveTest {
-
-   @Test
-   public void testListImages() throws Exception {
-      Set<? extends Image> response = connection.listImages();
-      assertNotNull(response);
-   }
-
-   @Test
-   public void testGetImage() throws Exception {
-      Set<? extends Image> response = connection.listImages();
-      assertNotNull(response);
-      if (response.size() > 0) {
-         Image image = Iterables.get(response, 0);
-         assertEquals(connection.getImage(image.getId()).getId(), image.getId());
-      }
-   }
-
-   @Test
-   public void testListInstances() throws Exception {
-      Set<? extends Instance> response = connection.listInstances();
-      assertNotNull(response);
-   }
-
-   @Test
-   public void testListInstancesFromRequestReturnsEmptySet() throws Exception {
-      Set<? extends Instance> response = connection.listInstancesFromRequest(Long.MAX_VALUE + "");
-      assertEquals(response.size(), 0);
-   }
-
-   @Test
-   public void testGetInstance() throws Exception {
-      Set<? extends Instance> response = connection.listInstances();
-      assertNotNull(response);
-      if (response.size() > 0) {
-         Instance instance = Iterables.get(response, 0);
-         assertEquals(connection.getInstance(instance.getId()).getId(), instance.getId());
-      }
-   }
-
-   @Test
-   public void testListKeys() throws Exception {
-      Set<? extends Key> response = connection.listKeys();
-      assertNotNull(response);
-   }
-
-   @Test
-   public void testGetKey() throws Exception {
-      Set<? extends Key> response = connection.listKeys();
-      assertNotNull(response);
-      if (response.size() > 0) {
-         Key key = Iterables.get(response, 0);
-         assertEquals(connection.getKey(key.getName()).getName(), key.getName());
-      }
-   }
-
-   @Test
-   public void testListVolumes() throws Exception {
-      Set<? extends Volume> response = connection.listVolumes();
-      assertNotNull(response);
-   }
-
-   @Test
-   public void testGetVolume() throws Exception {
-      Set<? extends Volume> response = connection.listVolumes();
-      assertNotNull(response);
-      if (response.size() > 0) {
-         Volume image = Iterables.get(response, 0);
-         assertEquals(connection.getVolume(image.getId()).getId(), image.getId());
-      }
-   }
-
-   @Test
-   public void testListLocations() throws Exception {
-      Set<? extends Location> response = connection.listLocations();
-      assertNotNull(response);
-   }
-
-   @Test
-   public void testListAddresss() throws Exception {
-      Set<? extends Address> response = connection.listAddresses();
-      assertNotNull(response);
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudComputeServiceLiveTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudComputeServiceLiveTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudComputeServiceLiveTest.java
deleted file mode 100644
index d6e4713..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudComputeServiceLiveTest.java
+++ /dev/null
@@ -1,44 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.compute;
-
-import org.jclouds.compute.BaseComputeServiceLiveTest;
-import org.jclouds.sshj.config.SshjSshClientModule;
-import org.testng.annotations.BeforeClass;
-import org.testng.annotations.Test;
-
-import com.google.inject.Module;
-
-/**
- * @author Adrian Cole
- */
-@Test(groups = "live", enabled = true, singleThreaded = true, testName = "IBMSmartCloudComputeServiceLiveTest")
-public class IBMSmartCloudComputeServiceLiveTest extends BaseComputeServiceLiveTest {
-
-   @BeforeClass
-   @Override
-   public void setServiceDefaults() {
-      provider = "ibm-smartcloud";
-   }
-
-   @Override
-   protected Module getSshModule() {
-      return new SshjSshClientModule();
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudTemplateBuilderLiveTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudTemplateBuilderLiveTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudTemplateBuilderLiveTest.java
deleted file mode 100644
index 3da56a2..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/compute/IBMSmartCloudTemplateBuilderLiveTest.java
+++ /dev/null
@@ -1,83 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.compute;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.IOException;
-import java.util.Set;
-
-import org.jclouds.compute.BaseTemplateBuilderLiveTest;
-import org.jclouds.compute.domain.OsFamily;
-import org.jclouds.compute.domain.OsFamilyVersion64Bit;
-import org.jclouds.compute.domain.Template;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Predicate;
-import com.google.common.collect.ImmutableSet;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "live", testName = "IBMSmartCloudTemplateBuilderLiveTest")
-public class IBMSmartCloudTemplateBuilderLiveTest extends BaseTemplateBuilderLiveTest {
-
-   public IBMSmartCloudTemplateBuilderLiveTest() {
-      provider = "ibm-smartcloud";
-   }
-
-   @Override
-   protected Predicate<OsFamilyVersion64Bit> defineUnsupportedOperatingSystems() {
-      return new Predicate<OsFamilyVersion64Bit>() {
-
-         @Override
-         public boolean apply(OsFamilyVersion64Bit input) {
-            switch (input.family) {
-               case SUSE:
-                  return !input.version.equals("") && !input.version.equals("11") && !input.version.equals("11 SP1");
-               case RHEL:
-                  return !input.version.equals("") && !input.version.equals("5.4") && !input.version.equals("5.5");
-               case WINDOWS:
-                  return !input.version.equals("") && !(input.version.equals("2008 R2") && input.is64Bit)
-                           && !input.version.equals("2008 R1") && !input.version.equals("2003 R2");
-               default:
-                  return true;
-            }
-         }
-
-      };
-   }
-
-   @Override
-   public void testDefaultTemplateBuilder() throws IOException {
-      Template defaultTemplate = context.getComputeService().templateBuilder().build();
-      assertEquals(defaultTemplate.getLocation().getIso3166Codes(), ImmutableSet.of("CA-ON"));
-      assertEquals(defaultTemplate.getImage().getId(), "20015393");
-      assertEquals(defaultTemplate.getHardware().getId(), "20015393/COP32.1/2048/60");
-      assertEquals(defaultTemplate.getImage().getOperatingSystem().getVersion(), "11 SP1");
-      assertEquals(defaultTemplate.getImage().getOperatingSystem().is64Bit(), false);
-      assertEquals(defaultTemplate.getImage().getOperatingSystem().getFamily(), OsFamily.SUSE);
-   }
-
-   @Override
-   protected Set<String> getIso3166Codes() {
-      return ImmutableSet.of("US-NC", "DE-BW", "US-CO", "CA-ON", "JP-12", "SG");
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ExtendReservationForInstanceTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ExtendReservationForInstanceTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ExtendReservationForInstanceTest.java
deleted file mode 100644
index a01ba25..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ExtendReservationForInstanceTest.java
+++ /dev/null
@@ -1,55 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.io.Payload;
-import org.jclouds.io.Payloads;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ExtendReservationForInstanceTest")
-public class ExtendReservationForInstanceTest extends BaseItemParserTest<Date> {
-   
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   protected Payload payload() {
-      return Payloads.newStringPayload("{ \"expirationTime\":1249876800000 }");
-   }
-
-   @Override
-   @Unwrap
-   public Date expected() {
-      return new Date(1249876800000l);
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetAddressTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetAddressTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetAddressTest.java
deleted file mode 100644
index 988ca23..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetAddressTest.java
+++ /dev/null
@@ -1,41 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import org.jclouds.ibm.smartcloud.domain.Address;
-import org.jclouds.json.BaseItemParserTest;
-import org.testng.annotations.Test;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "GetAddressTest")
-public class GetAddressTest extends BaseItemParserTest<Address> {
-
-   @Override
-   public String resource() {
-      return "/address.json";
-   }
-
-   @Override
-   public Address expected() {
-      return new Address(2, "1", "129.33.196.243", "1217", "1");
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetImageTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetImageTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetImageTest.java
deleted file mode 100644
index c4189ea..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetImageTest.java
+++ /dev/null
@@ -1,76 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-
-import org.jclouds.http.HttpUtils;
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Image;
-import org.jclouds.ibm.smartcloud.domain.InstanceType;
-import org.jclouds.ibm.smartcloud.domain.Price;
-import org.jclouds.ibm.smartcloud.domain.Image.Visibility;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "GetImageTest")
-public class GetImageTest extends BaseItemParserTest<Image> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/image.json";
-   }
-
-   @Override
-   public Image expected() {
-      return new Image(
-               "SUSE Linux Enterprise Server 11 for x86",
-               HttpUtils
-                        .createUri("https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/parameters.xml"),
-               Image.State.AVAILABLE,
-               Visibility.PUBLIC,
-               "SYSTEM",
-               "SUSE Linux Enterprise Server/11",
-               Image.Architecture.I386,
-               new Date(1216944000000l),
-               "41",
-               ImmutableSet.<InstanceType> of(new InstanceType("Bronze 32 bit", new Price(0.17, "UHR  ", "897", null,
-                        "USD", 1), "BRZ32.1/2048/175"), new InstanceType("Gold 32 bit", new Price(0.41, "UHR  ", "897",
-                        null, "USD", 1), "GLD32.4/4096/350"), new InstanceType("Silver 32 bit", new Price(0.265,
-                        "UHR  ", "897", null, "USD", 1), "SLV32.2/4096/350")),
-               ImmutableSet.<String> of("ifeE7VOzRG6SGvoDlRPTQw"),
-               HttpUtils
-                        .createUri("https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/GettingStarted.html"),
-               "20001150", "SUSE Linux Enterprise Server 11 for x86 Base OS 32-bit with pay for use licensing");
-
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetInstanceTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetInstanceTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetInstanceTest.java
deleted file mode 100644
index 4f574fb..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetInstanceTest.java
+++ /dev/null
@@ -1,61 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.IP;
-import org.jclouds.ibm.smartcloud.domain.Instance;
-import org.jclouds.ibm.smartcloud.domain.Instance.Software;
-import org.jclouds.ibm.smartcloud.domain.Instance.Status;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "GetInstanceTest")
-public class GetInstanceTest extends BaseItemParserTest<Instance> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/instance.json";
-   }
-
-   @Override
-   public Instance expected() {
-      return Instance.builder().launchTime(new Date(1305351683883l)).software(
-               ImmutableSet.of(new Software("SUSE Linux Enterprise Server", "OS", "11 SP1"))).primaryIP(
-               new IP("                ", "                ", 0)).requestId("80890").keyName("adriancole").name(
-               "adriancole").instanceType("COP32.1/2048/60").status(Status.NEW).owner("adrian@cloudconscious.com")
-               .location("101").imageId("20015393").rootOnly(true).requestName("adriancole").id("80590")
-               .expirationTime(new Date(1368423692824l)).diskSize(60).build();
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetKeyTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetKeyTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetKeyTest.java
deleted file mode 100644
index 62ee143..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetKeyTest.java
+++ /dev/null
@@ -1,54 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Key;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "GetKeyTest")
-public class GetKeyTest extends BaseItemParserTest<Key> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/key.json";
-   }
-
-   @Override
-   public Key expected() {
-      return new Key(true, ImmutableSet.<String> of("1"), "AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+...", "DEFAULT",
-               new Date(1260428507510l));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetVolumeTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetVolumeTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetVolumeTest.java
deleted file mode 100644
index cf916c3..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/GetVolumeTest.java
+++ /dev/null
@@ -1,50 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Volume;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-@Test(groups = "unit", testName = "GetVolumeTest")
-public class GetVolumeTest extends BaseItemParserTest<Volume> {
-   
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-   
-   @Override
-   public String resource() {
-      return "/volume.json";
-   }
-
-   @Override
-   public Volume expected() {
-      return new Volume("2", 5, 50, "aadelucc@us.ibm.com", new Date(1260469075119l), "1", ImmutableSet.<String> of(),
-               "ext3", "New Storage", "67");
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListAddressesTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListAddressesTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListAddressesTest.java
deleted file mode 100644
index fa691f7..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListAddressesTest.java
+++ /dev/null
@@ -1,48 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.domain.Address;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ListAddressesTest")
-public class ListAddressesTest extends BaseSetParserTest<Address> {
-
-   @Override
-   public String resource() {
-      return "/addresses.json";
-   }
-   
-   @Override
-   @Unwrap
-   public Set<Address> expected() {
-      return ImmutableSet.of(new Address(2, "1", "129.33.196.243", "1217", "1"), new Address(3, "2", "129.33.196.244",
-               "1218", null));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListImagesTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListImagesTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListImagesTest.java
deleted file mode 100644
index 3a55b00..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListImagesTest.java
+++ /dev/null
@@ -1,80 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.http.HttpUtils;
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Image;
-import org.jclouds.ibm.smartcloud.domain.InstanceType;
-import org.jclouds.ibm.smartcloud.domain.Price;
-import org.jclouds.ibm.smartcloud.domain.Image.Visibility;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", singleThreaded = true, testName = "ListImagesTest")
-public class ListImagesTest extends BaseSetParserTest<Image> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/images.json";
-   }
-
-   @Override
-   @Unwrap
-   public Set<Image> expected() {
-      return ImmutableSet
-               .of(new Image(
-                        "SUSE Linux Enterprise Server 11 for x86",
-                        HttpUtils
-                                 .createUri("https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/parameters.xml"),
-                        Image.State.AVAILABLE,
-                        Visibility.PUBLIC,
-                        "SYSTEM",
-                        "SUSE Linux Enterprise Server/11",
-                        Image.Architecture.X86_64,
-                        new Date(1216944000000l),
-                        "41",
-                        ImmutableSet.<InstanceType> of(new InstanceType("Bronze 32 bit", new Price(0.17, "UHR  ",
-                                 "897", null, "USD", 1), "BRZ32.1/2048/175"), new InstanceType("Gold 32 bit",
-                                 new Price(0.41, "UHR  ", "897", null, "USD", 1), "GLD32.4/4096/350"),
-                                 new InstanceType("Silver 32 bit", new Price(0.265, "UHR  ", "897", null, "USD", 1),
-                                          "SLV32.2/4096/350")),
-                        ImmutableSet.<String> of("ifeE7VOzRG6SGvoDlRPTQw"),
-                        HttpUtils
-                                 .createUri("https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/GettingStarted.html"),
-                        "20001150", "SUSE Linux Enterprise Server 11 for x86 Base OS 32-bit with pay for use licensing"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListInstancesTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListInstancesTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListInstancesTest.java
deleted file mode 100644
index d0c1b12..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListInstancesTest.java
+++ /dev/null
@@ -1,66 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.IP;
-import org.jclouds.ibm.smartcloud.domain.Instance;
-import org.jclouds.ibm.smartcloud.domain.Instance.Software;
-import org.jclouds.ibm.smartcloud.domain.Instance.Status;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ListInstancesTest")
-public class ListInstancesTest extends BaseSetParserTest<Instance> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/instances.json";
-   }
-
-   @Override
-   @Unwrap
-   public Set<Instance> expected() {
-
-      return ImmutableSet.of(Instance.builder().launchTime(new Date(1305351683883l)).software(
-               ImmutableSet.of(new Software("SUSE Linux Enterprise Server", "OS", "11 SP1"))).primaryIP(
-               new IP("                ", "                ", 0)).requestId("80890").keyName("adriancole").name("adriancole").instanceType(
-               "COP32.1/2048/60").status(Status.NEW).owner("adrian@cloudconscious.com").location("101").imageId(
-               "20015393").rootOnly(true).requestName("adriancole").id("80590")
-               .expirationTime(new Date(1368423692824l)).diskSize(60).build());
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListKeysTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListKeysTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListKeysTest.java
deleted file mode 100644
index f8fa767..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListKeysTest.java
+++ /dev/null
@@ -1,58 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Key;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ListKeyesTest")
-public class ListKeysTest extends BaseSetParserTest<Key> {
-   
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-   
-   @Override
-   public String resource() {
-      return "/keys.json";
-   }
-
-   @Override
-   @Unwrap
-   public Set<Key> expected() {
-      return ImmutableSet.of(new Key(true, ImmutableSet.<String> of("1"), "AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+...",
-               "DEFAULT", new Date(1260428507510l)), new Key(false, ImmutableSet.<String> of(),
-               "AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+", "BEAR", new Date(1260428507511l)));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListStorageOfferingsTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListStorageOfferingsTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListStorageOfferingsTest.java
deleted file mode 100644
index 78bbde9..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListStorageOfferingsTest.java
+++ /dev/null
@@ -1,66 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Price;
-import org.jclouds.ibm.smartcloud.domain.StorageOffering;
-import org.jclouds.ibm.smartcloud.domain.StorageOffering.Format;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ListStorageOfferingsTest")
-public class ListStorageOfferingsTest extends BaseSetParserTest<StorageOffering> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/storage-offerings.json";
-   }
-
-   @Override
-   @Unwrap
-   public Set<StorageOffering> expected() {
-      return ImmutableSet.of(//
-               new StorageOffering("41", new Price(0.039, "UHR", "897", new Date(1279497600000l), "USD", 1), 256,
-                        "Small", "20001208", ImmutableSet.of(new Format("ext3", "EXT3"))),//
-               new StorageOffering("41", new Price(0.312, "UHR", "897", new Date(1279497600000l), "USD", 1), 2048,
-                        "Large", "20001210", ImmutableSet.of(new Format("ext3", "EXT3"))),//
-               new StorageOffering("41", new Price(0.078, "UHR", "897", new Date(1279497600000l), "USD", 1), 512,
-                        "Medium", "20001209", ImmutableSet.of(new Format("ext3", "EXT3")))//
-               );
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListVolumesTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListVolumesTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListVolumesTest.java
deleted file mode 100644
index dae398c..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/ListVolumesTest.java
+++ /dev/null
@@ -1,57 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Volume;
-import org.jclouds.json.BaseSetParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ListVolumesTest")
-public class ListVolumesTest extends BaseSetParserTest<Volume> {
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/volumes.json";
-   }
-
-   @Override
-   @Unwrap
-   public Set<Volume> expected() {
-      return ImmutableSet.of(new Volume("2", 5, 50, "aadelucc@us.ibm.com", new Date(1260469075119l), "1", ImmutableSet
-               .<String> of(), "ext3", "New Storage", "67"), new Volume(null, 6, 51, "aadelucc@us.ibm.com", new Date(
-               1260469075120l), "2", ImmutableSet.<String> of("abrad"), "ext3", "New Storage1", "68"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/NewInstanceTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/NewInstanceTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/NewInstanceTest.java
deleted file mode 100644
index 6788f0b..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/parse/NewInstanceTest.java
+++ /dev/null
@@ -1,62 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.parse;
-
-import java.util.Date;
-import java.util.Set;
-
-import org.jclouds.ibm.smartcloud.config.IBMSmartCloudParserModule;
-import org.jclouds.ibm.smartcloud.domain.Instance;
-import org.jclouds.ibm.smartcloud.domain.Instance.Software;
-import org.jclouds.ibm.smartcloud.domain.Instance.Status;
-import org.jclouds.json.BaseItemParserTest;
-import org.jclouds.json.config.GsonModule;
-import org.jclouds.rest.annotations.Unwrap;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "GetInstanceTest")
-public class NewInstanceTest extends BaseItemParserTest<Instance> {
-
-   protected Injector injector() {
-      return Guice.createInjector(new GsonModule(), new IBMSmartCloudParserModule());
-   }
-
-   @Override
-   public String resource() {
-      return "/new_instance.json";
-   }
-
-   @Override
-   @Unwrap(depth = 2, edgeCollection = Set.class)
-   public Instance expected() {
-      return Instance.builder().launchTime(new Date(1305359078796l)).software(
-               ImmutableSet.of(new Software("SUSE Linux Enterprise Server", "OS", "11 SP1"))).requestId("80904")
-               .keyName("adriancole").name("adriancole").instanceType("COP32.1/2048/60").status(Status.NEW).owner(
-                        "adrian@cloudconscious.com").location("101").imageId("20015393").requestName("adriancole").id(
-                        "80604").expirationTime(new Date(1368431087355l)).build();
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationHandlerTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationHandlerTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationHandlerTest.java
deleted file mode 100644
index 9cb56d9..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationHandlerTest.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.ibm.smartcloud.domain.Location;
-import org.jclouds.ibm.smartcloud.reference.Capabilities;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableMap;
-
-/**
- * Tests behavior of {@code LocationHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "LocationHandlerTest")
-public class LocationHandlerTest extends BaseHandlerTest {
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/location.xml");
-
-      Location result = factory.create(injector.getInstance(LocationHandler.class)).parse(is);
-
-      Location expects = Location.builder().id("41").name("RTP").description("RTP usrdtsa0a1ccxra").location("RTP")
-               .state(Location.State.ONLINE).capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64)
-               .capability(Capabilities.CAPABILITY_AVAILABILITYAREA).build();
-
-      assertEquals(result.toString(), expects.toString());
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationsHandlerTest.java
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationsHandlerTest.java b/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationsHandlerTest.java
deleted file mode 100644
index 061748c..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/java/org/jclouds/ibm/smartcloud/xml/LocationsHandlerTest.java
+++ /dev/null
@@ -1,90 +0,0 @@
-/**
- * Licensed to jclouds, Inc. (jclouds) under one or more
- * contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  jclouds 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.jclouds.ibm.smartcloud.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.ibm.smartcloud.domain.Location;
-import org.jclouds.ibm.smartcloud.reference.Capabilities;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableMap;
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code LocationsHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit", testName = "ibm.smartcloud.LocationsHandlerTest")
-public class LocationsHandlerTest extends BaseHandlerTest {
-
-   @Test
-   public void testAllLocations() {
-      InputStream is = getClass().getResourceAsStream("/locations.xml");
-
-      Set<? extends Location> result = factory.create(injector.getInstance(LocationsHandler.class)).parse(is);
-
-      Set<? extends Location> expects = ImmutableSet.of(Location.builder().id("41").name("RTP").description(
-               "RTP usrdtsa0a1ccxra").location("RTP").state(Location.State.ONLINE).capability(
-               Capabilities.CAPABILITY_FORMAT, ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw"))
-               .capability(Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build(),
-
-      Location.builder().id("61").name("EHN").location("EHN").state(Location.State.ONLINE)
-               .capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build(),
-
-               Location.builder().id("82").name("us-co-dc1").description("BLD main DC").location("us-co-dc1").state(
-                        Location.State.ONLINE).capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build(),
-
-               Location.builder().id("101").name("ca-on-dc1").description("Data Center 1 at Ontario, Canada").location(
-                        "ca-on-dc1").state(Location.State.ONLINE).capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build(),
-
-               Location.builder().id("121").name("ap-jp-dc1").description("Data Center 1 at Makuhari, Japan").location(
-                        "ap-jp-dc1").state(Location.State.ONLINE).capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build(),
-
-               Location.builder().id("141").name("ap-sg-dc1").description("Data Center 1 at Singapore").location(
-                        "ap-sg-dc1").state(Location.State.ONLINE).capability(Capabilities.CAPABILITY_FORMAT,
-                        ImmutableMap.<String, String> of("EXT3", "ext3", "RAW", "raw")).capability(
-                        Capabilities.CAPABILITY_I386).capability(Capabilities.CAPABILITY_x86_64).capability(
-                        Capabilities.CAPABILITY_AVAILABILITYAREA).build()
-
-      );
-
-      assertEquals(result.toString(), expects.toString());
-
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/address.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/address.json b/sandbox-providers/ibm-smartcloud/src/test/resources/address.json
deleted file mode 100644
index 3cbae65..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/address.json
+++ /dev/null
@@ -1,7 +0,0 @@
-{
-"state":2,
-"location":"1", 
-"ip": "129.33.196.243", 
-"id":"1217",
-"instanceId":"1"
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/addresses.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/addresses.json b/sandbox-providers/ibm-smartcloud/src/test/resources/addresses.json
deleted file mode 100644
index e23b8ee..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/addresses.json
+++ /dev/null
@@ -1,16 +0,0 @@
-{"addresses": [
-{
-"state":2,
-"location":"1", 
-"ip": "129.33.196.243", 
-"id":"1217",
-"instanceId":"1"
-},
-{
-"state":3,
-"location":"2", 
-"ip": "129.33.196.244", 
-"id":"1218"
-}
-]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/image.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/image.json b/sandbox-providers/ibm-smartcloud/src/test/resources/image.json
deleted file mode 100644
index 7d68ce5..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/image.json
+++ /dev/null
@@ -1,51 +0,0 @@
-    {
-        "name": "SUSE Linux Enterprise Server 11 for x86",
-        "manifest": "https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/parameters.xml",
-        "state": 1,
-        "visibility": "PUBLIC",
-        "owner": "SYSTEM",
-        "architecture": "i386",
-        "platform": "SUSE Linux Enterprise Server/11",
-        "createdTime": 1216944000000,
-        "location": "41",
-        "supportedInstanceTypes": [{
-            "label": "Bronze 32 bit",
-            "price": {
-                "rate": 0.17,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "BRZ32.1/2048/175"
-        },
-        {
-            "label": "Gold 32 bit",
-            "price": {
-                "rate": 0.41,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "GLD32.4/4096/350"
-        },
-        {
-            "label": "Silver 32 bit",
-            "price": {
-                "rate": 0.265,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "SLV32.2/4096/350"
-        }],
-        "productCodes": ["ifeE7VOzRG6SGvoDlRPTQw"],
-        "documentation": "https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/GettingStarted.html",
-        "id": "20001150",
-        "description": "SUSE Linux Enterprise Server 11 for x86 Base OS 32-bit with pay for use licensing"
-    }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/images.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/images.json b/sandbox-providers/ibm-smartcloud/src/test/resources/images.json
deleted file mode 100644
index f68f1a6..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/images.json
+++ /dev/null
@@ -1,55 +0,0 @@
-{"images":
-  [{
-    
-        "name": "SUSE Linux Enterprise Server 11 for x86",
-        "manifest": "https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/parameters.xml",
-        "state": 1,
-        "visibility": "PUBLIC",
-        "owner": "SYSTEM",
-        "architecture": "x86_64",
-        "platform": "SUSE Linux Enterprise Server/11",
-        "createdTime": 1216944000000,
-        "location": "41",
-        "supportedInstanceTypes": [{
-            "label": "Bronze 32 bit",
-            "price": {
-                "rate": 0.17,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "BRZ32.1/2048/175"
-        },
-        {
-            "label": "Gold 32 bit",
-            "price": {
-                "rate": 0.41,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "GLD32.4/4096/350"
-        },
-        {
-            "label": "Silver 32 bit",
-            "price": {
-                "rate": 0.265,
-                "unitOfMeasure": "UHR  ",
-                "countryCode": "897",
-                "effectiveDate": -1,
-                "currencyCode": "USD",
-                "pricePerQuantity": 1
-            },
-            "id": "SLV32.2/4096/350"
-        }],
-        "productCodes": ["ifeE7VOzRG6SGvoDlRPTQw"],
-        "documentation": "https://www-147.ibm.com/cloud/enterprise/ram.ws/RAMSecure/artifact/{F006D027-02CC-9D08-D389-6C729D939D44}/1.0/GettingStarted.html",
-        "id": "20001150",
-        "description": "SUSE Linux Enterprise Server 11 for x86 Base OS 32-bit with pay for use licensing"
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/instance.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/instance.json b/sandbox-providers/ibm-smartcloud/src/test/resources/instance.json
deleted file mode 100644
index e453a80..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/instance.json
+++ /dev/null
@@ -1,29 +0,0 @@
-{
-        "launchTime": 1305351683883,
-        "software": [{
-            "version": "11 SP1",
-            "type": "OS",
-            "name": "SUSE Linux Enterprise Server"
-        }],
-        "primaryIP": {
-            "hostname": "                ",
-            "ip": "                ",
-            "type": 0
-        },
-        "requestId": "80890",
-        "keyName": "adriancole",
-        "name": "adriancole",
-        "instanceType": "COP32.1/2048/60",
-        "status": 0,
-        "owner": "adrian@cloudconscious.com",
-        "location": "101",
-        "imageId": "20015393",
-        "root-only": "true",
-        "productCodes": [],
-        "volumes": [],
-        "requestName": "adriancole",
-        "id": "80590",
-        "secondaryIP": [],
-        "expirationTime": 1368423692824,
-        "diskSize": "60"
-    }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/instances.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/instances.json b/sandbox-providers/ibm-smartcloud/src/test/resources/instances.json
deleted file mode 100644
index c842afe..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/instances.json
+++ /dev/null
@@ -1,31 +0,0 @@
-{
-    "instances": [{
-        "launchTime": 1305351683883,
-        "software": [{
-            "version": "11 SP1",
-            "type": "OS",
-            "name": "SUSE Linux Enterprise Server"
-        }],
-        "primaryIP": {
-            "hostname": "                ",
-            "ip": "                ",
-            "type": 0
-        },
-        "requestId": "80890",
-        "keyName": "adriancole",
-        "name": "adriancole",
-        "instanceType": "COP32.1/2048/60",
-        "status": 0,
-        "owner": "adrian@cloudconscious.com",
-        "location": "101",
-        "imageId": "20015393",
-        "root-only": "true",
-        "productCodes": [],
-        "volumes": [],
-        "requestName": "adriancole",
-        "id": "80590",
-        "secondaryIP": [],
-        "expirationTime": 1368423692824,
-        "diskSize": "60"
-    }]
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/key.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/key.json b/sandbox-providers/ibm-smartcloud/src/test/resources/key.json
deleted file mode 100644
index e6dfefc..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/key.json
+++ /dev/null
@@ -1,7 +0,0 @@
-{
-"default":true,
-"instanceIds":["1"],
-"keyMaterial":"AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+...",
-"keyName":"DEFAULT",
-"lastModifiedTime":1260428507510
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/23d9d901/sandbox-providers/ibm-smartcloud/src/test/resources/keys.json
----------------------------------------------------------------------
diff --git a/sandbox-providers/ibm-smartcloud/src/test/resources/keys.json b/sandbox-providers/ibm-smartcloud/src/test/resources/keys.json
deleted file mode 100644
index bd119d6..0000000
--- a/sandbox-providers/ibm-smartcloud/src/test/resources/keys.json
+++ /dev/null
@@ -1,18 +0,0 @@
-{
-"keys":[ 
-{
-"default":true,
-"instanceIds":["1"],
-"keyMaterial":"AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+...",
-"keyName":"DEFAULT",
-"lastModifiedTime":1260428507510
-},
-{
-"default":false,
-"instanceIds":[],
-"keyMaterial":"AAAB3NzaC1yc2EAAAADAQABAAABAQCqBw7a+",
-"keyName":"BEAR",
-"lastModifiedTime":1260428507511
-}
-]
-}
\ No newline at end of file