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:27 UTC

[07/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/internal/TerremarkVCloudLoginApiTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudLoginApiTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudLoginApiTest.java
deleted file mode 100644
index 95df1ff..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudLoginApiTest.java
+++ /dev/null
@@ -1,99 +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.internal;
-
-import static org.jclouds.reflect.Reflection2.method;
-import static org.testng.Assert.assertEquals;
-
-import java.io.IOException;
-import java.net.URI;
-
-import javax.ws.rs.core.HttpHeaders;
-
-import org.jclouds.http.HttpRequest;
-import org.jclouds.http.filters.BasicAuthentication;
-import org.jclouds.location.Provider;
-import org.jclouds.providers.AnonymousProviderMetadata;
-import org.jclouds.providers.ProviderMetadata;
-import org.jclouds.rest.internal.BaseAsyncClientTest;
-import org.jclouds.rest.internal.GeneratedHttpRequest;
-import org.jclouds.trmk.vcloud_0_8.endpoints.VCloudLogin;
-import org.jclouds.trmk.vcloud_0_8.functions.ParseLoginResponseFromHeaders;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Supplier;
-import com.google.common.collect.ImmutableList;
-import com.google.common.reflect.Invokable;
-import com.google.inject.Binder;
-import com.google.inject.Module;
-import com.google.inject.Provides;
-
-/**
- * Tests behavior of {@code VCloudLoginApi}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "VCloudLoginApiTest")
-public class TerremarkVCloudLoginApiTest extends BaseAsyncClientTest<TerremarkVCloudLoginApi> {
-
-   public void testLogin() throws SecurityException, NoSuchMethodException, IOException {
-      Invokable<?, ?> method = method(TerremarkVCloudLoginApi.class, "login");
-      GeneratedHttpRequest request = processor.createRequest(method, ImmutableList.of());
-
-      assertEquals(request.getRequestLine(), "POST http://localhost:8080/login HTTP/1.1");
-      assertNonPayloadHeadersEqual(request, HttpHeaders.ACCEPT + ": application/vnd.vmware.vcloud.orgList+xml\n");
-      assertPayloadEquals(request, null, null, false);
-
-      assertResponseParserClassEquals(method, request, ParseLoginResponseFromHeaders.class);
-      assertSaxResponseParserClassEquals(method, null);
-      assertFallbackClassEquals(method, null);
-
-      checkFilters(request);
-   }
-
-   @Override
-   protected void checkFilters(HttpRequest request) {
-      assertEquals(request.getFilters().size(), 1);
-      assertEquals(request.getFilters().get(0).getClass(), BasicAuthentication.class);
-   }
-
-   @Override
-   protected Module createModule() {
-      return new Module() {
-
-         @Override
-         public void configure(Binder binder) {
-         }
-
-         @Provides
-         @VCloudLogin
-         Supplier<URI> provideURI(@Provider Supplier<URI> uri) {
-            return uri;
-         }
-
-      };
-   }
-
-   @Override
-   protected ProviderMetadata createProviderMetadata() {
-      return AnonymousProviderMetadata.forApiOnEndpoint(TerremarkVCloudLoginApi.class,
-            "http://localhost:8080/login");
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudVersionsApiTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudVersionsApiTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudVersionsApiTest.java
deleted file mode 100644
index 217cd54..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/internal/TerremarkVCloudVersionsApiTest.java
+++ /dev/null
@@ -1,70 +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.internal;
-
-import static org.jclouds.reflect.Reflection2.method;
-import static org.testng.Assert.assertEquals;
-
-import java.io.IOException;
-
-import org.jclouds.http.HttpRequest;
-import org.jclouds.http.functions.ParseSax;
-import org.jclouds.providers.AnonymousProviderMetadata;
-import org.jclouds.providers.ProviderMetadata;
-import org.jclouds.rest.internal.BaseAsyncClientTest;
-import org.jclouds.rest.internal.GeneratedHttpRequest;
-import org.jclouds.trmk.vcloud_0_8.xml.SupportedVersionsHandler;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableList;
-import com.google.common.reflect.Invokable;
-/**
- * Tests behavior of {@code VCloudVersionsAsyncClient}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "VCloudVersionsApiTest")
-public class TerremarkVCloudVersionsApiTest extends BaseAsyncClientTest<TerremarkVCloudVersionsApi> {
-
-   public void testVersions() throws SecurityException, NoSuchMethodException, IOException {
-      Invokable<?, ?> method = method(TerremarkVCloudVersionsApi.class, "getSupportedVersions");
-      GeneratedHttpRequest request = processor.createRequest(method, ImmutableList.of());
-
-      assertEquals(request.getRequestLine(), "GET http://localhost:8080/versions HTTP/1.1");
-      assertNonPayloadHeadersEqual(request, "");
-      assertPayloadEquals(request, null, null, false);
-
-      assertResponseParserClassEquals(method, request, ParseSax.class);
-      assertSaxResponseParserClassEquals(method, SupportedVersionsHandler.class);
-      assertFallbackClassEquals(method, null);
-
-      checkFilters(request);
-   }
-
-   @Override
-   protected void checkFilters(HttpRequest request) {
-      assertEquals(request.getFilters().size(), 0);
-   }
-
-   @Override
-   protected ProviderMetadata createProviderMetadata() {
-      return AnonymousProviderMetadata.forApiOnEndpoint(TerremarkVCloudVersionsApi.class,
-            "http://localhost:8080");
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddInternetServiceOptionsTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddInternetServiceOptionsTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddInternetServiceOptionsTest.java
deleted file mode 100644
index cd79706..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddInternetServiceOptionsTest.java
+++ /dev/null
@@ -1,65 +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.options;
-
-import static org.jclouds.trmk.vcloud_0_8.options.AddInternetServiceOptions.Builder.disabled;
-import static org.jclouds.trmk.vcloud_0_8.options.AddInternetServiceOptions.Builder.withDescription;
-import static org.testng.Assert.assertEquals;
-
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code CreateInternetServiceOptions}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class AddInternetServiceOptionsTest {
-
-   Injector injector = Guice.createInjector(new SaxParserModule());
-
-   @Test
-   public void testWithDescription() {
-      AddInternetServiceOptions options = new AddInternetServiceOptions();
-      options.withDescription("yallo");
-      assertEquals(options.description, "yallo");
-   }
-
-   @Test
-   public void testWithDescriptionStatic() {
-      AddInternetServiceOptions options = withDescription("yallo");
-      assertEquals(options.description, "yallo");
-   }
-
-   @Test
-   public void testDisabled() {
-      AddInternetServiceOptions options = new AddInternetServiceOptions();
-      options.disabled();
-      assertEquals(options.enabled, "false");
-   }
-
-   @Test
-   public void testDisabledStatic() {
-      AddInternetServiceOptions options = disabled();
-      assertEquals(options.enabled, "false");
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddNodeOptionsTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddNodeOptionsTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddNodeOptionsTest.java
deleted file mode 100644
index 24b8d18..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/AddNodeOptionsTest.java
+++ /dev/null
@@ -1,65 +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.options;
-
-import static org.jclouds.trmk.vcloud_0_8.options.AddNodeOptions.Builder.disabled;
-import static org.jclouds.trmk.vcloud_0_8.options.AddNodeOptions.Builder.withDescription;
-import static org.testng.Assert.assertEquals;
-
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code CreateNodeOptions}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class AddNodeOptionsTest {
-
-   Injector injector = Guice.createInjector(new SaxParserModule());
-
-   @Test
-   public void testWithDescription() {
-      AddNodeOptions options = new AddNodeOptions();
-      options.withDescription("yallo");
-      assertEquals(options.description, "yallo");
-   }
-
-   @Test
-   public void testWithDescriptionStatic() {
-      AddNodeOptions options = withDescription("yallo");
-      assertEquals(options.description, "yallo");
-   }
-
-   @Test
-   public void testDisabled() {
-      AddNodeOptions options = new AddNodeOptions();
-      options.disabled();
-      assertEquals(options.enabled, "false");
-   }
-
-   @Test
-   public void testDisabledStatic() {
-      AddNodeOptions options = disabled();
-      assertEquals(options.enabled, "false");
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/InstantiateVAppTemplateOptionsTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/InstantiateVAppTemplateOptionsTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/InstantiateVAppTemplateOptionsTest.java
deleted file mode 100644
index ae970d7..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/options/InstantiateVAppTemplateOptionsTest.java
+++ /dev/null
@@ -1,155 +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.options;
-
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.addNetworkConfig;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.customizeOnInstantiate;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.inGroup;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.inRow;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.memory;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.processorCount;
-import static org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.Builder.withPassword;
-import static org.testng.Assert.assertEquals;
-
-import java.net.URI;
-
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.domain.FenceMode;
-import org.jclouds.trmk.vcloud_0_8.options.InstantiateVAppTemplateOptions.NetworkConfig;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.Iterables;
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code InstantiateVAppTemplateOptions}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class InstantiateVAppTemplateOptionsTest {
-
-   Injector injector = Guice.createInjector(new SaxParserModule());
-
-   @Test
-   public void testCustomizeOnInstantiate() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.customizeOnInstantiate(true);
-      assertEquals(options.shouldCustomizeOnInstantiate(), Boolean.TRUE);
-   }
-
-   @Test
-   public void testCustomizeOnInstantiateStatic() {
-      InstantiateVAppTemplateOptions options = customizeOnInstantiate(true);
-      assertEquals(options.shouldCustomizeOnInstantiate(), Boolean.TRUE);
-   }
-
-   @Test
-   public void testRam() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.memory(512);
-      assertEquals(options.getMemorySizeMegabytes(), "512");
-   }
-
-   @Test
-   public void testRamStatic() {
-      InstantiateVAppTemplateOptions options = memory(512);
-      assertEquals(options.getMemorySizeMegabytes(), "512");
-   }
-
-   @Test
-   public void testInGroup() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.inGroup("group1");
-      assertEquals(options.getProperties().get("group"), "group1");
-   }
-
-   @Test
-   public void testInGroupStatic() {
-      InstantiateVAppTemplateOptions options = inGroup("group1");
-      assertEquals(options.getProperties().get("group"), "group1");
-   }
-
-   @Test
-   public void testInRow() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.inRow("row1");
-      assertEquals(options.getProperties().get("row"), "row1");
-   }
-
-   @Test
-   public void testInRowStatic() {
-      InstantiateVAppTemplateOptions options = inRow("row1");
-      assertEquals(options.getProperties().get("row"), "row1");
-   }
-
-   @Test
-   public void testWithPassword() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.withPassword("password1");
-      assertEquals(options.getProperties().get("password"), "password1");
-   }
-
-   @Test
-   public void testWithPasswordStatic() {
-      InstantiateVAppTemplateOptions options = withPassword("password1");
-      assertEquals(options.getProperties().get("password"), "password1");
-   }
-
-   @Test
-   public void testAddNetworkConfig() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.addNetworkConfig(new NetworkConfig("default", URI.create("http://localhost"), FenceMode.ALLOW_IN_OUT));
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getNetworkName(), "default");
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getParentNetwork(), URI.create("http://localhost"));
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getFenceMode(), FenceMode.ALLOW_IN_OUT);
-   }
-
-   @Test
-   public void testAddNetworkConfigStatic() {
-      InstantiateVAppTemplateOptions options = addNetworkConfig(new NetworkConfig("default",
-            URI.create("http://localhost"), FenceMode.ALLOW_IN_OUT));
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getNetworkName(), "default");
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getParentNetwork(), URI.create("http://localhost"));
-      assertEquals(Iterables.get(options.getNetworkConfig(), 0).getFenceMode(), FenceMode.ALLOW_IN_OUT);
-   }
-
-   @Test
-   public void testCpuCount() {
-      assertEquals(processorCount(3).getCpuCount(), "3");
-   }
-
-   @Test
-   public void testCpuCountStatic() {
-      InstantiateVAppTemplateOptions options = processorCount(3);
-      assertEquals(options.getCpuCount(), "3");
-   }
-
-   @Test
-   public void testMegabytes() {
-      InstantiateVAppTemplateOptions options = new InstantiateVAppTemplateOptions();
-      options.memory(512);
-      assertEquals(options.getMemorySizeMegabytes(), "512");
-   }
-
-   @Test
-   public void testMegabytesStatic() {
-      InstantiateVAppTemplateOptions options = memory(512);
-      assertEquals(options.getMemorySizeMegabytes(), "512");
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/suppliers/OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/suppliers/OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/suppliers/OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest.java
deleted file mode 100644
index 84b0c24..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/suppliers/OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest.java
+++ /dev/null
@@ -1,115 +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.suppliers;
-
-import static org.easymock.EasyMock.createMock;
-import static org.testng.Assert.assertEquals;
-
-import java.util.NoSuchElementException;
-
-import org.jclouds.config.ValueOfConfigurationKeyOrNull;
-import org.jclouds.trmk.vcloud_0_8.domain.ReferenceType;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.Test;
-
-import com.google.common.base.Predicates;
-import com.google.common.collect.ImmutableList;
-import com.google.common.collect.ImmutableSet;
-import com.google.inject.AbstractModule;
-import com.google.inject.Guice;
-import com.google.inject.name.Names;
-
-/**
- * Tests behavior of
- * {@code OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest")
-public class OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefaultTest {
-   ValueOfConfigurationKeyOrNull valueOfConfigurationKeyOrNull = Guice.createInjector().getInstance(
-         ValueOfConfigurationKeyOrNull.class);
-
-   @Test(expectedExceptions = IllegalArgumentException.class)
-   public void testIllegalArgumentWhenResourcesEmpty() {
-      new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(valueOfConfigurationKeyOrNull, "foo",
-            Predicates.<ReferenceType> alwaysTrue()).apply(ImmutableSet.<ReferenceType> of());
-   }
-
-   @Test
-   public void testReturnsOnlyResource() {
-      ReferenceType reference = createMock(ReferenceType.class);
-
-      assertEquals(new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(valueOfConfigurationKeyOrNull,
-            "foo", Predicates.<ReferenceType> alwaysTrue()).apply(ImmutableSet.<ReferenceType> of(reference)),
-            reference);
-
-   }
-
-   @Test
-   public void testReturnsFirstResourceWhenConfigurationUnspecified() {
-      ReferenceType reference1 = createMock(ReferenceType.class);
-      ReferenceType reference2 = createMock(ReferenceType.class);
-
-      assertEquals(new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(valueOfConfigurationKeyOrNull,
-            "foo", Predicates.<ReferenceType> alwaysTrue()).apply(ImmutableList.<ReferenceType> of(reference1,
-            reference2)), reference1);
-
-   }
-
-   @Test
-   public void testReturnsResourceMatchingDefaultPredicateWhenConfigurationUnspecified() {
-      ReferenceType reference1 = createMock(ReferenceType.class);
-      ReferenceType reference2 = createMock(ReferenceType.class);
-
-      assertEquals(new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(valueOfConfigurationKeyOrNull,
-            "foo", Predicates.equalTo(reference2)).apply(ImmutableList.<ReferenceType> of(reference1, reference2)),
-            reference2);
-
-   }
-
-   @Test
-   public void testReturnsResourceWithNameMatchingConfigurationKey() {
-      ReferenceType reference1 = new ReferenceTypeImpl("travis tritt", null, null);
-      ReferenceType reference2 = new ReferenceTypeImpl("hail mary", null, null);
-
-      assertEquals(
-            new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(Guice.createInjector(
-                  new AbstractModule() {
-                     protected void configure() {
-                        bindConstant().annotatedWith(Names.named("foo")).to(".*mary.*");
-                     }
-                  }).getInstance(ValueOfConfigurationKeyOrNull.class), "foo", Predicates.<ReferenceType> alwaysTrue()).apply(ImmutableList
-                  .<ReferenceType> of(reference1, reference2)), reference2);
-
-   }
-
-   @Test(expectedExceptions = NoSuchElementException.class)
-   public void testThrowsNoSuchElementWhenNoneMatchConfigurationKey() {
-      ReferenceType reference1 = new ReferenceTypeImpl("travis tritt", null, null);
-      ReferenceType reference2 = new ReferenceTypeImpl("hail mary", null, null);
-
-      new OnlyReferenceTypeFirstWithNameMatchingConfigurationKeyOrDefault(Guice.createInjector(new AbstractModule() {
-         protected void configure() {
-            bindConstant().annotatedWith(Names.named("foo")).to(".*happy.*");
-         }
-      }).getInstance(ValueOfConfigurationKeyOrNull.class), "foo", Predicates.<ReferenceType> alwaysTrue())
-            .apply(ImmutableList.<ReferenceType> of(reference1, reference2));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogHandlerTest.java
deleted file mode 100644
index e8a9a0d..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogHandlerTest.java
+++ /dev/null
@@ -1,141 +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.CATALOGITEM_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.Catalog;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code CatalogHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class CatalogHandlerTest {
-
-   private Injector injector;
-
-   private Factory factory;
-
-   public void testTerremark() {
-      InputStream is = getClass().getResourceAsStream("/catalog.xml");
-      injector = Guice.createInjector(new SaxParserModule());
-      factory = injector.getInstance(ParseSax.Factory.class);
-      Catalog result = factory.create(injector.getInstance(CatalogHandler.class)).parse(is);
-      assertEquals(result.getName(), "Miami Environment 1");
-      assert result.getDescription() == null;
-
-      assertEquals(result.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/vdc/32/catalog"));
-      assertEquals(
-            result.get("CentOS 5.3 (32-bit)"),
-            new ReferenceTypeImpl("CentOS 5.3 (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/5")));
-      assertEquals(
-            result.get("CentOS 5.3 (64-bit)"),
-            new ReferenceTypeImpl("CentOS 5.3 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/6")));
-      assertEquals(
-            result.get("RHEL 5.3 (32-bit)"),
-            new ReferenceTypeImpl("RHEL 5.3 (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/7")));
-      assertEquals(
-            result.get("RHEL 5.3 (64-bit)"),
-            new ReferenceTypeImpl("RHEL 5.3 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/8")));
-      assertEquals(result.get("Ubuntu JeOS 9.04 (32-bit)"), new ReferenceTypeImpl("Ubuntu JeOS 9.04 (32-bit)",
-            CATALOGITEM_XML, URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/11")));
-      assertEquals(result.get("Ubuntu JeOS 9.04 (64-bit)"), new ReferenceTypeImpl("Ubuntu JeOS 9.04 (64-bit)",
-            CATALOGITEM_XML, URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/12")));
-      assertEquals(result.get("Ubuntu Server 9.04 (32-bit)"), new ReferenceTypeImpl("Ubuntu Server 9.04 (32-bit)",
-            CATALOGITEM_XML, URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/9")));
-      assertEquals(result.get("Ubuntu Server 9.04 (64-bit)"), new ReferenceTypeImpl("Ubuntu Server 9.04 (64-bit)",
-            CATALOGITEM_XML, URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/10")));
-      assertEquals(
-            result.get("Windows 2003 Enterprise R2 (32-bit)"),
-            new ReferenceTypeImpl("Windows 2003 Enterprise R2 (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/1")));
-      assertEquals(
-            result.get("Windows 2003 Enterprise R2 (64-bit)"),
-            new ReferenceTypeImpl("Windows 2003 Enterprise R2 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/2")));
-      assertEquals(
-            result.get("Windows 2003 Standard R2 (32-bit)"),
-            new ReferenceTypeImpl("Windows 2003 Standard R2 (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/3")));
-      assertEquals(
-            result.get("Windows 2003 Standard R2 (64-bit)"),
-            new ReferenceTypeImpl("Windows 2003 Standard R2 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/4")));
-      assertEquals(
-            result.get("Windows 2003 Standard R2 w.SQL 2008 Web (64-bit)"),
-            new ReferenceTypeImpl("Windows 2003 Standard R2 w.SQL 2008 Web (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/23")));
-      assertEquals(
-            result.get("Windows Server 2008 Enterprise (32-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Enterprise (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/13")));
-      assertEquals(
-            result.get("Windows Server 2008 Enterprise (64-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Enterprise (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/15")));
-      assertEquals(
-            result.get("Windows Server 2008 Enterprise R2 (64-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Enterprise R2 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/16")));
-      assertEquals(
-            result.get("Windows Server 2008 Standard (32-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Standard (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/17")));
-      assertEquals(
-            result.get("Windows Server 2008 Standard (64-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Standard (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/18")));
-      assertEquals(
-            result.get("Windows Server 2008 Standard R2 (64-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Standard R2 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/19")));
-      assertEquals(
-            result.get("Windows Server 2008 Standard w.SQL 2008 Web (64-bit)"),
-            new ReferenceTypeImpl("Windows Server 2008 Standard w.SQL 2008 Web (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/14")));
-      assertEquals(
-            result.get("Windows Web Server 2008 (32-bit)"),
-            new ReferenceTypeImpl("Windows Web Server 2008 (32-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/20")));
-      assertEquals(
-            result.get("Windows Web Server 2008 (64-bit)"),
-            new ReferenceTypeImpl("Windows Web Server 2008 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/21")));
-      assertEquals(
-            result.get("Windows Web Server 2008 R2 (64-bit)"),
-            new ReferenceTypeImpl("Windows Web Server 2008 R2 (64-bit)", CATALOGITEM_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogItemHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogItemHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogItemHandlerTest.java
deleted file mode 100644
index 0d9258a..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CatalogItemHandlerTest.java
+++ /dev/null
@@ -1,86 +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.http.functions.ParseSax;
-import org.jclouds.http.functions.config.SaxParserModule;
-import org.jclouds.trmk.vcloud_0_8.domain.CatalogItem;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.CatalogItemImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.jclouds.trmk.vcloud_0_8.internal.TerremarkVCloudApiMetadata;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSortedMap;
-import com.google.inject.Guice;
-import com.google.inject.name.Names;
-
-/**
- * Tests behavior of {@code CatalogItemHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "CatalogItemHandlerTest")
-public class CatalogItemHandlerTest extends BaseHandlerTest {
-   @Override
-   @BeforeTest
-   protected void setUpInjector() {
-      injector = Guice.createInjector(new SaxParserModule() {
-         @Override
-         public void configure() {
-            super.configure();
-            Names.bindProperties(binder(), TerremarkVCloudApiMetadata.defaultProperties());
-         }
-      });
-      factory = injector.getInstance(ParseSax.Factory.class);
-      assert factory != null;
-   }
-
-   public void testApplyInputStream() {
-
-      InputStream is = getClass().getResourceAsStream("/catalogItem-terremark.xml");
-
-      CatalogItem result = factory.create(
-            injector.getInstance(CatalogItemHandler.class)).parse(is);
-      assertEquals(
-            result,
-            new CatalogItemImpl(
-                  "Windows Web Server 2008 R2 (64-bit)",
-                  URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22"),
-                  null,
-                  new ReferenceTypeImpl(
-                        "Compute Options",
-                        "application/xml",
-                        URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22/options/compute")),
-                  new ReferenceTypeImpl(
-                        "Customization Options",
-                        "application/xml",
-                        URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/catalogItem/22/options/customization")),
-                  new ReferenceTypeImpl("Windows Web Server 2008 R2 (64-bit)",
-                        "application/vnd.vmware.vcloud.vAppTemplate+xml", URI
-                              .create("https://services.vcloudexpress.terremark.com/api/v0.8/vAppTemplate/22")),
-                  ImmutableSortedMap.of("LicensingCost", "0")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CustomizationParametersHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CustomizationParametersHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CustomizationParametersHandlerTest.java
deleted file mode 100644
index 0f9e5a2..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/CustomizationParametersHandlerTest.java
+++ /dev/null
@@ -1,46 +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.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.CustomizationParameters;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code CustomizationParametersHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "CustomizationParametersHandlerTest")
-public class CustomizationParametersHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream(
-            "/CustomizationParameters.xml");
-
-      CustomizationParameters result = factory
-            .create(injector.getInstance(CustomizationParametersHandler.class))
-            .parse(is);
-      assertEquals(result, new CustomizationParameters(true, false, false));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCenterHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCenterHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCenterHandlerTest.java
deleted file mode 100644
index ed0c62a..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCenterHandlerTest.java
+++ /dev/null
@@ -1,45 +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.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.DataCenter;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code DataCenterHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "DataCenterHandlerTest")
-public class DataCenterHandlerTest extends BaseHandlerTest {
-
-   public void test() {
-      InputStream is = getClass().getResourceAsStream("/datacenter.xml");
-
-      DataCenter result = factory.create(injector.getInstance(DataCenterHandler.class)).parse(is);
-
-      DataCenter expects = DataCenter.builder().id("1").name("Terremark - Miami").code("MIA").build();
-      assertEquals(result.toString(), expects.toString());
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCentersHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCentersHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCentersHandlerTest.java
deleted file mode 100644
index 8fdedda..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/DataCentersHandlerTest.java
+++ /dev/null
@@ -1,50 +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.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.DataCenter;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code DataCentersHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during
-// surefire
-@Test(groups = "unit", testName = "DataCentersHandlerTest")
-public class DataCentersHandlerTest extends BaseHandlerTest {
-
-   public void test() {
-      InputStream is = getClass().getResourceAsStream("/datacenters.xml");
-
-      Set<DataCenter> result = factory.create(injector.getInstance(DataCentersHandler.class)).parse(is);
-
-      ImmutableSet<DataCenter> expects = ImmutableSet.<DataCenter>of(DataCenter.builder().id("1").name("Terremark - Miami").code("MIA").build(),
-            DataCenter.builder().id("3670").name("Terremark - Culpeper").code("CUA").build());
-      assertEquals(result.toString(), expects.toString());
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServiceHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServiceHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServiceHandlerTest.java
deleted file mode 100644
index 70ef254..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServiceHandlerTest.java
+++ /dev/null
@@ -1,66 +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.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.InternetService;
-import org.jclouds.trmk.vcloud_0_8.domain.Protocol;
-import org.jclouds.trmk.vcloud_0_8.domain.PublicIpAddress;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code InternetServiceHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "InternetServiceHandlerTest")
-public class InternetServiceHandlerTest extends BaseHandlerTest {
-
-   @BeforeTest
-   @Override
-   protected void setUpInjector() {
-      super.setUpInjector();
-   }
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/InternetService.xml");
-
-      InternetService result = factory.create(injector.getInstance(InternetServiceHandler.class))
-            .parse(is);
-      assertEquals(result, new InternetService("IS_for_Jim", null, new PublicIpAddress("10.1.22.159", null), 80,
-            Protocol.HTTP, false, 1, "Some test service"));
-   }
-
-   public void test2() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/InternetService2.xml");
-
-      InternetService result = factory.create(injector.getInstance(InternetServiceHandler.class))
-            .parse(is);
-      assertEquals(result, new InternetService("IS_for_Jim2", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/InternetServices/524"), new PublicIpAddress(
-            "10.1.22.159", URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/4208")), 45,
-            Protocol.HTTP, false, 1, "Some test service"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServicesHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServicesHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServicesHandlerTest.java
deleted file mode 100644
index e58f737..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/InternetServicesHandlerTest.java
+++ /dev/null
@@ -1,60 +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.net.UnknownHostException;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.InternetService;
-import org.jclouds.trmk.vcloud_0_8.domain.Protocol;
-import org.jclouds.trmk.vcloud_0_8.domain.PublicIpAddress;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code InternetServicesHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "InternetServicesHandlerTest")
-public class InternetServicesHandlerTest extends BaseHandlerTest {
-
-   public void test() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/InternetServices.xml");
-
-      Set<InternetService> result = factory.create(injector.getInstance(InternetServicesHandler.class)).parse(is);
-      assertEquals(result.toString(), ImmutableSet.of(new InternetService("IS_for_Jim2", URI
-               .create("https://services.vcloudexpress.terremark.com/api/v0.8/InternetServices/524"),
-               new PublicIpAddress("10.1.22.159", URI
-                        .create("https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/4208")), 45,
-               Protocol.HTTP, false, 1, "Some test service")).toString());
-   }
-
-   public void test2() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/InternetServices-2.xml");
-
-      Set<InternetService> result = factory.create(injector.getInstance(InternetServicesHandler.class)).parse(is);
-      assertEquals(result.size(), 6);
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/IpAddressesHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/IpAddressesHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/IpAddressesHandlerTest.java
deleted file mode 100644
index 9f8f2dc..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/IpAddressesHandlerTest.java
+++ /dev/null
@@ -1,49 +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.UnknownHostException;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.IpAddress;
-import org.jclouds.trmk.vcloud_0_8.domain.IpAddress.Status;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code IpAddressesHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "IpAddressesHandlerTest")
-public class IpAddressesHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/ipAddresses.xml");
-
-      Set<IpAddress> result = factory.create(injector.getInstance(IpAddressesHandler.class))
-               .parse(is);
-      assertEquals(result, ImmutableSet.of(new IpAddress("10.114.34.131", Status.ASSIGNED,
-               "testforjcloud2"), new IpAddress("10.114.34.132", Status.AVAILABLE, 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/KeyPairByNameHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairByNameHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairByNameHandlerTest.java
deleted file mode 100644
index 4988f90..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairByNameHandlerTest.java
+++ /dev/null
@@ -1,64 +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 static org.testng.Assert.assertNull;
-
-import java.io.InputStream;
-import java.net.URI;
-import java.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.KeyPair;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableList;
-
-/**
- * Tests behavior of {@code KeyPairByNameHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "KeyPairByNameHandlerTest")
-public class KeyPairByNameHandlerTest extends BaseHandlerTest {
-
-   public void testGood() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/keysList.xml");
-
-      KeyPair result = factory.create(
-            addOrgAndNameToHandler(injector.getInstance(KeyPairByNameHandler.class), "org", "default")).parse(is);
-      assertEquals(result,
-            new KeyPair(URI.create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/extensions/key/9"),
-                  "default", true, null, "4e:af:8a:9f:e9:d2:72:d7:4b:a0:da:98:72:98:4d:7d"));
-
-   }
-
-   public void testNotFound() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/keysList.xml");
-
-      KeyPair result = factory.create(
-            addOrgAndNameToHandler(injector.getInstance(KeyPairByNameHandler.class), "org", "monster")).parse(is);
-      assertNull(result);
-   }
-
-   private KeyPairByNameHandler addOrgAndNameToHandler(KeyPairByNameHandler handler, String org, String name) {
-      handler.setContext(requestForArgs(ImmutableList.<Object> of(org, name)));
-      return handler;
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairHandlerTest.java
deleted file mode 100644
index aa9282a..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeyPairHandlerTest.java
+++ /dev/null
@@ -1,65 +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.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.ssh.SshKeys;
-import org.jclouds.trmk.vcloud_0_8.domain.KeyPair;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code KeyHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "KeyPairHandlerTest")
-public class KeyPairHandlerTest extends BaseHandlerTest {
-   public static final KeyPair keyPair = new KeyPair(URI
-            .create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.8/extensions/key/13691"),
-            "jclouds_te_r_1241", false, "-----BEGIN RSA PRIVATE KEY-----\n"
-                     + "MIICWwIBAAKBgQCxdOcKd0WDuphOojK6Z2uErdgPsjei3/Xs6CzjL7a4ofd15rfz\n"
-                     + "oRLbuNhLto4p/3drDjYdNrtPRLq5iNHq/qrRsHOJKS+bpAVQapuKDLCWwXa25nyM\n"
-                     + "hG9iL/kwYGvS55CSOvHp5AH+diBuu6M9ay0w7idOBPnFdg4OMLIpAUTvqwICAQEC\n"
-                     + "gYEAi3rDirdldHy/bp1eqG0tqQgkWAqVUTOEiGbMnqUBLINJ+Q7+KBUD3YJYU2qh\n"
-                     + "i5f8Pjr7t1XZ8pmhtLFEXw3k40F7oV/NGs4CsnbYlxbegzHTzMNnN1dA+zj333jr\n"
-                     + "N7U760b5D1cx5yTL5wF59gYaP8xugDnuCvRqbinqijApnzECQQDbJcxGUShVCpEh\n"
-                     + "W0+BT/YHtM7BI1S6me7JdL5NMHsg1HE/0Ghi7nFUfbJDNsuIomRqbO5qcG7RpIN/\n"
-                     + "xxsXyJFFAkEAz0xTsTiMxRMyaIpytoTliE3JBC/g5375eo2Epb740jbdkFvC5cin\n"
-                     + "r6breljhbcm4LUIQG5sdnZspnxMH65N0LwJAEQ3mD27oPmZs6bFwxVTqTkvUUsP+\n"
-                     + "n/QSlSf25yCo9Zr92yEnALnm86YrwX7JHY8gt5jptpoueebzUqjlOKMIUQJANgru\n"
-                     + "+GljdB/mSxEq2uneNHfjuGAntOFZ8SHnz5FptU8M79gr1k02rExjPcd7hDeToDgS\n"
-                     + "JRSEPAOYTFWlbTpdCwJAU1dI02ailOUpa1Dso5Mi7kO6QPygJfGyI6HlomvvHQZ3\n"
-                     + "vyHKfLPKeAOfRYvkgHpf3q0WGoNh5M6GcQRwFQdhTA==\n" + "-----END RSA PRIVATE KEY-----",
-            "fa:69:2c:0c:81:03:80:39:33:4d:de:ef:13:3c:e6:ef");
-
-   public void testGood() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/key.xml");
-
-      KeyPair result = factory.create(injector.getInstance(KeyPairHandler.class)).parse(is);
-
-      assertEquals(result, keyPair);
-      assertEquals(result.getFingerPrint(), SshKeys.fingerprintPrivateKey(result.getPrivateKey()));
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeysHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeysHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeysHandlerTest.java
deleted file mode 100644
index 27d2cff..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/KeysHandlerTest.java
+++ /dev/null
@@ -1,50 +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.net.UnknownHostException;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.KeyPair;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code KeysHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "KeysHandlerTest")
-public class KeysHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/keysList.xml");
-
-      Set<KeyPair> result = factory.create(injector.getInstance(KeyPairsHandler.class)).parse(is);
-      assertEquals(result, ImmutableSet.of(new KeyPair(URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/extensions/key/9"), "default", true,
-            null, "4e:af:8a:9f:e9:d2:72:d7:4b:a0:da:98:72:98:4d:7d")));
-
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkExtendedInfoHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkExtendedInfoHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkExtendedInfoHandlerTest.java
deleted file mode 100644
index 7e5774f..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkExtendedInfoHandlerTest.java
+++ /dev/null
@@ -1,47 +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.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.NetworkExtendedInfo;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code NetworkExtendedInfoHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "NetworkExtendedInfoHandlerTest")
-public class NetworkExtendedInfoHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/TerremarkNetwork.xml");
-
-      NetworkExtendedInfo result = factory.create(injector.getInstance(NetworkExtendedInfoHandler.class)).parse(is);
-      assertEquals(result, new NetworkExtendedInfo("XXXXX", URI
-               .create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.5/extensions/network/XXXXX"),
-               "10.X.X.0/27", "209.X.X.X", "10.X.X.0", "10.X.X.X", "10.X.X.1", NetworkExtendedInfo.Type.DMZ, "279",
-               "10.X.X.0/27 (DMZ_279)"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkHandlerTest.java
deleted file mode 100644
index ca29bba..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NetworkHandlerTest.java
+++ /dev/null
@@ -1,72 +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.FenceMode;
-import org.jclouds.trmk.vcloud_0_8.domain.Network;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.NetworkImpl;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.Test;
-
-import com.google.inject.Guice;
-import com.google.inject.Injector;
-
-/**
- * Tests behavior of {@code VDCNetworkHandler}
- * 
- * @author Adrian Cole
- */
-@Test(groups = "unit")
-public class NetworkHandlerTest {
-
-   private Injector injector;
-
-   private Factory factory;
-
-   public void testTerremark() {
-      InputStream is = getClass().getResourceAsStream("/network-terremark.xml");
-      injector = Guice.createInjector(new SaxParserModule());
-      factory = injector.getInstance(ParseSax.Factory.class);
-      Network result = factory.create(injector.getInstance(NetworkHandler.class)).parse(is);
-      assertEquals(
-            result,
-            new NetworkImpl(
-                  "10.122.209.128/28",
-                  "application/vnd.vmware.vcloud.network+xml",
-                  URI.create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.5/network/40031"),
-                  null,
-                  "10.122.209.129",
-                  "255.255.255.240",
-                  FenceMode.ISOLATED,
-                  new ReferenceTypeImpl(
-                        "10.122.209.128/28",
-                        "application/xml",
-                        URI.create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.5/extensions/network/40031")),
-                  new ReferenceTypeImpl(
-                        "IP Addresses",
-                        "application/xml",
-                        URI.create("https://services.enterprisecloud.terremark.com/api/v0.8b-ext2.5/extensions/network/40031/ips"))));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodeHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodeHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodeHandlerTest.java
deleted file mode 100644
index 4e4ac18..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodeHandlerTest.java
+++ /dev/null
@@ -1,46 +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.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.Node;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code NodeHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "NodeHandlerTest")
-public class NodeHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/NodeService.xml");
-
-      Node result = factory.create(injector.getInstance(NodeHandler.class)).parse(is);
-      assertEquals(result, new Node("Node for Jim", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/NodeServices/242"), "172.16.20.3", 80,
-            false, "Some test node"));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodesHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodesHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodesHandlerTest.java
deleted file mode 100644
index ab9d827..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/NodesHandlerTest.java
+++ /dev/null
@@ -1,49 +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.net.UnknownHostException;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.Node;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code NodesHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "NodesHandlerTest")
-public class NodesHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/NodeServices.xml");
-
-      Set<Node> result = factory.create(injector.getInstance(NodesHandler.class)).parse(is);
-      assertEquals(result, ImmutableSet.of(new Node("Node for Jim", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/NodeServices/242"), "172.16.20.3", 80,
-            false, "Some test node")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgHandlerTest.java
deleted file mode 100644
index 0e9dd91..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgHandlerTest.java
+++ /dev/null
@@ -1,83 +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.jclouds.trmk.vcloud_0_8.TerremarkVCloudMediaType.TASKSLIST_XML;
-import static org.testng.Assert.assertEquals;
-
-import java.io.InputStream;
-import java.net.URI;
-
-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.Org;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.jclouds.trmk.vcloud_0_8.internal.TerremarkVCloudApiMetadata;
-import org.testng.annotations.BeforeTest;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableMap;
-import com.google.inject.Guice;
-import com.google.inject.name.Names;
-
-/**
- * Tests behavior of {@code OrgHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "OrgHandlerTest")
-public class OrgHandlerTest extends BaseHandlerTest {
-   @Override
-   @BeforeTest
-   protected void setUpInjector() {
-      injector = Guice.createInjector(new SaxParserModule() {
-         @Override
-         public void configure() {
-            super.configure();
-            Names.bindProperties(binder(), TerremarkVCloudApiMetadata.defaultProperties());
-         }
-      });
-      factory = injector.getInstance(ParseSax.Factory.class);
-      assert factory != null;
-   }
-
-   public void testApplyInputStream() {
-
-      InputStream is = getClass().getResourceAsStream("/org.xml");
-
-      Org result =  factory.create(injector.getInstance(OrgHandler.class)).parse(is);
-      assertEquals(result.getName(), "adrian@jclouds.org");
-      assertEquals(result.getHref(), URI.create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/org/48"));
-      assertEquals(result.getCatalogs(), ImmutableMap.of("Miami Environment 1 Catalog", new ReferenceTypeImpl(
-               "Miami Environment 1 Catalog", CATALOG_XML, URI
-                        .create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/vdc/32/catalog"))));
-      assertEquals(result.getVDCs(), ImmutableMap.of("Miami Environment 1", new ReferenceTypeImpl(
-               "Miami Environment 1", TerremarkVCloudMediaType.VDC_XML, URI
-                        .create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/vdc/32"))));
-      assertEquals(result.getTasksLists(), ImmutableMap.of(
-            "Miami Environment 1 Tasks List",
-            new ReferenceTypeImpl("Miami Environment 1 Tasks List", TASKSLIST_XML, URI
-                  .create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/vdc/32/tasksList"))));
-      assertEquals(result.getKeys(), new ReferenceTypeImpl("Keys", "application/vnd.tmrk.vcloudExpress.keysList+xml",
-               URI.create("https://services.vcloudexpress.terremark.com/api/v0.8a-ext1.6/extensions/org/48/keys")));
-
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgListHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgListHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgListHandlerTest.java
deleted file mode 100644
index 63cb575..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/OrgListHandlerTest.java
+++ /dev/null
@@ -1,49 +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.Map;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.ReferenceType;
-import org.jclouds.trmk.vcloud_0_8.domain.internal.ReferenceTypeImpl;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableMap;
-
-/**
- * Tests behavior of {@code OrgListHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "OrgListHandlerTest")
-public class OrgListHandlerTest extends BaseHandlerTest {
-
-   public void testApplyInputStream() {
-      InputStream is = getClass().getResourceAsStream("/orglist.xml");
-
-      Map<String, ReferenceType> result = factory.create(injector.getInstance(OrgListHandler.class)).parse(is);
-      assertEquals(result, ImmutableMap.of("adrian@jclouds.org", new ReferenceTypeImpl("adrian@jclouds.org",
-               "application/vnd.vmware.vcloud.org+xml", URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/org/48"))));
-   }
-   
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressHandlerTest.java
deleted file mode 100644
index 10718ca..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressHandlerTest.java
+++ /dev/null
@@ -1,45 +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.net.UnknownHostException;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.PublicIpAddress;
-import org.testng.annotations.Test;
-
-/**
- * Tests behavior of {@code PublicIpAddressHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "PublicIpAddressHandlerTest")
-public class PublicIpAddressHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/PublicIpAddress.xml");
-
-      PublicIpAddress result = factory.create(injector.getInstance(PublicIpAddressHandler.class)).parse(is);
-      assertEquals(result, new PublicIpAddress("204.51.112.91", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/8720")));
-   }
-}

http://git-wip-us.apache.org/repos/asf/incubator-jclouds/blob/ddfefd7e/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressesHandlerTest.java
----------------------------------------------------------------------
diff --git a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressesHandlerTest.java b/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressesHandlerTest.java
deleted file mode 100644
index 43487db..0000000
--- a/common/trmk/src/test/java/org/jclouds/trmk/vcloud_0_8/xml/PublicIpAddressesHandlerTest.java
+++ /dev/null
@@ -1,50 +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.net.UnknownHostException;
-import java.util.Set;
-
-import org.jclouds.http.functions.BaseHandlerTest;
-import org.jclouds.trmk.vcloud_0_8.domain.PublicIpAddress;
-import org.testng.annotations.Test;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Tests behavior of {@code PublicIpAddressesHandler}
- * 
- * @author Adrian Cole
- */
-// NOTE:without testName, this will not call @Before* and fail w/NPE during surefire
-@Test(groups = "unit", testName = "PublicIpAddressesHandlerTest")
-public class PublicIpAddressesHandlerTest extends BaseHandlerTest {
-
-   public void test1() throws UnknownHostException {
-      InputStream is = getClass().getResourceAsStream("/PublicIpAddresses.xml");
-
-      Set<PublicIpAddress> result = factory.create(injector.getInstance(PublicIpAddressesHandler.class)).parse(is);
-      assertEquals(result, ImmutableSet.of(new PublicIpAddress("204.51.112.91", URI
-            .create("https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/8720")), new PublicIpAddress(
-            "204.51.114.79", URI.create("https://services.vcloudexpress.terremark.com/api/v0.8/PublicIps/14965"))));
-
-   }
-}