You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jclouds.apache.org by ad...@apache.org on 2013/09/30 18:15:26 UTC

[06/17] JCLOUDS-304. Remove broken terremark providers

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ResourceAllocationHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ResourceAllocationHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ResourceAllocationHandlerTest.java
deleted file mode 100644
index ed53afd..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ResourceAllocationHandlerTest.java
+++ /dev/null
@@ -1,57 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-
-import org.jclouds.cim.ResourceAllocationSettingData;
-import org.jclouds.cim.ResourceAllocationSettingData.ResourceType;
-import org.jclouds.cim.xml.ResourceAllocationSettingDataHandler;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code ResourceAllocationHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "ResourceAllocationHandlerTest")
-public class ResourceAllocationHandlerTest extends BaseHandlerTest {
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      super.setUpInjector();
-   }
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/item.xml");
-
-      ResourceAllocationSettingData result = factory.create(
-               injector.getInstance(ResourceAllocationSettingDataHandler.class)).parse(is);
-      assertEquals(result.getAddress(), "0");
-      assertEquals(result.getDescription(), "SCSI Controller");
-      assertEquals(result.getElementName(), "SCSI Controller 0");
-      assertEquals(result.getInstanceID(), "3");
-      assertEquals(result.getResourceSubType(), "lsilogic");
-      assertEquals(result.getResourceType(), ResourceType.PARALLEL_SCSI_HBA);
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/SupportedVersionsHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/SupportedVersionsHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/SupportedVersionsHandlerTest.java
deleted file mode 100644
index 2cf068f..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/SupportedVersionsHandlerTest.java
+++ /dev/null
@@ -1,53 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-import java.util.SortedMap;
-
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.http.functions.ParseSax.Factory;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSortedMap;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code SupportedVersionsHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class SupportedVersionsHandlerTest {
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/versions.xml");
-
-      Injector injector = Guice.createInjector(new SaxParserModule());
-      Factory factory = injector.getInstance(ParseSax.Factory.class);
-
-      SortedMap<String, URI> result = factory.create(
-               injector.getInstance(SupportedVersionsHandler.class)).parse(is);
-      assertEquals(result, ImmutableSortedMap.of("0.8", URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/login")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TaskHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TaskHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TaskHandlerTest.java
deleted file mode 100644
index e7c1216..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TaskHandlerTest.java
+++ /dev/null
@@ -1,95 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-import org.jclouds.date.DateService;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType;
-import org.jclouds.trmk.vcloud_0_8.domain.Task;
-import org.jclouds.trmk.vcloud_0_8.domain.TaskStatus;
-import org.jclouds.trmk.vcloud_0_8.domain.VCloudError.MinorCode;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ErrorImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.TaskImpl;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code TaskHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "TaskHandlerTest")
-public class TaskHandlerTest extends BaseHandlerTest {
-
-   private DateService dateService;
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      super.setUpInjector();
-      dateService = injector.getInstance(DateService.class);
-   }
-
-   public void testTerremark() {
-      InputStream is = getClass().getResourceAsStream("/task.xml");
-
-      Task result = factory.create(injector.getInstance(TaskHandler.class)).parse(is);
-      Task expects = new TaskImpl(URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/task/3299"), null,
-            TaskStatus.SUCCESS, dateService.iso8601DateParse("2009-08-24T21:29:32.983Z"),
-            dateService.iso8601DateParse("2009-08-24T21:29:44.65Z"), null, new ReferenceTypeImpl("Server1",
-                  TerremarkVCloudMediaType.VAPP_XML,
-                  URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/4012")), null
-
-      );
-      assertEquals(result, expects);
-
-   }
-
-   public void testSelf() {
-      InputStream is = getClass().getResourceAsStream("/task-self.xml");
-
-      Task result = factory.create(injector.getInstance(TaskHandler.class)).parse(is);
-
-      Task expects = new TaskImpl(URI.create("https://vcloud.safesecureweb.com/api/v0.8/task/d188849-78"), null,
-            TaskStatus.QUEUED, null, null, null, null, null);
-      assertEquals(result, expects);
-
-   }
-
-   public void testError() {
-      InputStream is = getClass().getResourceAsStream("/task-error.xml");
-
-      Task result = factory.create(injector.getInstance(TaskHandler.class)).parse(is);
-
-      Task expects = new TaskImpl(URI.create("http://10.150.4.49/api/v0.8/task/23"), null, TaskStatus.ERROR,
-            dateService.iso8601SecondsDateParse("2009-12-07T19:05:02Z"),
-            dateService.iso8601SecondsDateParse("2009-12-10T14:40:32Z"), null, new ReferenceTypeImpl("testapp1",
-                  TerremarkVCloudMediaType.VAPP_XML, URI.create("http://10.150.4.49/api/v0.8/vapp/1")), new ErrorImpl(
-                  "Error processing job", 500, MinorCode.UNRECOGNIZED,
-                  " Error in runDailySummaries date used:2009-12-09 19:40:30.577326+00:00", null));
-      assertEquals(result, expects);
-
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TasksListHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TasksListHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TasksListHandlerTest.java
deleted file mode 100644
index 7357cd5..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/TasksListHandlerTest.java
+++ /dev/null
@@ -1,74 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-import org.jclouds.date.DateService;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType;
-import org.jclouds.trmk.vcloud_0_8.domain.Task;
-import org.jclouds.trmk.vcloud_0_8.domain.TaskStatus;
-import org.jclouds.trmk.vcloud_0_8.domain.TasksList;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.TaskImpl;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSortedSet;
-
-/**
- * Tests behavior of {@code TasksListHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "TasksListHandlerTest")
-public class TasksListHandlerTest extends BaseHandlerTest {
-
-   private DateService dateService;
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      super.setUpInjector();
-      dateService = injector.getInstance(DateService.class);
-   }
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/taskslist.xml");
-
-      TasksList result = factory.create(injector.getInstance(TasksListHandler.class)).parse(is);
-      assertEquals(result.getLocation(), URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/tasksList/1"));
-      Task task1 = new TaskImpl(URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/task/3300"),
-               null, TaskStatus.SUCCESS, dateService.iso8601DateParse("2009-08-24T21:30:19.587Z"), dateService
-                        .iso8601DateParse("2009-08-24T21:30:32.63Z"), null, new ReferenceTypeImpl("Server1",
-                              TerremarkVCloudMediaType.VAPP_XML, URI
-                                 .create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/4012")), null);
-      Task task2 = new TaskImpl(URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/task/3299"),
-               null, TaskStatus.SUCCESS, dateService.iso8601DateParse("2009-08-24T21:29:32.983Z"), dateService
-                        .iso8601DateParse("2009-08-24T21:29:44.65Z"), null, new ReferenceTypeImpl("Server1",
-                              TerremarkVCloudMediaType.VAPP_XML, URI
-                                 .create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/4012")), null);
-      assertEquals(result.getTasks(), ImmutableSortedSet.of(task1, task2));
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppExtendedInfoHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppExtendedInfoHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppExtendedInfoHandlerTest.java
deleted file mode 100644
index fd4ad50..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppExtendedInfoHandlerTest.java
+++ /dev/null
@@ -1,76 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.ComputePoolReference;
-import org.jclouds.trmk.vcloud_0_8.domain.NetworkAdapter;
-import org.jclouds.trmk.vcloud_0_8.domain.Subnet;
-import org.jclouds.trmk.vcloud_0_8.domain.VAppExtendedInfo;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code VAppExtendedInfoHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "VAppExtendedInfoHandlerTest")
-public class VAppExtendedInfoHandlerTest extends BaseHandlerTest {
-
-   public void test() {
-      InputStream is = getClass().getResourceAsStream("/vapp-ext.xml");
-
-      VAppExtendedInfo result = factory.create(injector.getInstance(VAppExtendedInfoHandler.class)).parse(is);
-      assertEquals(
-               result,
-               VAppExtendedInfo
-                        .builder()
-                        .id("392992")
-                        .href(
-                                 URI
-                                          .create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.8/extensions/vapp/392992"))
-                        .name("instance01")
-                        .networkAdapter(
-                                 NetworkAdapter
-                                          .builder()
-                                          .macAddress("00:50:56:95:12:96")
-                                          .name("Network adapter 1")
-                                          .subnet(
-                                                   Subnet
-                                                            .builder()
-                                                            .href(
-                                                                     URI
-                                                                              .create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.8/extensions/network/43781"))
-                                                            .name("10.122.213.192/27").build()).build())
-                        .computePoolReference(
-                                 ComputePoolReference
-                                          .builder()
-                                          .href(
-                                                   URI
-                                                            .create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.8/extensions/computePool/692"))
-                                          .name(
-
-                                          "Resource Pool 692").build()).build());
-
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppHandlerTest.java
deleted file mode 100644
index 113dc81..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppHandlerTest.java
+++ /dev/null
@@ -1,193 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static com.google.common.collect.Iterables.find;
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-import java.net.UnknownHostException;
-import java.util.List;
-import java.util.Properties;
-
-import org.jclouds.Constants;
-import org.jclouds.cim.CIMPredicates;
-import org.jclouds.cim.ResourceAllocationSettingData;
-import org.jclouds.cim.ResourceAllocationSettingData.ResourceType;
-import org.jclouds.cim.VirtualSystemSettingData;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType;
-import org.jclouds.trmk.vcloud_0_8.domain.Status;
-import org.jclouds.trmk.vcloud_0_8.domain.VApp;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableList;
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Iterables;
-import com.google.common.collect.Lists;
-import com.google.inject.AbstractModule;
-import com.google.inject.Guice;
-import com.google.inject.name.Names;
-
-/**
- * Tests behavior of {@code VAppHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "VAppHandlerTest")
-public class VAppHandlerTest extends BaseHandlerTest {
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      injector = Guice.createInjector(new SaxParserModule(), new AbstractModule() {
-
-         @Override
-         protected void configure() {
-            Properties toBind = new Properties();
-            toBind.setProperty(Constants.PROPERTY_API_VERSION, "0.8");
-            Names.bindProperties(binder(), toBind);
-         }
-
-      });
-      factory = injector.getInstance(ParseSax.Factory.class);
-   }
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/launched_vapp.xml");
-
-      VApp result = factory.create(
-               injector.getInstance(VAppHandler.class)).parse(is);
-
-      assertEquals(result.getName(), "adriantest");
-      assertEquals(result.getStatus(), Status.UNRESOLVED);
-
-      assertEquals(result.getSize().longValue(), 4l);
-
-      assertEquals(result.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/13775"));
-      assertEquals(result.getVDC(), new ReferenceTypeImpl(null, "application/vnd.vmware.vcloud.vdc+xml", URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32")));
-
-   }
-
-   public void testGetVApp() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/get_vapp.xml");
-
-      VApp result = factory.create(
-               injector.getInstance(VAppHandler.class)).parse(is);
-
-      assertEquals(result.getName(), "centos-53");
-      assertEquals(result.getStatus(), Status.OFF);
-
-      assertEquals(result.getSize().longValue(), 10485760);
-      assertEquals(result.getOperatingSystemDescription(), "Red Hat Enterprise Linux 5 (64-bit)");
-
-      assertEquals(result.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/16238"));
-      assertEquals(result.getVDC(), new ReferenceTypeImpl(null, TerremarkVCloudMediaType.VDC_XML, URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32")));
-
-      VirtualSystemSettingData system = VirtualSystemSettingData.builder().instanceID("0").elementName(
-               "Virtual Hardware Family").virtualSystemIdentifier("centos-53").virtualSystemType("vmx-07").build();
-      assertEquals(result.getSystem().toString(), system.toString());
-      assertEquals(result.getNetworkToAddresses().get("Internal"), ImmutableList.<String> of("10.114.34.132"));
-
-      ResourceAllocationSettingData cpu = ResourceAllocationSettingData.builder().instanceID("1").elementName(
-               "1 virtual CPU(s)").description("Number of Virtual CPUs").resourceType(ResourceType.PROCESSOR)
-               .virtualQuantity(2l).virtualQuantityUnits("hertz * 10^6").build();
-
-      ResourceAllocationSettingData controller = ResourceAllocationSettingData.builder().instanceID("3").elementName(
-               "SCSI Controller 0").description("SCSI Controller").resourceType(ResourceType.PARALLEL_SCSI_HBA)
-               .resourceSubType("lsilogic").address("0").virtualQuantity(1l).build();
-      ResourceAllocationSettingData memory = ResourceAllocationSettingData.builder().instanceID("2").elementName(
-               "512MB of memory").description("Memory Size").resourceType(ResourceType.MEMORY).virtualQuantity(512l)
-               .virtualQuantityUnits("byte * 2^20").build();
-      ResourceAllocationSettingData disk = ResourceAllocationSettingData.builder().instanceID("9").elementName(
-               "Hard Disk 1").resourceType(ResourceType.DISK_DRIVE).hostResource("10485760").addressOnParent("0")
-               .virtualQuantity(10485760l).virtualQuantityUnits("byte * 2^20").build();
-      assertEquals(result.getResourceAllocations(), ImmutableSet.of(cpu, memory, controller, disk));
-      assertEquals(find(result.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.PROCESSOR))
-               .getVirtualQuantity().intValue(), 1);
-      find(result.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.PARALLEL_SCSI_HBA));
-
-      assertEquals(find(result.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.MEMORY))
-               .getVirtualQuantity().intValue(), 512);
-      assertEquals(find(result.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.DISK_DRIVE))
-               .getVirtualQuantity().longValue(), 10485760);
-      assertEquals(result.getSize().longValue(), find(result.getResourceAllocations(),
-               CIMPredicates.resourceTypeIn(ResourceType.DISK_DRIVE)).getVirtualQuantity().longValue());
-   }
-
-   public void testGetVApp2disks() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/get_vapp2disks.xml");
-
-      VApp vApp = factory.create(injector.getInstance(VAppHandler.class)).parse(is);
-
-      assertEquals(vApp.getName(), "eduardo");
-      assertEquals(vApp.getStatus(), Status.OFF);
-
-      assertEquals(vApp.getSize().longValue(), 30408704);
-      assertEquals(vApp.getOperatingSystemDescription(), "Ubuntu Linux (32-bit)");
-
-      assertEquals(vApp.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/15639"));
-      assertEquals(vApp.getVDC(), new ReferenceTypeImpl(null, TerremarkVCloudMediaType.VDC_XML, URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32")));
-      VirtualSystemSettingData system = VirtualSystemSettingData.builder().instanceID("0").elementName(
-               "Virtual Hardware Family").virtualSystemIdentifier("eduardo").virtualSystemType("vmx-07").build();
-      assertEquals(vApp.getSystem().toString(), system.toString());
-
-      assertEquals(vApp.getNetworkToAddresses().get("Internal"), ImmutableList.of("10.114.34.131"));
-
-      ResourceAllocationSettingData cpu = ResourceAllocationSettingData.builder().instanceID("1").elementName(
-               "2 virtual CPU(s)").description("Number of Virtual CPUs").resourceType(ResourceType.PROCESSOR)
-               .virtualQuantity(2l).virtualQuantityUnits("hertz * 10^6").build();
-
-      ResourceAllocationSettingData controller = ResourceAllocationSettingData.builder().instanceID("3").elementName(
-               "SCSI Controller 0").description("SCSI Controller").resourceType(ResourceType.PARALLEL_SCSI_HBA)
-               .resourceSubType("lsilogic").address("0").virtualQuantity(1l).build();
-      ResourceAllocationSettingData memory = ResourceAllocationSettingData.builder().instanceID("2").elementName(
-               "1024MB of memory").description("Memory Size").resourceType(ResourceType.MEMORY).virtualQuantity(1024l)
-               .virtualQuantityUnits("byte * 2^20").build();
-      ResourceAllocationSettingData disk = ResourceAllocationSettingData.builder().instanceID("9").elementName(
-               "Hard Disk 1").resourceType(ResourceType.DISK_DRIVE).hostResource("4194304").addressOnParent("0")
-               .virtualQuantity(4194304l).virtualQuantityUnits("byte * 2^20").build();
-      ResourceAllocationSettingData disk2 = ResourceAllocationSettingData.builder().instanceID("9").elementName(
-               "Hard Disk 2").resourceType(ResourceType.DISK_DRIVE).hostResource("26214400").addressOnParent("1")
-               .virtualQuantity(26214400l).virtualQuantityUnits("byte * 2^20").build();
-
-      assertEquals(vApp.getResourceAllocations(), ImmutableSet.of(cpu, memory, controller, disk, disk2));
-      assertEquals(find(vApp.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.PROCESSOR))
-               .getVirtualQuantity().intValue(), 2);
-      find(vApp.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.PARALLEL_SCSI_HBA));
-      assertEquals(find(vApp.getResourceAllocations(), CIMPredicates.resourceTypeIn(ResourceType.MEMORY))
-               .getVirtualQuantity().longValue(), 1024);
-
-      // extract the disks on the vApp sorted by addressOnParent
-      List<ResourceAllocationSettingData> disks = Lists.newArrayList(Iterables.filter(vApp.getResourceAllocations(),
-               CIMPredicates.resourceTypeIn(ResourceType.DISK_DRIVE)));
-
-      assertEquals(disks.get(0).getVirtualQuantity().longValue(), 4194304);
-      assertEquals(disks.get(1).getVirtualQuantity().longValue(), 26214400);
-
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppTemplateHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppTemplateHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppTemplateHandlerTest.java
deleted file mode 100644
index f071053..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VAppTemplateHandlerTest.java
+++ /dev/null
@@ -1,55 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.http.functions.ParseSax.Factory;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.domain.VAppTemplate;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.VAppTemplateImpl;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code VAppTemplateHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class VAppTemplateHandlerTest {
-
-   private Injector injector;
-
-   private Factory factory;
-
-   public void testTerremark() {
-      InputStream is = getClass().getResourceAsStream("/vAppTemplate-trmk.xml");
-      injector = Guice.createInjector(new SaxParserModule());
-      factory = injector.getInstance(ParseSax.Factory.class);
-      VAppTemplate result = factory.create(injector.getInstance(VAppTemplateHandler.class)).parse(is);
-      assertEquals(result, new VAppTemplateImpl("CentOS 5.3 (32-bit)", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/vAppTemplate/5"),
-            "description of CentOS 5.3 (32-bit)", null));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VDCHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VDCHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VDCHandlerTest.java
deleted file mode 100644
index d128452..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/VDCHandlerTest.java
+++ /dev/null
@@ -1,79 +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.jclouds.trmk.vcloud_0_8.xml;
-
-import static org.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType.CATALOG_XML;
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.http.functions.ParseSax.Factory;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType;
-import org.jclouds.trmk.vcloud_0_8.domain.ReferenceType;
-import org.jclouds.trmk.vcloud_0_8.domain.VDC;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableMap;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code VDCHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class VDCHandlerTest {
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/vdc.xml");
-      Injector injector = Guice.createInjector(new SaxParserModule());
-      Factory factory = injector.getInstance(ParseSax.Factory.class);
-
-      VDC result = factory.create(injector.getInstance(VDCHandler.class)).parse(is);
-      assertEquals(result.getName(), "Miami Environment 1");
-      assertEquals(result.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32"));
-      assertEquals(result.getResourceEntities(), ImmutableMap.<String, ReferenceType> of(
-            "adriantest",
-            new ReferenceTypeImpl("adriantest", TerremarkVCloudMediaType.VAPP_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/15124")),
-            "centos-53",
-            new ReferenceTypeImpl("centos-53", TerremarkVCloudMediaType.VAPP_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/vapp/15120"))));
-
-      assertEquals(result.getAvailableNetworks(), ImmutableMap.of(
-            "10.114.34.128/26",
-            new ReferenceTypeImpl("10.114.34.128/26", "application/vnd.vmware.vcloud.network+xml", URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/network/1708"))));
-      assertEquals(
-            result.getCatalog(),
-            new ReferenceTypeImpl("Miami Environment 1", CATALOG_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32/catalog")));
-      assertEquals(
-            result.getPublicIps(),
-            new ReferenceTypeImpl("Public IPs", "application/xml", URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32/publicIps")));
-      assertEquals(
-            result.getInternetServices(),
-            new ReferenceTypeImpl("Internet Services", "application/xml", URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32/internetServices")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/SystemHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/SystemHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/SystemHandlerTest.java
deleted file mode 100644
index cc82e33..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/SystemHandlerTest.java
+++ /dev/null
@@ -1,56 +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.jclouds.trmk.vcloud_0_8.xml.ovf;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-
-import org.jclouds.cim.VirtualSystemSettingData;
-import org.jclouds.cim.xml.VirtualSystemSettingDataHandler;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code SystemHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "SystemHandlerTest")
-public class SystemHandlerTest extends BaseHandlerTest {
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      super.setUpInjector();
-   }
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/system.xml");
-
-      VirtualSystemSettingData result = factory.create(injector.getInstance(VirtualSystemSettingDataHandler.class))
-               .parse(is);
-      assertEquals(result.getElementName(), "Virtual Hardware Family");
-      assertEquals(result.getInstanceID(), "0");
-      assertEquals(result.getVirtualSystemIdentifier(), "adriantest1");
-      assertEquals(result.getVirtualSystemTypes(), ImmutableSet.of("vmx-07"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/VAppHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/VAppHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/VAppHandlerTest.java
deleted file mode 100644
index ae8a8dc..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/ovf/VAppHandlerTest.java
+++ /dev/null
@@ -1,182 +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.jclouds.trmk.vcloud_0_8.xml.ovf;
-
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-import java.net.UnknownHostException;
-import java.util.Properties;
-import java.util.Set;
-
-import org.jclouds.Constants;
-import org.jclouds.cim.ResourceAllocationSettingData;
-import org.jclouds.cim.ResourceAllocationSettingData.ResourceType;
-import org.jclouds.cim.VirtualSystemSettingData;
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.domain.Status;
-import org.jclouds.trmk.vcloud_0_8.domain.VApp;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.VAppImpl;
-import org.jclouds.trmk.vcloud_0_8.xml.VAppHandler;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableListMultimap;
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.ListMultimap;
-import com.google.inject.AbstractModule;
-import com.google.inject.Guice;
-import com.google.inject.name.Names;
-
-/**
- * Tests behavior of {@code VCloudExpressVAppHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "VCloudExpressVAppHandlerTest")
-public class VAppHandlerTest extends BaseHandlerTest {
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      injector = Guice.createInjector(new SaxParserModule(), new AbstractModule() {
-
-         @Override
-         protected void configure() {
-            Properties toBind = new Properties();
-            toBind.setProperty(Constants.PROPERTY_API_VERSION, "0.8");
-            Names.bindProperties(binder(), toBind);
-         }
-
-      });
-      factory = injector.getInstance(ParseSax.Factory.class);
-   }
-
-   public void testInstantiated() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/instantiatedvapp.xml");
-
-      VApp result = factory.create(injector.getInstance(VAppHandler.class)).parse(is);
-
-      VApp expects = new VAppImpl("centos53", URI
-               .create("http://10.150.4.49/api/v0.8/vApp/10"), Status.RESOLVED, 123456789l, new ReferenceTypeImpl(null,
-               "application/vnd.vmware.vcloud.vdc+xml", URI.create("http://10.150.4.49/api/v0.8/vdc/4")),
-               ImmutableListMultimap.<String, String> of(), null, null, null, ImmutableSet
-                        .<ResourceAllocationSettingData> of());
-      assertEquals(result, expects);
-   }
-
-   public void testDefault() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/vapp.xml");
-
-      VApp result = factory.create(injector.getInstance(VAppHandler.class)).parse(is);
-
-      ListMultimap<String, String> networkToAddresses = ImmutableListMultimap.<String, String> of("Public Network",
-               "10.150.4.93");
-
-      VirtualSystemSettingData system = VirtualSystemSettingData.builder().instanceID("0").elementName(
-               "Virtual Hardware Family").virtualSystemIdentifier("centos53").virtualSystemType("vmx-07").build();
-
-      Set<ResourceAllocationSettingData> resourceAllocations = ImmutableSet.<ResourceAllocationSettingData> of(
-               ResourceAllocationSettingData.builder().instanceID("1").elementName("1 virtual CPU(s)").description(
-                        "Number of Virtual CPUs").resourceType(ResourceType.PROCESSOR).virtualQuantity(1l)
-                        .allocationUnits("hertz * 10^6").virtualQuantityUnits("count").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("2").elementName("16MB of memory").description(
-                        "Memory Size").resourceType(ResourceType.MEMORY).virtualQuantity(16l).allocationUnits(
-                        "byte * 2^20").virtualQuantityUnits("byte * 2^20").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("3").elementName("SCSI Controller 0").description(
-                        "SCSI Controller").resourceType(ResourceType.PARALLEL_SCSI_HBA).resourceSubType("lsilogic")
-                        .address("0").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("8").elementName("Network Adapter 1").description(
-                        "PCNet32 ethernet adapter on \"Internal\" network").resourceType(ResourceType.ETHERNET_ADAPTER)
-                        .resourceSubType("PCNet32").addressOnParent("7").connection("Internal").automaticAllocation(
-                                 true).build(),
-
-               ResourceAllocationSettingData.builder().instanceID("9").elementName("Hard Disk 1").resourceType(
-                        ResourceType.DISK_DRIVE).hostResource("104857").addressOnParent("0").parent("3")
-                        .virtualQuantity(104857l).build());
-
-      VApp expects = new VAppImpl("centos53", URI
-               .create("http://10.150.4.49/api/v0.8/vApp/10"), Status.ON, Long.valueOf(104857), new ReferenceTypeImpl(null,
-               "application/vnd.vmware.vcloud.vdc+xml", URI.create("http://10.150.4.49/api/v0.8/vdc/4")),
-               networkToAddresses, null, "Other Linux (32-bit)", system, resourceAllocations);
-      assertEquals(result.getHref(), expects.getHref());
-      assertEquals(result.getName(), expects.getName());
-      assertEquals(result.getNetworkToAddresses(), expects.getNetworkToAddresses());
-      assertEquals(result.getOperatingSystemDescription(), expects.getOperatingSystemDescription());
-      assertEquals(result.getResourceAllocations().toString(), expects.getResourceAllocations().toString());
-      assertEquals(result.getSize(), expects.getSize());
-      assertEquals(result.getStatus(), expects.getStatus());
-      assertEquals(result.getSystem().toString(), expects.getSystem().toString());
-      assertEquals(result.getType(), expects.getType());
-      assertEquals(result.getVDC(), expects.getVDC());
-   }
-
-   public void testLatest() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/vapp2.xml");
-
-      VApp result = factory.create(injector.getInstance(VAppHandler.class)).parse(is);
-
-      ListMultimap<String, String> networkToAddresses = ImmutableListMultimap.<String, String> of("Public Network",
-               "10.23.119.221");
-      VirtualSystemSettingData system = VirtualSystemSettingData.builder().instanceID("0").elementName(
-               "Virtual Hardware Family").virtualSystemIdentifier("m1").virtualSystemType("vmx-07").build();
-
-      Set<ResourceAllocationSettingData> resourceAllocations = ImmutableSet.<ResourceAllocationSettingData> of(
-               ResourceAllocationSettingData.builder().instanceID("1").elementName("1 virtual CPU(s)").description(
-                        "Number of Virtual CPUs").resourceType(ResourceType.PROCESSOR).virtualQuantity(1l)
-                        .allocationUnits("hertz * 10^6").virtualQuantityUnits("count").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("2").elementName("512MB of memory").description(
-                        "Memory Size").resourceType(ResourceType.MEMORY).virtualQuantity(512l).allocationUnits(
-                        "byte * 2^20").virtualQuantityUnits("byte * 2^20").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("3").elementName("SCSI Controller 0").description(
-                        "SCSI Controller").resourceType(ResourceType.PARALLEL_SCSI_HBA).resourceSubType("lsilogic")
-                        .address("0").build(),
-
-               ResourceAllocationSettingData.builder().instanceID("8").elementName("Network Adapter 1").description(
-                        "PCNet32 ethernet adapter on \"Internal\" network").resourceType(ResourceType.ETHERNET_ADAPTER)
-                        .resourceSubType("PCNet32").addressOnParent("7").connection("Internal").automaticAllocation(
-                                 true).build(),
-
-               ResourceAllocationSettingData.builder().instanceID("9").elementName("Hard Disk 1").resourceType(
-                        ResourceType.DISK_DRIVE).hostResource("10485760").addressOnParent("0").parent("3")
-                        .virtualQuantity(10485760l).build());
-
-      VApp expects = new VAppImpl("m1", URI.create("http://localhost:8000/api/v0.8/vApp/80"),
-               Status.ON, Long.valueOf(10485760), new ReferenceTypeImpl(null, "application/vnd.vmware.vcloud.vdc+xml", URI
-                        .create("http://localhost:8000/api/v0.8/vdc/28")), networkToAddresses, null,
-               "Microsoft Windows XP Professional (32-bit)", system, resourceAllocations);
-      assertEquals(result.getHref(), expects.getHref());
-      assertEquals(result.getName(), expects.getName());
-      assertEquals(result.getNetworkToAddresses(), expects.getNetworkToAddresses());
-      assertEquals(result.getOperatingSystemDescription(), expects.getOperatingSystemDescription());
-      assertEquals(result.getResourceAllocations().toString(), expects.getResourceAllocations().toString());
-      assertEquals(result.getSize(), expects.getSize());
-      assertEquals(result.getStatus(), expects.getStatus());
-      assertEquals(result.getSystem().toString(), expects.getSystem().toString());
-      assertEquals(result.getType(), expects.getType());
-      assertEquals(result.getVDC(), expects.getVDC());
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/ComputeOption.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/ComputeOption.xml b/common/trmk/src/test/resources/ComputeOption.xml
deleted file mode 100644
index 6ba5e98..0000000
--- a/common/trmk/src/test/resources/ComputeOption.xml
+++ /dev/null
@@ -1,6 +0,0 @@
-<ComputeOption xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <ProcessorCount>1</ProcessorCount>
-    <Memory>512</Memory>
-    <CostPerHour>0.0390</CostPerHour>
-</ComputeOption>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/ComputeOptions.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/ComputeOptions.xml b/common/trmk/src/test/resources/ComputeOptions.xml
deleted file mode 100644
index 2dded57..0000000
--- a/common/trmk/src/test/resources/ComputeOptions.xml
+++ /dev/null
@@ -1,13 +0,0 @@
-<ComputeOptions xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <ComputeOption>
-        <ProcessorCount>1</ProcessorCount>
-        <Memory>512</Memory>
-        <CostPerHour>0.0390</CostPerHour>
-    </ComputeOption>
-    <ComputeOption>
-        <ProcessorCount>8</ProcessorCount>
-        <Memory>16384</Memory>
-        <CostPerHour>1.6100</CostPerHour>
-    </ComputeOption>
-</ComputeOptions>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateInternetService-options-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateInternetService-options-test.xml b/common/trmk/src/test/resources/CreateInternetService-options-test.xml
deleted file mode 100644
index 63e3b73..0000000
--- a/common/trmk/src/test/resources/CreateInternetService-options-test.xml
+++ /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.
-
--->
-<CreateInternetServiceRequest
-	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:xsd="http://www.w3.org/2001/XMLSchema"
-	xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<Name>name</Name>
-	<Protocol>TCP</Protocol>
-	<Port>22</Port>
-	<Enabled>false</Enabled>
-	
-	<Description>yahoo</Description>
-	
-</CreateInternetServiceRequest>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateInternetService-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateInternetService-test.xml b/common/trmk/src/test/resources/CreateInternetService-test.xml
deleted file mode 100644
index ae9a632..0000000
--- a/common/trmk/src/test/resources/CreateInternetService-test.xml
+++ /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.
-
--->
-<CreateInternetServiceRequest
-	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:xsd="http://www.w3.org/2001/XMLSchema"
-	xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<Name>name</Name>
-	<Protocol>TCP</Protocol>
-	<Port>22</Port>
-	<Enabled>true</Enabled>
-	
-	<Description>name TCP 22</Description>
-	
-</CreateInternetServiceRequest>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateInternetService-test2.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateInternetService-test2.xml b/common/trmk/src/test/resources/CreateInternetService-test2.xml
deleted file mode 100644
index a95c554..0000000
--- a/common/trmk/src/test/resources/CreateInternetService-test2.xml
+++ /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.
-
--->
-<CreateInternetServiceRequest
-	xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:xsd="http://www.w3.org/2001/XMLSchema"
-	xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<Name>name</Name>
-	<Protocol>TCP</Protocol>
-	<Port>22</Port>
-	<Enabled>true</Enabled>
-	
-	
-</CreateInternetServiceRequest>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateNodeService-options-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateNodeService-options-test.xml b/common/trmk/src/test/resources/CreateNodeService-options-test.xml
deleted file mode 100644
index 96ed09c..0000000
--- a/common/trmk/src/test/resources/CreateNodeService-options-test.xml
+++ /dev/null
@@ -1,27 +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.
-
--->
-<CreateNodeServiceRequest xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-	xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<IpAddress>10.2.2.2</IpAddress>
-	<Name>name</Name>
-	<Port>22</Port>
-	<Enabled>false</Enabled>
-	
-    <Description>yahoo</Description>
-</CreateNodeServiceRequest>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateNodeService-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateNodeService-test.xml b/common/trmk/src/test/resources/CreateNodeService-test.xml
deleted file mode 100644
index fb0cc41..0000000
--- a/common/trmk/src/test/resources/CreateNodeService-test.xml
+++ /dev/null
@@ -1,27 +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.
-
--->
-<CreateNodeServiceRequest xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-	xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<IpAddress>172.16.20.3</IpAddress>
-	<Name>Node for Jim</Name>
-	<Port>80</Port>
-	<Enabled>false</Enabled>
-	
-    <Description>Some test node</Description>
-</CreateNodeServiceRequest>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CreateNodeService-test2.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CreateNodeService-test2.xml b/common/trmk/src/test/resources/CreateNodeService-test2.xml
deleted file mode 100644
index c319bbd..0000000
--- a/common/trmk/src/test/resources/CreateNodeService-test2.xml
+++ /dev/null
@@ -1,26 +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.
-
--->
-<CreateNodeServiceRequest xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-	xmlns:xsd="http://www.w3.org/2001/XMLSchema" xmlns="urn:tmrk:vCloudExpressExtensions-1.6">
-	<IpAddress>10.2.2.2</IpAddress>
-	<Name>name</Name>
-	<Port>22</Port>
-	<Enabled>true</Enabled>
-	
-</CreateNodeServiceRequest>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/CustomizationParameters.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/CustomizationParameters.xml b/common/trmk/src/test/resources/CustomizationParameters.xml
deleted file mode 100644
index bfc2e77..0000000
--- a/common/trmk/src/test/resources/CustomizationParameters.xml
+++ /dev/null
@@ -1,6 +0,0 @@
-<CustomizationParameters xmlns="urn:tmrk:vCloudExpress-1.0"
-	xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-	<CustomizeNetwork>true</CustomizeNetwork>
-	<CustomizePassword>false</CustomizePassword>
-	<CustomizeSSH>false</CustomizeSSH>
-</CustomizationParameters>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InstantiateVAppTemplateParams-options-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InstantiateVAppTemplateParams-options-test.xml b/common/trmk/src/test/resources/InstantiateVAppTemplateParams-options-test.xml
deleted file mode 100644
index a9bd60f..0000000
--- a/common/trmk/src/test/resources/InstantiateVAppTemplateParams-options-test.xml
+++ /dev/null
@@ -1 +0,0 @@
-<InstantiateVAppTemplateParams xmlns="http://www.vmware.com/vcloud/v0.8" xmlns:ovf="http://schemas.dmtf.org/ovf/envelope/1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" name="name" xsi:schemaLocation="http://www.vmware.com/vcloud/v0.8 http://vcloud.safesecureweb.com/ns/vcloud.xsd"><VAppTemplate href="https://vcloud/vAppTemplate/3"/><InstantiationParams><ProductSection xmlns:q1="http://www.vmware.com/vcloud/v0.8"><Property xmlns="http://schemas.dmtf.org/ovf/envelope/1" ovf:key="group" ovf:value="group"/><Property xmlns="http://schemas.dmtf.org/ovf/envelope/1" ovf:key="password" ovf:value="password"/><Property xmlns="http://schemas.dmtf.org/ovf/envelope/1" ovf:key="row" ovf:value="row"/></ProductSection><VirtualHardwareSection xmlns:q1="http://www.vmware.com/vcloud/v0.8"><Item xmlns="http://schemas.dmtf.org/ovf/envelope/1"><InstanceID xmlns="http://schemas.dmtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">1</InstanceID><ResourceType xmlns="http://schemas.d
 mtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">3</ResourceType><VirtualQuantity xmlns="http://schemas.dmtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">2</VirtualQuantity></Item><Item xmlns="http://schemas.dmtf.org/ovf/envelope/1"><InstanceID xmlns="http://schemas.dmtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">2</InstanceID><ResourceType xmlns="http://schemas.dmtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">4</ResourceType><VirtualQuantity xmlns="http://schemas.dmtf.org/wbem/wscim/1/cim-schema/2/CIM_ResourceAllocationSettingData">512</VirtualQuantity></Item></VirtualHardwareSection><NetworkConfigSection><NetworkConfig name="name"><Features><FenceMode>allowInOut</FenceMode></Features><NetworkAssociation href="http://network"/></NetworkConfig></NetworkConfigSection></InstantiationParams></InstantiateVAppTemplateParams>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InstantiateVAppTemplateParams-test.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InstantiateVAppTemplateParams-test.xml b/common/trmk/src/test/resources/InstantiateVAppTemplateParams-test.xml
deleted file mode 100644
index 53e11df..0000000
--- a/common/trmk/src/test/resources/InstantiateVAppTemplateParams-test.xml
+++ /dev/null
@@ -1 +0,0 @@
-<InstantiateVAppTemplateParams xmlns="http://www.vmware.com/vcloud/v0.8" xmlns:ovf="http://schemas.dmtf.org/ovf/envelope/1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" name="name" xsi:schemaLocation="http://www.vmware.com/vcloud/v0.8 http://vcloud.safesecureweb.com/ns/vcloud.xsd"><VAppTemplate href="https://vcloud/vAppTemplate/3"/><InstantiationParams><ProductSection xmlns:q1="http://www.vmware.com/vcloud/v0.8"/><NetworkConfigSection><NetworkConfig name="name"><Features><FenceMode>allowInOut</FenceMode></Features><NetworkAssociation href="https://vcloud.safesecureweb.com/network/1990"/></NetworkConfig></NetworkConfigSection></InstantiationParams></InstantiateVAppTemplateParams>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InternetService.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InternetService.xml b/common/trmk/src/test/resources/InternetService.xml
deleted file mode 100644
index 5290b6a..0000000
--- a/common/trmk/src/test/resources/InternetService.xml
+++ /dev/null
@@ -1,16 +0,0 @@
-<InternetService xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-Instance">
-    <Id>523</Id>
-    <Href i:nil="true" />
-    <Name>IS_for_Jim</Name>
-    <PublicIpAddress>
-        <Id>4208</Id>
-        <Href i:nil="true" />
-        <Name>10.1.22.159</Name>
-    </PublicIpAddress>
-    <Port>80</Port>
-    <Protocol>HTTP</Protocol>
-    <Enabled>false</Enabled>
-    <Timeout>1</Timeout>
-    <Description>Some test service</Description>
-</InternetService> 
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InternetService2.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InternetService2.xml b/common/trmk/src/test/resources/InternetService2.xml
deleted file mode 100644
index c92bd34..0000000
--- a/common/trmk/src/test/resources/InternetService2.xml
+++ /dev/null
@@ -1,17 +0,0 @@
-<InternetService xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <Id>524</Id>
-    <Href>https://services.vcloudexpress.terremark.com/api/v0.8/InternetServices/524</Href>
-    <Name>IS_for_Jim2</Name>
-    <PublicIpAddress>
-        <Id>4208</Id>
-        <Href>https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/4208
-        </Href>
-        <Name>10.1.22.159</Name>
-    </PublicIpAddress>
-    <Port>45</Port>
-    <Protocol>HTTP</Protocol>
-    <Enabled>false</Enabled>
-    <Timeout>1</Timeout>
-    <Description>Some test service</Description>
-</InternetService> 
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InternetServices-2.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InternetServices-2.xml b/common/trmk/src/test/resources/InternetServices-2.xml
deleted file mode 100644
index a35468c..0000000
--- a/common/trmk/src/test/resources/InternetServices-2.xml
+++ /dev/null
@@ -1,155 +0,0 @@
-<InternetServices xmlns="urn:tmrk:eCloudExtensions-2.6"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <InternetService>
-        <Id>18792</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/18792</Href>
-        <Name>cl960b-62752757-443</Name>
-        <PublicIpAddress>
-            <Id>29232</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/29232</Href>
-            <Name>209.251.180.145</Name>
-        </PublicIpAddress>
-        <Port>443</Port>
-        <Protocol>TCP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout>2</Timeout>
-        <Description />
-        <RedirectURL />
-        <Monitor i:nil="true" />
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>SourceIP</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-    <InternetService>
-        <Id>19264</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/19264</Href>
-        <Name>OpenVPN</Name>
-        <PublicIpAddress>
-            <Id>36648</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/36648</Href>
-            <Name>209.251.180.245</Name>
-        </PublicIpAddress>
-        <Port>1194</Port>
-        <Protocol>UDP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout>2</Timeout>
-        <Description />
-        <RedirectURL />
-        <Monitor i:nil="true" />
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>SourceIP</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-    <InternetService>
-        <Id>20870</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/20870</Href>
-        <Name>cid6b2-64d1f1e8-443</Name>
-        <PublicIpAddress>
-            <Id>40097</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/40097</Href>
-            <Name>209.251.181.14</Name>
-        </PublicIpAddress>
-        <Port>443</Port>
-        <Protocol>TCP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout>2</Timeout>
-        <Description />
-        <RedirectURL />
-        <Monitor i:nil="true" />
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>SourceIP</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-    <InternetService>
-        <Id>21170</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/21170</Href>
-        <Name>cic908-6b6a0ac2-443</Name>
-        <PublicIpAddress>
-            <Id>40162</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/40162</Href>
-            <Name>209.251.181.16</Name>
-        </PublicIpAddress>
-        <Port>443</Port>
-        <Protocol>TCP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout i:nil="true" />
-        <Description />
-        <RedirectURL />
-        <Monitor>
-            <MonitorType>Disabled</MonitorType>
-            <UrlSendString i:nil="true" />
-            <HttpHeader i:nil="true" />
-            <ReceiveString i:nil="true" />
-            <Interval>0</Interval>
-            <ResponseTimeOut>0</ResponseTimeOut>
-            <DownTime>0</DownTime>
-            <Retries>0</Retries>
-            <IsEnabled>true</IsEnabled>
-        </Monitor>
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>None</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-    <InternetService>
-        <Id>21319</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/21319</Href>
-        <Name>ci7eeb-7a6baa70-443</Name>
-        <PublicIpAddress>
-            <Id>40203</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/40203</Href>
-            <Name>209.251.181.17</Name>
-        </PublicIpAddress>
-        <Port>443</Port>
-        <Protocol>TCP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout>2</Timeout>
-        <Description />
-        <RedirectURL />
-        <Monitor>
-            <MonitorType>Disabled</MonitorType>
-            <UrlSendString i:nil="true" />
-            <HttpHeader i:nil="true" />
-            <ReceiveString i:nil="true" />
-            <Interval>0</Interval>
-            <ResponseTimeOut>0</ResponseTimeOut>
-            <DownTime>0</DownTime>
-            <Retries>0</Retries>
-            <IsEnabled>true</IsEnabled>
-        </Monitor>
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>SourceIP</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-    <InternetService>
-        <Id>13798</Id>
-        <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/internetService/13798</Href>
-        <Name>cl8116-4df02afd-443</Name>
-        <PublicIpAddress>
-            <Id>48625</Id>
-            <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.6/extensions/publicIp/48625</Href>
-            <Name>209.251.181.60</Name>
-        </PublicIpAddress>
-        <Port>443</Port>
-        <Protocol>TCP</Protocol>
-        <Enabled>true</Enabled>
-        <Timeout>2</Timeout>
-        <Description />
-        <RedirectURL />
-        <Monitor i:nil="true" />
-        <IsBackupService>false</IsBackupService>
-        <BackupService i:nil="true" />
-        <BackupOf />
-        <PersistenceType>SourceIP</PersistenceType>
-        <TrustedNetworkGroup i:nil="true" />
-    </InternetService>
-</InternetServices>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/InternetServices.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/InternetServices.xml b/common/trmk/src/test/resources/InternetServices.xml
deleted file mode 100644
index 3c1019f..0000000
--- a/common/trmk/src/test/resources/InternetServices.xml
+++ /dev/null
@@ -1,20 +0,0 @@
-<InternetServices xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <InternetService>
-        <Id>524</Id>
-        <Href>https://services.vcloudexpress.terremark.com/api/v0.8/InternetServices/524
-        </Href>
-        <Name>IS_for_Jim2</Name>
-        <PublicIpAddress>
-            <Id>4208</Id>
-            <Href>https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/4208
-            </Href>
-            <Name>10.1.22.159</Name>
-        </PublicIpAddress>
-        <Port>45</Port>
-        <Protocol>HTTP</Protocol>
-        <Enabled>false</Enabled>
-        <Timeout>1</Timeout>
-        <Description>Some test service</Description>
-    </InternetService>
-</InternetServices>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/NodeService.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/NodeService.xml b/common/trmk/src/test/resources/NodeService.xml
deleted file mode 100644
index 49ac89a..0000000
--- a/common/trmk/src/test/resources/NodeService.xml
+++ /dev/null
@@ -1,11 +0,0 @@
-<NodeService xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <Id>242</Id>
-    <Href>https://services.vcloudexpress.terremark.com/api/v0.8/NodeServices/242
-    </Href>
-    <Name>Node for Jim</Name>
-    <IpAddress>172.16.20.3</IpAddress>
-    <Port>80</Port>
-    <Enabled>false</Enabled>
-    <Description>Some test node</Description>
-</NodeService>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/NodeServices.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/NodeServices.xml b/common/trmk/src/test/resources/NodeServices.xml
deleted file mode 100644
index 226066a..0000000
--- a/common/trmk/src/test/resources/NodeServices.xml
+++ /dev/null
@@ -1,13 +0,0 @@
-<NodeServices xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <NodeService>
-        <Id>242</Id>
-        <Href>https://services.vcloudexpress.terremark.com/api/v0.8/NodeServices/242
-        </Href>
-        <Name>Node for Jim</Name>
-        <IpAddress>172.16.20.3</IpAddress>
-        <Port>80</Port>
-        <Enabled>false</Enabled>
-        <Description>Some test node</Description>
-    </NodeService>
-</NodeServices>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/PublicIpAddress.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/PublicIpAddress.xml b/common/trmk/src/test/resources/PublicIpAddress.xml
deleted file mode 100644
index a519a81..0000000
--- a/common/trmk/src/test/resources/PublicIpAddress.xml
+++ /dev/null
@@ -1,7 +0,0 @@
-<PublicIPAddress xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <Id>8720</Id>
-    <Href>https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/8720
-    </Href>
-    <Name>204.51.112.91</Name>
-</PublicIPAddress>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/PublicIpAddresses.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/PublicIpAddresses.xml b/common/trmk/src/test/resources/PublicIpAddresses.xml
deleted file mode 100644
index 264863e..0000000
--- a/common/trmk/src/test/resources/PublicIpAddresses.xml
+++ /dev/null
@@ -1,15 +0,0 @@
-<PublicIpAddresses xmlns="urn:tmrk:vCloudExpress-1.0"
-    xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <PublicIPAddress>
-        <Id>8720</Id>
-        <Href>https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/8720
-        </Href>
-        <Name>204.51.112.91</Name>
-    </PublicIPAddress>
-    <PublicIPAddress>
-        <Id>14965</Id>
-        <Href>https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/14965
-        </Href>
-        <Name>204.51.114.79</Name>
-    </PublicIPAddress>
-</PublicIpAddresses>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/TerremarkNetwork.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/TerremarkNetwork.xml b/common/trmk/src/test/resources/TerremarkNetwork.xml
deleted file mode 100644
index 0241427..0000000
--- a/common/trmk/src/test/resources/TerremarkNetwork.xml
+++ /dev/null
@@ -1,12 +0,0 @@
-<Network xmlns="urn:tmrk:eCloudExtensions-2.5" xmlns:i="http://www.w3.org/2001/XMLSchema-instance">
-    <Id>XXXXX</Id>
-    <Href>https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.5/extensions/network/XXXXX</Href>
-    <Name>10.X.X.0/27</Name>
-    <RnatAddress>209.X.X.X</RnatAddress>
-    <Address>10.X.X.0</Address>
-    <BroadcastAddress>10.X.X.X</BroadcastAddress>
-    <GatewayAddress>10.X.X.1</GatewayAddress>
-    <NetworkType>DMZ</NetworkType>
-    <Vlan>279</Vlan>
-    <FriendlyName>10.X.X.0/27 (DMZ_279)</FriendlyName>
-</Network>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/catalog.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/catalog.xml b/common/trmk/src/test/resources/catalog.xml
deleted file mode 100644
index f2d5eaa..0000000
--- a/common/trmk/src/test/resources/catalog.xml
+++ /dev/null
@@ -1,27 +0,0 @@
-<Catalog href="https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32/catalog" type="application/vnd.vmware.vcloud.catalog+xml" name="Miami Environment 1" xmlns="http://www.vmware.com/vcloud/v1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xmlns:xsd="http://www.w3.org/2001/XMLSchema">
-  <CatalogItems>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/5" type="application/vnd.vmware.vcloud.catalogItem+xml" name="CentOS 5.3 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/6" type="application/vnd.vmware.vcloud.catalogItem+xml" name="CentOS 5.3 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/7" type="application/vnd.vmware.vcloud.catalogItem+xml" name="RHEL 5.3 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/8" type="application/vnd.vmware.vcloud.catalogItem+xml" name="RHEL 5.3 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/11" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Ubuntu JeOS 9.04 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/12" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Ubuntu JeOS 9.04 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/9" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Ubuntu Server 9.04 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/10" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Ubuntu Server 9.04 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/1" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows 2003 Enterprise R2 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/2" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows 2003 Enterprise R2 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/3" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows 2003 Standard R2 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/4" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows 2003 Standard R2 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/23" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows 2003 Standard R2 w.SQL 2008 Web (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/13" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Enterprise (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/15" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Enterprise (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/16" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Enterprise R2 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/17" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Standard (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/18" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Standard (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/19" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Standard R2 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/14" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Server 2008 Standard w.SQL 2008 Web (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/20" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Web Server 2008 (32-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/21" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Web Server 2008 (64-bit)"/>
-    <CatalogItem href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22" type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Web Server 2008 R2 (64-bit)"/>
-  </CatalogItems>
-</Catalog>

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/catalogItem-terremark.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/catalogItem-terremark.xml b/common/trmk/src/test/resources/catalogItem-terremark.xml
deleted file mode 100644
index feb8b82..0000000
--- a/common/trmk/src/test/resources/catalogItem-terremark.xml
+++ /dev/null
@@ -1,16 +0,0 @@
-<CatalogItem
-    href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22"
-    type="application/vnd.vmware.vcloud.catalogItem+xml" name="Windows Web Server 2008 R2 (64-bit)"
-    xmlns="http://www.vmware.com/vcloud/v1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-    xmlns:xsd="http://www.w3.org/2001/XMLSchema">
-    <Link rel="down"
-        href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22/options/compute"
-        type="application/xml" name="Compute Options" />
-    <Link rel="down"
-        href="https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22/options/customization"
-        type="application/xml" name="Customization Options" />
-    <Entity
-        href="https://services.vcloudexpress.terremark.com/api/v0.8/vAppTemplate/22"
-        type="application/vnd.vmware.vcloud.vAppTemplate+xml" name="Windows Web Server 2008 R2 (64-bit)" />
-    <Property key="LicensingCost">0</Property>
-</CatalogItem>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/cloneVApp-default.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/cloneVApp-default.xml b/common/trmk/src/test/resources/cloneVApp-default.xml
deleted file mode 100644
index 48e0681..0000000
--- a/common/trmk/src/test/resources/cloneVApp-default.xml
+++ /dev/null
@@ -1 +0,0 @@
-<CloneVAppParams xmlns="http://www.vmware.com/vcloud/v0.8" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" deploy="false" name="my-vapp" powerOn="false" xsi:schemaLocation="http://www.vmware.com/vcloud/v0.8 http://vcloud.safesecureweb.com/ns/vcloud.xsd"><VApp href="https://vcloud.safesecureweb.com/api/v0.8/vapp/4181" type="application/vnd.vmware.vcloud.vApp+xml"/></CloneVAppParams>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/resources/cloneVApp.xml
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/resources/cloneVApp.xml b/common/trmk/src/test/resources/cloneVApp.xml
deleted file mode 100644
index bdc3aae..0000000
--- a/common/trmk/src/test/resources/cloneVApp.xml
+++ /dev/null
@@ -1 +0,0 @@
-<CloneVAppParams xmlns="http://www.vmware.com/vcloud/v0.8" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" deploy="true" name="new-linux-server" powerOn="true" xsi:schemaLocation="http://www.vmware.com/vcloud/v0.8 http://vcloud.safesecureweb.com/ns/vcloud.xsd"><Description>The description of the new vApp</Description><VApp href="https://vcloud.safesecureweb.com/api/v0.8/vapp/201" type="application/vnd.vmware.vcloud.vApp+xml"/></CloneVAppParams>
\ No newline at end of file