You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jclouds.apache.org by na...@apache.org on 2018/01/08 14:55:46 UTC

[05/21] jclouds-labs git commit: Promoted Azure ARM to the main repo

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiLiveTest.java
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiLiveTest.java b/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiLiveTest.java
deleted file mode 100644
index 78d5425..0000000
--- a/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiLiveTest.java
+++ /dev/null
@@ -1,249 +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.azurecompute.arm.internal;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-import static org.jclouds.compute.config.ComputeServiceProperties.TIMEOUT_IMAGE_AVAILABLE;
-import static org.jclouds.util.Predicates2.retry;
-import static org.testng.Assert.assertNotNull;
-import static org.testng.Assert.assertTrue;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.TIMEOUT_RESOURCE_DELETED;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_DELETE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_SECRET_DELETE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_SECRET_RECOVERABLE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_KEY_DELETED_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_KEY_RECOVERABLE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_CERTIFICATE_DELETE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_CERTIFICATE_RECOVERABLE_STATUS;
-import static org.jclouds.azurecompute.arm.config.AzureComputeProperties.VAULT_CERTIFICATE_OPERATION_STATUS;
-
-import java.io.IOException;
-import java.net.URI;
-import java.util.Arrays;
-import java.util.List;
-import java.util.Properties;
-import java.util.Random;
-
-import com.google.common.base.Charsets;
-import com.google.common.base.Throwables;
-import com.google.common.io.Resources;
-import org.jclouds.apis.BaseApiLiveTest;
-import org.jclouds.azurecompute.arm.AzureComputeApi;
-import org.jclouds.azurecompute.arm.config.Tenant;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultPredicates.DeletedVaultStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultKeyPredicates.DeletedKeyStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultKeyPredicates.RecoverableKeyStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultSecretPredicates.DeletedSecretStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultSecretPredicates.RecoverableSecretStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultCertificatePredicates.CertificateOperationStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultCertificatePredicates.DeletedCertificateStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.VaultCertificatePredicates.RecoverableCertificateStatusPredicateFactory;
-import org.jclouds.azurecompute.arm.compute.config.AzurePredicatesModule.PublicIpAvailablePredicateFactory;
-import org.jclouds.azurecompute.arm.domain.NetworkSecurityGroup;
-import org.jclouds.azurecompute.arm.domain.NetworkSecurityGroupProperties;
-import org.jclouds.azurecompute.arm.domain.NetworkSecurityRule;
-import org.jclouds.azurecompute.arm.domain.NetworkSecurityRuleProperties;
-import org.jclouds.azurecompute.arm.domain.Provisionable;
-import org.jclouds.azurecompute.arm.domain.ResourceGroup;
-import org.jclouds.azurecompute.arm.domain.Subnet;
-import org.jclouds.azurecompute.arm.domain.VirtualNetwork;
-import org.testng.annotations.AfterClass;
-import org.testng.annotations.BeforeClass;
-
-import com.google.common.base.Predicate;
-import com.google.common.base.Supplier;
-import com.google.common.collect.ImmutableMap;
-import com.google.common.collect.Lists;
-import com.google.inject.name.Names;
-import com.google.inject.Injector;
-import com.google.inject.Module;
-import com.google.inject.Key;
-import com.google.inject.TypeLiteral;
-
-public class BaseAzureComputeApiLiveTest extends BaseApiLiveTest<AzureComputeApi> {
-
-   protected static final int RAND = new Random().nextInt(999);
-   public static final String LOCATION = "westeurope";
-   public static final String LOCATIONDESCRIPTION = "West Europe";
-   public static final String DEFAULT_VIRTUALNETWORK_ADDRESS_PREFIX = "10.2.0.0/16";
-   
-   protected Predicate<URI> imageAvailablePredicate;
-   protected Predicate<URI> resourceDeleted;
-   protected PublicIpAvailablePredicateFactory publicIpAvailable;
-   protected Predicate<Supplier<Provisionable>> resourceAvailable;
-   protected DeletedVaultStatusPredicateFactory deletedVaultStatus;
-   protected DeletedKeyStatusPredicateFactory deletedKeyStatus;
-   protected RecoverableKeyStatusPredicateFactory recoverableKeyStatus;
-   protected DeletedSecretStatusPredicateFactory deletedSecretStatus;
-   protected RecoverableSecretStatusPredicateFactory recoverableSecretStatus;
-   protected DeletedCertificateStatusPredicateFactory deletedCertificateStatus;
-   protected RecoverableCertificateStatusPredicateFactory recoverableCertificateStatus;
-   protected CertificateOperationStatusPredicateFactory certificateOperationStatus;
-
-
-   protected String resourceGroupName;
-   
-   protected String vaultResourceGroup;
-   protected String vaultName;
-   protected String vaultCertificateUrl;
-   protected String tenantId;
-
-   public BaseAzureComputeApiLiveTest() {
-      provider = "azurecompute-arm";
-   }
-   
-   @Override
-   @AfterClass(groups = "live")
-   protected void tearDown() {
-      try {
-         if (resourceGroupName != null) {
-            deleteResourceGroup(resourceGroupName);
-         }
-      } finally {
-         super.tearDown();
-      }
-   }
-
-   @BeforeClass
-   @Override
-   public void setup() {
-      super.setup();
-
-      // Providing system properties for specifying the required Azure KeyVault configurations for Live tests
-      // They have to be externally provided, because azurecompute-arm doesn't support creating KeyVaults yet
-      //
-      // TODO Replace the used configurations once full KeyVault implementation is added to azurecompute-arm
-      vaultResourceGroup = System.getProperty("test.azurecompute-arm.vault.resource.group");
-      vaultName = System.getProperty("test.azurecompute-arm.vault.name");
-      vaultCertificateUrl = System.getProperty("test.azurecompute-arm.vault.certificate.url");
-   }
-
-   @Override protected AzureComputeApi create(Properties props, Iterable<Module> modules) {
-      Injector injector = newBuilder().modules(modules).overrides(props).buildInjector();
-      imageAvailablePredicate = injector.getInstance(Key.get(new TypeLiteral<Predicate<URI>>() {
-      }, Names.named(TIMEOUT_IMAGE_AVAILABLE)));
-      resourceDeleted = injector.getInstance(Key.get(new TypeLiteral<Predicate<URI>>() {
-      }, Names.named(TIMEOUT_RESOURCE_DELETED)));
-      publicIpAvailable = injector.getInstance(PublicIpAvailablePredicateFactory.class);
-      resourceAvailable = injector.getInstance(Key.get(new TypeLiteral<Predicate<Supplier<Provisionable>>>() {
-      }));
-      deletedVaultStatus = injector.getInstance(Key.get(DeletedVaultStatusPredicateFactory.class, Names.named(VAULT_DELETE_STATUS)));
-      deletedKeyStatus = injector.getInstance(Key.get(DeletedKeyStatusPredicateFactory.class, Names.named(VAULT_KEY_DELETED_STATUS)));
-      recoverableKeyStatus = injector.getInstance(Key.get(RecoverableKeyStatusPredicateFactory.class, Names.named(VAULT_KEY_RECOVERABLE_STATUS)));
-      deletedSecretStatus = injector.getInstance(Key.get(DeletedSecretStatusPredicateFactory.class, Names.named(VAULT_SECRET_DELETE_STATUS)));
-      recoverableSecretStatus = injector.getInstance(Key.get(RecoverableSecretStatusPredicateFactory.class, Names.named(VAULT_SECRET_RECOVERABLE_STATUS)));
-      deletedCertificateStatus = injector.getInstance(Key.get(DeletedCertificateStatusPredicateFactory.class, Names.named(VAULT_CERTIFICATE_DELETE_STATUS)));
-      recoverableCertificateStatus = injector.getInstance(Key.get(RecoverableCertificateStatusPredicateFactory.class, Names.named(VAULT_CERTIFICATE_RECOVERABLE_STATUS)));
-      certificateOperationStatus = injector.getInstance(Key.get(CertificateOperationStatusPredicateFactory.class, Names.named(VAULT_CERTIFICATE_OPERATION_STATUS)));
-
-      tenantId = injector.getInstance(Key.get(String.class, Tenant.class));
-      return injector.getInstance(AzureComputeApi.class);
-   }
-
-   @Override protected Properties setupProperties() {
-      Properties properties = super.setupProperties();
-      // for oauth
-      AzureLiveTestUtils.defaultProperties(properties);
-      checkNotNull(setIfTestSystemPropertyPresent(properties, "oauth.endpoint"), "test.oauth.endpoint");
-      return properties;
-   }
-   
-   protected void assertResourceDeleted(URI uri) {
-      if (uri != null) {
-         assertTrue(resourceDeleted.apply(uri),
-               String.format("Resource %s was not terminated in the configured timeout", uri));
-      }
-   }
-
-   protected VirtualNetwork createDefaultVirtualNetwork(final String resourceGroupName, final String virtualNetworkName, final String virtualnetworkAddressPrefix, final String location) {
-      final VirtualNetwork.VirtualNetworkProperties virtualNetworkProperties =
-              VirtualNetwork.VirtualNetworkProperties.create(null, null,
-                      VirtualNetwork.AddressSpace.create(Arrays.asList(virtualnetworkAddressPrefix)), null);
-      VirtualNetwork virtualNetwork = api.getVirtualNetworkApi(resourceGroupName).createOrUpdate(virtualNetworkName, location, null, virtualNetworkProperties);
-      retry(new Predicate<String>() {
-         @Override
-         public boolean apply(final String name) {
-            VirtualNetwork virtualNetwork = api.getVirtualNetworkApi(resourceGroupName).get(name);
-            return virtualNetwork.properties().provisioningState().equals("Succeeded");
-         }
-      }, 60 * 4 * 1000).apply(virtualNetwork.name());
-      return virtualNetwork;
-   }
-
-   protected Subnet createDefaultSubnet(final String resourceGroupName, final String subnetName, final String virtualNetworkName, final String subnetAddressSpace) {
-      Subnet.SubnetProperties  properties = Subnet.SubnetProperties.builder().addressPrefix(subnetAddressSpace).build();
-      Subnet subnet = api.getSubnetApi(resourceGroupName, virtualNetworkName).createOrUpdate(subnetName, properties);
-      retry(new Predicate<String>() {
-         @Override
-         public boolean apply(final String name) {
-            Subnet subnet = api.getSubnetApi(resourceGroupName, virtualNetworkName).get(name);
-            return subnet.properties().provisioningState().equals("Succeeded");
-         }
-      }, 60 * 4 * 1000).apply(subnet.name());
-      return subnet;
-   }
-
-   protected void createTestResourceGroup() {
-      String name = String.format("rg-%s-%s", this.getClass().getSimpleName().toLowerCase(),
-            System.getProperty("user.name"));
-      ResourceGroup rg = api.getResourceGroupApi().create(name, LOCATION, ImmutableMap.<String, String> of());
-      assertNotNull(rg);
-      resourceGroupName = rg.name();
-   }
-
-   protected void deleteResourceGroup(final String resourceGroupName) {
-      URI uri = api.getResourceGroupApi().delete(resourceGroupName);
-      assertResourceDeleted(uri);
-   }
-
-   protected NetworkSecurityGroup newNetworkSecurityGroup(String nsgName, String locationName) {
-      NetworkSecurityRule rule = NetworkSecurityRule.create("denyallout", null, null,
-              NetworkSecurityRuleProperties.builder()
-                      .description("deny all out")
-                      .protocol(NetworkSecurityRuleProperties.Protocol.Tcp)
-                      .sourcePortRange("*")
-                      .destinationPortRange("*")
-                      .sourceAddressPrefix("*")
-                      .destinationAddressPrefix("*")
-                      .access(NetworkSecurityRuleProperties.Access.Deny)
-                      .priority(4095)
-                      .direction(NetworkSecurityRuleProperties.Direction.Outbound)
-                      .build());
-      List<NetworkSecurityRule> ruleList = Lists.newArrayList();
-      ruleList.add(rule);
-      NetworkSecurityGroup nsg = NetworkSecurityGroup.create("id", nsgName, locationName, null,
-              NetworkSecurityGroupProperties.builder()
-                      .securityRules(ruleList)
-                      .build(),
-              null);
-      return nsg;
-   }
-
-   protected String getSubscriptionId() {
-      String subscriptionId = endpoint.substring(endpoint.lastIndexOf("/") + 1);
-      assertNotNull(subscriptionId);
-      return subscriptionId;
-   }
-
-   protected String stringFromResource(String resourceName) {
-      try {
-         return Resources.toString(getClass().getResource(resourceName), Charsets.UTF_8);
-      } catch (IOException e) {
-         throw Throwables.propagate(e);
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiMockTest.java
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiMockTest.java b/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiMockTest.java
deleted file mode 100644
index 8a0efd4..0000000
--- a/azurecompute-arm/src/test/java/org/jclouds/azurecompute/arm/internal/BaseAzureComputeApiMockTest.java
+++ /dev/null
@@ -1,203 +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.azurecompute.arm.internal;
-
-import static com.google.common.base.Predicates.not;
-import static com.google.common.collect.Iterables.filter;
-import static com.google.common.util.concurrent.MoreExecutors.sameThreadExecutor;
-import static org.assertj.core.util.Sets.newHashSet;
-import static org.jclouds.oauth.v2.config.CredentialType.BEARER_TOKEN_CREDENTIALS;
-import static org.jclouds.oauth.v2.config.OAuthProperties.CREDENTIAL_TYPE;
-import static org.testng.Assert.assertEquals;
-
-import java.io.IOException;
-import java.net.URI;
-import java.net.URISyntaxException;
-import java.util.Properties;
-import java.util.Set;
-
-import org.jclouds.ContextBuilder;
-import org.jclouds.azurecompute.arm.AzureComputeApi;
-import org.jclouds.azurecompute.arm.AzureComputeProviderMetadata;
-import org.jclouds.azurecompute.arm.AzureManagementApiMetadata;
-import org.jclouds.azurecompute.arm.config.AzureComputeHttpApiModule;
-import org.jclouds.azurecompute.arm.config.GraphRBAC;
-import org.jclouds.concurrent.config.ExecutorServiceModule;
-import org.jclouds.date.DateService;
-import org.jclouds.providers.ProviderMetadata;
-import org.jclouds.rest.ApiContext;
-import org.jclouds.rest.ConfiguresHttpApi;
-import org.testng.annotations.AfterMethod;
-import org.testng.annotations.BeforeMethod;
-
-import com.google.common.base.Charsets;
-import com.google.common.base.Predicates;
-import com.google.common.base.Supplier;
-import com.google.common.base.Suppliers;
-import com.google.common.base.Throwables;
-import com.google.common.collect.ImmutableSet;
-import com.google.common.io.Resources;
-import com.google.gson.JsonParser;
-import com.google.inject.Module;
-import com.google.inject.TypeLiteral;
-import com.squareup.okhttp.mockwebserver.MockResponse;
-import com.squareup.okhttp.mockwebserver.MockWebServer;
-import com.squareup.okhttp.mockwebserver.RecordedRequest;
-
-public class BaseAzureComputeApiMockTest {
-
-   private static final String MOCK_BEARER_TOKEN = "eyJ0eXAiOiJKV1QiLCJhbGciOiJSUzI1NiIsIng1dCI6Ik1uQ19WWmNBVGZNNXBPWWlKSE1iYTlnb0VLWSIsImtpZCI6Ik1uQ19WWmNBVGZNNXBPWWlKSE1iYTlnb0VLWSJ9";
-   private static final String DEFAULT_ENDPOINT = new AzureComputeProviderMetadata().getEndpoint();
-
-   protected MockWebServer server;
-   protected AzureComputeApi api;
-   protected ApiContext<AzureComputeApi> context;
-   protected DateService dateService;
-
-   // So that we can ignore formatting.
-   private final JsonParser parser = new JsonParser();
-
-   @BeforeMethod
-   public void start() throws IOException, URISyntaxException {
-      server = new MockWebServer();
-      server.play();
-      
-      context = ContextBuilder.newBuilder(testProviderMetadata())
-              .credentials("mock", MOCK_BEARER_TOKEN)
-              .endpoint(server.getUrl("/").toString() + "subscriptions/SUBSCRIPTIONID")
-              .modules(setupModules())
-              .overrides(setupProperties())
-              .build();
-      api = context.getApi();
-      dateService = context.utils().injector().getInstance(DateService.class);
-   }
-   
-   protected ProviderMetadata testProviderMetadata() {
-      // Omit the default HTTP API modules to allow overriding
-      Set<Class<? extends Module>> defaultModules = newHashSet(filter(
-            new AzureManagementApiMetadata().getDefaultModules(),
-            not(Predicates.<Class<? extends Module>> equalTo(AzureComputeHttpApiModule.class))));
-      return AzureComputeProviderMetadata.builder()
-            .apiMetadata(AzureManagementApiMetadata.builder().defaultModules(defaultModules).build()).build();
-   }
-
-   protected Properties setupProperties() {
-      Properties properties = new Properties();
-      properties.put(CREDENTIAL_TYPE, BEARER_TOKEN_CREDENTIALS.toString());
-      properties.put("oauth.endpoint", "https://login.microsoftonline.com/tenant-id/oauth2/token");
-      return properties;
-   }
-
-   protected Set<Module> setupModules() {
-      ImmutableSet.Builder<Module> modules = ImmutableSet.builder();
-      modules.add(new ExecutorServiceModule(sameThreadExecutor()));
-      // Override the default HTTP module to accomodate custom bindings for the
-      // hardcoded endpoints such as the Graph RBAC API one.
-      modules.add(new TestAzureComputeHttpApiModule(server));
-      return modules.build();
-   }
-   
-   @AfterMethod(alwaysRun = true)
-   public void stop() throws IOException {
-      server.shutdown();
-      api.close();
-   }
-
-   protected String url(String path) {
-      return server.getUrl(path).toString();
-   }
-
-   protected MockResponse jsonResponse(String resource) {
-      return new MockResponse().addHeader("Content-Type", "application/json").setBody(stringFromResource(resource));
-   }
-
-   protected MockResponse response404() {
-      return new MockResponse().setStatus("HTTP/1.1 404 Not Found");
-   }
-
-   protected MockResponse response200() {
-      return new MockResponse().setStatus("HTTP/1.1 200 OK");
-   }
-
-   protected MockResponse response202() {
-      return new MockResponse().setStatus("HTTP/1.1 202 Accepted");
-   }
-
-   protected MockResponse response204() {
-      return new MockResponse().setStatus("HTTP/1.1 204 No Content");
-   }
-
-   protected MockResponse response202WithHeader() {
-      return new MockResponse()
-            .setStatus("HTTP/1.1 202 Accepted")
-            .addHeader(
-                  "Location",
-                  "https://management.azure.com/subscriptions/SUBSCRIPTIONID/operationresults/eyJqb2JJZCI6IlJFU09VUkNFR1JPVVBERUxFVElPTkpPQi1SVEVTVC1DRU5UUkFMVVMiLCJqb2JMb2NhdGlvbiI6ImNlbnRyYWx1cyJ9?api-version=2014-04-01");
-   }
-
-   protected MockResponse response200WithHeader() {
-      return new MockResponse()
-              .setStatus("HTTP/1.1 200 O")
-              .addHeader("Location", "https://management.azure.com/subscriptions/SUBSCRIPTIONID/operationresults/eyJqb2JJZCI6IlJFU09VUkNFR1JPVVBERUxFVElPTkpPQi1SVEVTVC1DRU5UUkFMVVMiLCJqb2JMb2NhdGlvbiI6ImNlbnRyYWx1cyJ9?api-version=2014-04-01");
-   }
-
-   protected String stringFromResource(String resourceName) {
-      try {
-         String rsrc = Resources.toString(getClass().getResource(resourceName), Charsets.UTF_8);
-         if (rsrc.contains(DEFAULT_ENDPOINT)) {
-            rsrc = rsrc.replace(DEFAULT_ENDPOINT, url(""));
-         }
-         return rsrc;
-      } catch (IOException e) {
-         throw Throwables.propagate(e);
-      }
-   }
-
-   protected RecordedRequest assertSent(MockWebServer server, String method, String path) throws InterruptedException {
-      RecordedRequest request = server.takeRequest();
-      assertEquals(request.getMethod(), method);
-      assertEquals(request.getPath(), path);
-      assertEquals(request.getHeader("Accept"), "application/json");
-      assertEquals(request.getHeader("Authorization"), "Bearer " + MOCK_BEARER_TOKEN);
-      return request;
-   }
-
-   protected RecordedRequest assertSent(MockWebServer server, String method, String path, String json)
-         throws InterruptedException {
-      RecordedRequest request = assertSent(server, method, path);
-      assertEquals(request.getHeader("Content-Type"), "application/json");
-      assertEquals(parser.parse(new String(request.getBody(), Charsets.UTF_8)), parser.parse(json));
-      return request;
-   }
-   
-   @ConfiguresHttpApi
-   private static class TestAzureComputeHttpApiModule extends AzureComputeHttpApiModule {
-      private final MockWebServer server;
-      
-      public TestAzureComputeHttpApiModule(MockWebServer server) {
-         this.server = server;
-      }
-
-      @Override
-      protected void bindServiceEndpoints() {
-         // Override the hardcoded service URIs to allow mocking service endpoints
-         bind(new TypeLiteral<Supplier<URI>>() {
-         }).annotatedWith(GraphRBAC.class).toInstance(
-               Suppliers.ofInstance(URI.create(server.getUrl("/graphrbac").toString() + "/tenant-id")));
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/PublicIPAddressCreate.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/PublicIPAddressCreate.json b/azurecompute-arm/src/test/resources/PublicIPAddressCreate.json
deleted file mode 100644
index d9e06aa..0000000
--- a/azurecompute-arm/src/test/resources/PublicIPAddressCreate.json
+++ /dev/null
@@ -1,20 +0,0 @@
-{
-  "name": "mypublicaddress",
-  "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/mypublicaddress",
-  "etag": "W/\"f0bdaf62-456b-4338-8f65-05417b1a55e9\"",
-  "type": "Microsoft.Network/publicIPAddresses",
-  "location": "northeurope",
-  "tags": {
-    "testkey": "testvalue"
-  },
-  "properties": {
-    "provisioningState": "Updating",
-    "resourceGuid": "ebe3f160-2484-447a-8980-c587b214b16f",
-    "publicIPAllocationMethod": "Static",
-    "idleTimeoutInMinutes": 4,
-    "dnsSettings": {
-      "domainNameLabel": "foobar",
-      "fqdn": "foobar.northeurope.cloudapp.azure.com"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/PublicIPAddressCreateDnsRecordInUse.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/PublicIPAddressCreateDnsRecordInUse.json b/azurecompute-arm/src/test/resources/PublicIPAddressCreateDnsRecordInUse.json
deleted file mode 100644
index 16a52c8..0000000
--- a/azurecompute-arm/src/test/resources/PublicIPAddressCreateDnsRecordInUse.json
+++ /dev/null
@@ -1,7 +0,0 @@
-{
-  "error": {
-    "code": "DnsRecordInUse",
-    "message": "DNS record foobar.northeurope.cloudapp.azure.com is already used by another public IP.",
-    "details": []
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/PublicIPAddressGetInfo.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/PublicIPAddressGetInfo.json b/azurecompute-arm/src/test/resources/PublicIPAddressGetInfo.json
deleted file mode 100644
index 00ca989..0000000
--- a/azurecompute-arm/src/test/resources/PublicIPAddressGetInfo.json
+++ /dev/null
@@ -1,24 +0,0 @@
-{
-  "name": "mypublicaddress",
-  "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/mypublicaddress",
-  "etag": "W/\"0b020646-202f-4ac6-b1a7-f9645db7c371\"",
-  "type": "Microsoft.Network/publicIPAddresses",
-  "location": "northeurope",
-  "tags": {
-    "testkey": "testvalue"
-  },
-  "properties": {
-    "provisioningState": "Succeeded",
-    "resourceGuid": "eb0da01e-2a30-4e84-b7a4-0ce9dde019f5",
-    "ipAddress": "12.123.12.123",
-    "publicIPAllocationMethod": "Static",
-    "idleTimeoutInMinutes": 4,
-    "dnsSettings": {
-      "domainNameLabel": "foobar",
-      "fqdn": "foobar.northeurope.cloudapp.azure.com"
-    },
-    "ipConfiguration": {
-      "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-    }
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/PublicIPAddressList.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/PublicIPAddressList.json b/azurecompute-arm/src/test/resources/PublicIPAddressList.json
deleted file mode 100644
index 2b78b37..0000000
--- a/azurecompute-arm/src/test/resources/PublicIPAddressList.json
+++ /dev/null
@@ -1,80 +0,0 @@
-{
-  "value": [
-    {
-      "name": "my2ndpublicaddress",
-      "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/my2ndpublicaddress",
-      "etag": "W/\"b83fa879-46ee-48a9-8120-26572449788f\"",
-      "type": "Microsoft.Network/publicIPAddresses",
-      "location": "northeurope",
-      "tags": {
-        "testkey": "testvalue"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "ebe3f160-2484-447a-8980-c587b214b16f",
-        "publicIPAllocationMethod": "Dynamic",
-        "idleTimeoutInMinutes": 4,
-        "dnsSettings": {
-          "domainNameLabel": "foobar123",
-          "fqdn": "foobar123.northeurope.cloudapp.azure.com"
-        }
-      }
-    },
-    {
-      "name": "my3rdpublicaddress",
-      "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/my3rdpublicaddress",
-      "etag": "W/\"17d2cf9a-7aa8-4c53-a5b8-ebc2ccb7bf93\"",
-      "type": "Microsoft.Network/publicIPAddresses",
-      "location": "northeurope",
-      "tags": {
-        "testkey": "testvalue"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "e1107240-79c5-4829-ba16-f7a00c2763df",
-        "ipAddress": "12.12.123.123",
-        "publicIPAllocationMethod": "Static",
-        "idleTimeoutInMinutes": 4
-      }
-    },
-    {
-      "name": "my4thpublicaddress",
-      "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/my4thpublicaddress",
-      "etag": "W/\"c32275e9-e1fc-465a-a5de-728c1359e123\"",
-      "type": "Microsoft.Network/publicIPAddresses",
-      "location": "northeurope",
-      "tags": {
-        "testkey": "testvalue"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "dbde9a83-8c1a-43f4-8d81-0fa469703e8a",
-        "ipAddress": "12.12.123.124",
-        "publicIPAllocationMethod": "Static",
-        "idleTimeoutInMinutes": 4
-      }
-    },
-    {
-      "name": "mypublicaddress",
-      "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/publicIPAddresses/mypublicaddress",
-      "etag": "W/\"0b020646-202f-4ac6-b1a7-f9645db7c371\"",
-      "type": "Microsoft.Network/publicIPAddresses",
-      "location": "northeurope",
-      "tags": {},
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "eb0da01e-2a30-4e84-b7a4-0ce9dde019f5",
-        "ipAddress": "12.123.12.125",
-        "publicIPAllocationMethod": "Static",
-        "idleTimeoutInMinutes": 4,
-        "dnsSettings": {
-          "domainNameLabel": "foobar",
-          "fqdn": "foobar.northeurope.cloudapp.azure.com"
-        },
-        "ipConfiguration": {
-          "id": "/subscriptions/fakeb2f5-4710-4e93-bdf4-419edbde2178/resourceGroups/myresourcegroup/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-        }
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/availabilitysetcreate.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/availabilitysetcreate.json b/azurecompute-arm/src/test/resources/availabilitysetcreate.json
deleted file mode 100644
index 748f749..0000000
--- a/azurecompute-arm/src/test/resources/availabilitysetcreate.json
+++ /dev/null
@@ -1,11 +0,0 @@
-{
-  "properties": {
-    "platformUpdateDomainCount": 2,
-    "platformFaultDomainCount": 3
-  },
-  "type": "Microsoft.Compute/availabilitySets",
-  "location": "westeurope",
-  "tags": {},
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/availabilitySets/myas",
-  "name": "myas"
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/availabilitysetget.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/availabilitysetget.json b/azurecompute-arm/src/test/resources/availabilitysetget.json
deleted file mode 100644
index 97870cb..0000000
--- a/azurecompute-arm/src/test/resources/availabilitysetget.json
+++ /dev/null
@@ -1,12 +0,0 @@
-{
-  "properties": {
-    "platformUpdateDomainCount": 2,
-    "platformFaultDomainCount": 3,
-    "virtualMachines": []
-  },
-  "type": "Microsoft.Compute/availabilitySets",
-  "location": "westeurope",
-  "tags": {},
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/availabilitySets/myas",
-  "name": "myas"
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/availabilitysetlist.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/availabilitysetlist.json b/azurecompute-arm/src/test/resources/availabilitysetlist.json
deleted file mode 100644
index 77b8fbf..0000000
--- a/azurecompute-arm/src/test/resources/availabilitysetlist.json
+++ /dev/null
@@ -1,16 +0,0 @@
-{
-  "value": [
-    {
-      "properties": {
-        "platformUpdateDomainCount": 2,
-        "platformFaultDomainCount": 3,
-        "virtualMachines": []
-      },
-      "type": "Microsoft.Compute/availabilitySets",
-      "location": "westeurope",
-      "tags": {},
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/availabilitySets/myas",
-      "name": "myas"
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createdeploymentaccepted.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createdeploymentaccepted.json b/azurecompute-arm/src/test/resources/createdeploymentaccepted.json
deleted file mode 100644
index 8ae5a59..0000000
--- a/azurecompute-arm/src/test/resources/createdeploymentaccepted.json
+++ /dev/null
@@ -1,33 +0,0 @@
-{
-  "id": "/subscriptions/04f7ec88-8e28-41ed-8537-5e17766001f5/resourceGroups/jims216group/providers/Microsoft.Resources/deployments/jcdep1458344383064",
-  "name": "jcdep1458344383064",
-  "properties": {
-    "parameters": {
-      "newStorageAccountName": {
-        "type": "String",
-        "value": "jcres1458344383064"
-      },
-      "storageAccountType": {
-        "type": "String",
-        "value": "Standard_LRS"
-      },
-      "location": {
-        "type": "String",
-        "value": "West US"
-      }
-    },
-    "mode": "Incremental",
-    "provisioningState": "Accepted",
-    "timestamp": "2016-03-18T23:39:47.3048037Z",
-    "duration": "PT2.4433028S",
-    "correlationId": "8dee9711-8632-4948-9fe6-368bb75e6438",
-    "providers": [{
-      "namespace": "Microsoft.Storage",
-      "resourceTypes": [{
-        "resourceType": "storageAccounts",
-        "locations": ["westus"]
-      }]
-    }],
-    "dependencies": []
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createdeploymentsucceeded.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createdeploymentsucceeded.json b/azurecompute-arm/src/test/resources/createdeploymentsucceeded.json
deleted file mode 100644
index e992204..0000000
--- a/azurecompute-arm/src/test/resources/createdeploymentsucceeded.json
+++ /dev/null
@@ -1,36 +0,0 @@
-{
-  "id": "/subscriptions/04f7ec88-8e28-41ed-8537-5e17766001f5/resourceGroups/jims216group/providers/Microsoft.Resources/deployments/jcdep1458344383064",
-  "name": "jcdep1458344383064",
-  "properties": {
-    "parameters": {
-      "newStorageAccountName": {
-        "type": "String",
-        "value": "jcres1458344383064"
-      },
-      "storageAccountType": {
-        "type": "String",
-        "value": "Standard_LRS"
-      },
-      "location": {
-        "type": "String",
-        "value": "West US"
-      }
-    },
-    "mode": "Incremental",
-    "provisioningState": "Succeeded",
-    "timestamp": "2016-03-18T23:40:25.1856907Z",
-    "duration": "PT40.3241898S",
-    "correlationId": "8dee9711-8632-4948-9fe6-368bb75e6438",
-    "providers": [{
-      "namespace": "Microsoft.Storage",
-      "resourceTypes": [{
-        "resourceType": "storageAccounts",
-        "locations": ["westus"]
-      }]
-    }],
-    "dependencies": [],
-    "outputResources": [{
-      "id": "Microsoft.Storage/storageAccounts/jcres1458344383064"
-    }]
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/creatediskresponse.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/creatediskresponse.json b/azurecompute-arm/src/test/resources/creatediskresponse.json
deleted file mode 100644
index 1fcc2bb..0000000
--- a/azurecompute-arm/src/test/resources/creatediskresponse.json
+++ /dev/null
@@ -1,11 +0,0 @@
-{
-  "properties": {
-    "creationData": {
-      "createOption": "Empty"
-    },
-    "diskSizeGB": 2,
-    "provisioningState": "Updating",
-    "isArmResource": true
-  },
-  "location": "westeurope"
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createnetworkinterfacecard.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createnetworkinterfacecard.json b/azurecompute-arm/src/test/resources/createnetworkinterfacecard.json
deleted file mode 100644
index d08b8f6..0000000
--- a/azurecompute-arm/src/test/resources/createnetworkinterfacecard.json
+++ /dev/null
@@ -1,35 +0,0 @@
-{
-  "name": "myNic",
-  "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic",
-  "etag": "W/\"6b51f6e7-232b-4289-b740-04a996929f5e\"",
-  "type": "Microsoft.Network/networkInterfaces",
-  "location": "northeurope",
-  "tags": {
-    "mycustomtag": "foobar"
-  },
-  "properties": {
-    "provisioningState": "Succeeded",
-    "resourceGuid": "f3465472-536f-49e7-9e9c-fa91b971a618",
-    "ipConfigurations": [
-      {
-        "name": "myip1",
-        "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1",
-        "etag": "W/\"6b51f6e7-232b-4289-b740-04a996929f5e\"",
-        "properties": {
-          "provisioningState": "Succeeded",
-          "privateIPAddress": "10.2.0.4",
-          "privateIPAllocationMethod": "Dynamic",
-          "subnet": {
-            "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet"
-          },
-          "primary": true
-        }
-      }
-    ],
-    "dnsSettings": {
-      "dnsServers": [],
-      "appliedDnsServers": []
-    },
-    "enableIPForwarding": false
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createsubnet.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createsubnet.json b/azurecompute-arm/src/test/resources/createsubnet.json
deleted file mode 100644
index 60db9cf..0000000
--- a/azurecompute-arm/src/test/resources/createsubnet.json
+++ /dev/null
@@ -1,5 +0,0 @@
-{
-  "properties":{
-    "addressPrefix":"10.2.0.0/24"
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createsubnetresponse.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createsubnetresponse.json b/azurecompute-arm/src/test/resources/createsubnetresponse.json
deleted file mode 100644
index 0be69a6..0000000
--- a/azurecompute-arm/src/test/resources/createsubnetresponse.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-  "name": "mysubnet",
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet",
-  "etag": "W/\"b68ab7a3-38d5-4690-a978-20149a6a0994\"",
-  "properties": {
-    "provisioningState": "Succeeded",
-    "addressPrefix": "10.2.0.0/24",
-    "ipConfigurations": [
-      {
-        "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-      }
-    ]
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createvirtualmachineresponse.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createvirtualmachineresponse.json b/azurecompute-arm/src/test/resources/createvirtualmachineresponse.json
deleted file mode 100644
index 7402e14..0000000
--- a/azurecompute-arm/src/test/resources/createvirtualmachineresponse.json
+++ /dev/null
@@ -1,109 +0,0 @@
-{
-  "properties": {
-    "vmId": "27ee085b-d707-xxxx-yyyy-2370e2eb1cc1",
-    "licenseType": "Windows_Server",
-    "availabilitySet": {
-      "id":"/subscriptions/SUBSCRIPTIONID/resourceGroups/myResourceGroup/providers/Microsoft.Compute/availabilitySets/myAVSet"
-    },
-    "hardwareProfile": {
-      "vmSize": "Standard_D1"
-    },
-    "storageProfile": {
-      "imageReference": {
-        "publisher": "publisher",
-        "offer": "OFFER",
-        "sku": "sku",
-        "version": "ver",
-        "id": "/subscriptions/SUBSCRIPTIONID/providers/Microsoft.Compute/locations/westus/publishers/MicrosoftWindowsServerEssentials/artifactype/vmimage/offers/OFFER/skus/OFFER/versions/latest"
-      },
-      "osDisk": {
-        "osType": "Windows",
-        "name": "windowsmachine",
-        "createOption": "FromImage",
-        "managedDisk": {
-          "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myResourceGroup/providers/Microsoft.Compute/disks/osDisk",
-          "storageAccountType": "Standard_LRS"
-        },
-        "caching": "ReadWrite"
-      },
-      "dataDisks":[
-        {
-          "name":"mydatadisk1",
-          "diskSizeGB":"1",
-          "lun": 0,
-          "managedDisk": {
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myResourceGroup/providers/Microsoft.Compute/disks/osDisk",
-            "storageAccountType": "Standard_LRS"
-          },
-          "caching": "ReadWrite",
-          "createOption":"Empty"
-        }
-      ]
-    },
-    "osProfile": {
-      "computerName": "windowsmachine",
-      "adminUsername": "azureuser",
-      "adminPassword": "password",
-      "customData": "",
-      "windowsConfiguration": {
-        "provisionVMAgent": false,
-        "enableAutomaticUpdates": true,
-        "winRM": {    
-          "listeners": [
-            {    
-              "protocol": "https",    
-              "certificateUrl": "url-to-certificate"    
-            }
-          ]
-        },    
-        "additionalUnattendContent": [
-          {      
-            "passName":"oobesystem",    
-            "componentName":"Microsoft-Windows-Shell-Setup",    
-            "settingName":"FirstLogonCommands",    
-            "content":"<XML unattend content>"    
-          }
-        ]
-      },
-      "secrets":[
-        {     
-          "sourceVault": {
-             "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup1/providers/Microsoft.KeyVault/vaults/myvault1"     
-           },
-           "vaultCertificates": [
-             {
-               "certificateUrl": "https://myvault1.vault.azure.net/secrets/SECRETNAME/SECRETVERSION",
-               "certificateStore": "CERTIFICATESTORENAME"
-             }
-           ]
-         }
-       ]
-    },
-    "networkProfile": {
-      "networkInterfaces":[
-        {
-          "id":"/subscriptions/SUBSCRIPTIONID/resourceGroups/groupname/providers/Microsoft.Network/networkInterfaces/windowsmachine167"
-        }
-      ]
-    },
-    "diagnosticsProfile": {
-      "bootDiagnostics": {
-        "enabled": true,
-        "storageUri": "https://groupname2760.blob.core.windows.net/"
-      }
-    },
-    "provisioningState": "Creating"
-  },
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/groupname/providers/Microsoft.Compute/virtualMachines/windowsmachine",
-  "name": "windowsmachine",
-  "type": "Microsoft.Compute/virtualMachines",
-  "location": "westus",
-  "tags": {
-    "foo": "bar"
-  },
-  "plan": {
-    "name": "deadline-slave-7-2",
-    "publisher": "thinkboxsoftware",
-    "product": "deadline7-2"
-  }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/createvirtualnetwork.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/createvirtualnetwork.json b/azurecompute-arm/src/test/resources/createvirtualnetwork.json
deleted file mode 100644
index 49484b0..0000000
--- a/azurecompute-arm/src/test/resources/createvirtualnetwork.json
+++ /dev/null
@@ -1,20 +0,0 @@
-{
-  "name": "mockvirtualnetwork",
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/mockvirtualnetwork",
-  "etag": "W/\"bb0f3bf7-381e-424b-8e00-8f813c61956c\"",
-  "type": "Microsoft.Network/virtualNetworks",
-  "location": "westeurope",
-  "tags": {
-    "key": "value"
-  },
-  "properties": {
-    "provisioningState": "Updating",
-    "resourceGuid": "5192bdb3-f6ed-44ad-bf4c-059cff905791",
-    "addressSpace": {
-      "addressPrefixes": [
-        "10.2.0.0/16"
-      ]
-    },
-    "subnets": []
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/getdisk.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/getdisk.json b/azurecompute-arm/src/test/resources/getdisk.json
deleted file mode 100644
index db09d8d..0000000
--- a/azurecompute-arm/src/test/resources/getdisk.json
+++ /dev/null
@@ -1,19 +0,0 @@
-{
-  "sku": {
-    "name": "Standard_LRS",
-    "tier": "Standard"
-  },
-  "properties": {
-    "creationData": {
-      "createOption": "Empty"
-    },
-    "diskSizeGB": 2,
-    "timeCreated": "2017-03-01T09:38:18.5808215+00:00",
-    "provisioningState": "Succeeded",
-    "diskState": "Unattached"
-  },
-  "type": "Microsoft.Compute/disks",
-  "location": "westeurope",
-  "id": "/subscriptions/610bba05-d7a7-4567-96af-48ecbd09453b/resourceGroups/rg-diskapilivetest-andrea/providers/Microsoft.Compute/disks/myDisk",
-  "name": "myDisk"
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/getnetworkinterfacecard.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/getnetworkinterfacecard.json b/azurecompute-arm/src/test/resources/getnetworkinterfacecard.json
deleted file mode 100644
index f613291..0000000
--- a/azurecompute-arm/src/test/resources/getnetworkinterfacecard.json
+++ /dev/null
@@ -1,35 +0,0 @@
-{
-  "name": "myNic",
-  "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic",
-  "etag": "W/\"3dff0c55-a7a7-434f-837b-0cad946b755f\"",
-  "type": "Microsoft.Network/networkInterfaces",
-  "location": "northeurope",
-  "tags": {
-    "mycustomtag": "foobar"
-  },
-  "properties": {
-    "provisioningState": "Succeeded",
-    "resourceGuid": "f3465472-536f-49e7-9e9c-fa91b971a618",
-    "ipConfigurations": [
-      {
-        "name": "myip1",
-        "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1",
-        "etag": "W/\"3dff0c55-a7a7-434f-837b-0cad946b755f\"",
-        "properties": {
-          "provisioningState": "Succeeded",
-          "privateIPAddress": "10.2.0.4",
-          "privateIPAllocationMethod": "Dynamic",
-          "subnet": {
-            "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet"
-          },
-          "primary": true
-        }
-      }
-    ],
-    "dnsSettings": {
-      "dnsServers": [],
-      "appliedDnsServers": []
-    },
-    "enableIPForwarding": false
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/getonesubnet.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/getonesubnet.json b/azurecompute-arm/src/test/resources/getonesubnet.json
deleted file mode 100644
index b1c7786..0000000
--- a/azurecompute-arm/src/test/resources/getonesubnet.json
+++ /dev/null
@@ -1,14 +0,0 @@
-{
-  "name": "mysubnet",
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet",
-  "etag": "W/\"bc7e1d77-eec0-4b91-ae80-afc33cf3c867\"",
-  "properties": {
-    "provisioningState": "Succeeded",
-    "addressPrefix": "10.2.0.0/24",
-    "ipConfigurations": [
-      {
-        "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-      }
-    ]
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/getresourceprovidermetadata.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/getresourceprovidermetadata.json b/azurecompute-arm/src/test/resources/getresourceprovidermetadata.json
deleted file mode 100644
index b7693d7..0000000
--- a/azurecompute-arm/src/test/resources/getresourceprovidermetadata.json
+++ /dev/null
@@ -1,366 +0,0 @@
-{
-  "id": "/subscriptions/SUBSCRIPTIONID/providers/Microsoft.Compute",
-  "namespace": "Microsoft.Compute",
-  "authorization": {
-    "applicationId": "12312312-1212-1212-1212-121212121212",
-    "roleDefinitionId": "34534534-272e-4238-8723-123423452224"
-  },
-  "resourceTypes": [
-    {
-      "resourceType": "availabilitySets",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ],
-      "capabilities": "CrossResourceGroupResourceMove, CrossSubscriptionResourceMove"
-    },
-    {
-      "resourceType": "virtualMachines",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ],
-      "capabilities": "CrossResourceGroupResourceMove, CrossSubscriptionResourceMove"
-    },
-    {
-      "resourceType": "virtualMachines/extensions",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ],
-      "capabilities": "CrossResourceGroupResourceMove, CrossSubscriptionResourceMove"
-    },
-    {
-      "resourceType": "virtualMachines/diagnosticSettings",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2014-04-01"
-      ]
-    },
-    {
-      "resourceType": "virtualMachines/metricDefinitions",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2014-04-01"
-      ]
-    },
-    {
-      "resourceType": "virtualMachineScaleSets",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ],
-      "capabilities": "None"
-    },
-    {
-      "resourceType": "virtualMachineScaleSets/extensions",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ],
-      "capabilities": "CrossResourceGroupResourceMove, CrossSubscriptionResourceMove"
-    },
-    {
-      "resourceType": "virtualMachineScaleSets/virtualMachines",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "virtualMachineScaleSets/networkInterfaces",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "virtualMachineScaleSets/virtualMachines/networkInterfaces",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "locations",
-      "locations": [],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "locations/operations",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "locations/vmSizes",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "locations/usages",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "locations/publishers",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    },
-    {
-      "resourceType": "operations",
-      "locations": [
-        "East US",
-        "East US 2",
-        "West US",
-        "Central US",
-        "North Central US",
-        "South Central US",
-        "North Europe",
-        "West Europe",
-        "East Asia",
-        "Southeast Asia",
-        "Japan East",
-        "Japan West",
-        "Brazil South"
-      ],
-      "apiVersions": [
-        "2016-03-30",
-        "2015-06-15",
-        "2015-05-01-preview"
-      ]
-    }
-  ],
-  "registrationState": "Registered"
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/getvault.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/getvault.json b/azurecompute-arm/src/test/resources/getvault.json
deleted file mode 100644
index 53bee7d..0000000
--- a/azurecompute-arm/src/test/resources/getvault.json
+++ /dev/null
@@ -1,60 +0,0 @@
-{
-  "id": "/subscriptions/012e832d-7b27-4c30-9f21-22cdd9159d12/resourceGroups/rg-vaultapilivetest-andrea/providers/Microsoft.KeyVault/vaults/vaultapilivetest-andrea",
-  "name": "vaultapilivetest-andrea",
-  "type": "Microsoft.KeyVault/vaults",
-  "location": "westeurope",
-  "tags": {},
-  "properties": {
-    "sku": {
-      "family": "A",
-      "name": "Standard"
-    },
-    "tenantId": "ba85e8cd-8c83-486e-a7e3-0d7666169d34",
-    "accessPolicies": [
-      {
-        "tenantId": "ba85e8cd-8c83-486e-a7e3-0d7666169d34",
-        "objectId": "b025a8c0-d7fa-42fd-8e62-d988a3f12791",
-        "permissions": {
-          "keys": [
-            "Get",
-            "List",
-            "Update",
-            "Create",
-            "Import",
-            "Delete",
-            "Recover",
-            "Backup",
-            "Restore"
-          ],
-          "secrets": [
-            "Get",
-            "List",
-            "Set",
-            "Delete",
-            "Recover",
-            "Backup",
-            "Restore"
-          ],
-          "certificates": [
-            "Get",
-            "List",
-            "Update",
-            "Create",
-            "Import",
-            "Delete",
-            "ManageContacts",
-            "ManageIssuers",
-            "GetIssuers",
-            "ListIssuers",
-            "SetIssuers",
-            "DeleteIssuers"
-          ]
-        }
-      }
-    ],
-    "enabledForDeployment": false,
-    "enabledForDiskEncryption": false,
-    "enabledForTemplateDeployment": false,
-    "vaultUri": "https://vaultapilivetest-andrea.vault.azure.net/"
-  }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/image.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/image.json b/azurecompute-arm/src/test/resources/image.json
deleted file mode 100644
index 0c7b54c..0000000
--- a/azurecompute-arm/src/test/resources/image.json
+++ /dev/null
@@ -1,43 +0,0 @@
-{
-  "location": "West US",
-  "tags": {
-    "key": "value"
-  },
-  "properties": {
-    "sourceVirtualMachine": {
-      "id": "/subscriptions/{subscriptionId}/resourceGroups/myResourceGroup/providers/Microsoft.Compute/virtualMachines/myVM"
-    },
-    "storageProfile": {
-      "osDisk": {
-        "osType": "Windows",
-        "blobUri": "https://mystorageaccount.blob.core.windows.net/osimages/osimage.vhd",
-        "snapshot": {
-          "id": "subscriptions/{subscriptionId}/resourceGroups/myResourceGroup/providers/Microsoft.Compute/snapshots/mySnapshot1"
-        },
-        "managedDisk": {
-          "id": "subscriptions/{subscriptionId}/resourceGroups/myResourceGroup/providers/Microsoft.Compute/disks/myManagedDisk1"
-        },
-        "osState": "generalized",
-        "hostCaching": "ReadWrite",
-        "storageAccountType": "Standard_LRS",
-        "diskSizeGB": 20
-      },
-      "dataDisks": [
-        {
-          "lun": "1",
-          "blobUri": "https://mystorageaccount.blob.core.windows.net/dataimages/dataimage.vhd",
-          "snapshot": {
-            "id": "subscriptions/{subscriptionId}/resourceGroups/myResourceGroup/providers/Microsoft.Compute/snapshots/mySnapshot2"
-          },
-          "managedDisk": {
-            "id": "subscriptions/{subscriptionId}/resourceGroups/myResourceGroup/providers/Microsoft.Compute/disks/myManagedDisk2"
-          },
-          "hostCaching": "ReadWrite",
-          "storageAccountType": "Standard_LRS",
-          "diskSizeInGB": 20
-        }
-      ]
-    },
-    "provisioningState": "creating"
-  }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/isavailablestorageservice.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/isavailablestorageservice.json b/azurecompute-arm/src/test/resources/isavailablestorageservice.json
deleted file mode 100644
index b6f2459..0000000
--- a/azurecompute-arm/src/test/resources/isavailablestorageservice.json
+++ /dev/null
@@ -1,3 +0,0 @@
-{
-  "nameAvailable": true
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/listdeployments.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/listdeployments.json b/azurecompute-arm/src/test/resources/listdeployments.json
deleted file mode 100644
index 122500f..0000000
--- a/azurecompute-arm/src/test/resources/listdeployments.json
+++ /dev/null
@@ -1,99 +0,0 @@
-{
-  "value": [
-    {
-      "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Resources/deployments/jcdep1458344383064",
-      "name": "jcdep1458344383064",
-      "properties": {
-        "parameters": {},
-        "mode": "Incremental",
-        "provisioningState": "Running",
-        "timestamp": "2016-04-26T11:48:11.1807222Z",
-        "duration": "PT0.950828S",
-        "correlationId": "f7876e0f-22ec-413c-a79e-0a718b4789a2",
-        "providers": [
-          {
-            "namespace": "Microsoft.Storage",
-            "resourceTypes": [
-              {
-                "resourceType": "storageAccounts",
-                "locations": [
-                  "northeurope"
-                ]
-              }
-            ]
-          },
-          {
-            "namespace": "Microsoft.Network",
-            "resourceTypes": [
-              {
-                "resourceType": "virtualNetworks",
-                "locations": [
-                  "northeurope"
-                ]
-              },
-              {
-                "resourceType": "publicIPAddresses",
-                "locations": [
-                  "northeurope"
-                ]
-              },
-              {
-                "resourceType": "networkInterfaces",
-                "locations": [
-                  "northeurope"
-                ]
-              }
-            ]
-          },
-          {
-            "namespace": "Microsoft.Compute",
-            "resourceTypes": [
-              {
-                "resourceType": "virtualMachines",
-                "locations": [
-                  "northeurope"
-                ]
-              }
-            ]
-          }
-        ],
-        "dependencies": [
-          {
-            "dependsOn": [
-              {
-                "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Network/publicIPAddresses/jc1461584629971publicip",
-                "resourceType": "Microsoft.Network/publicIPAddresses",
-                "resourceName": "jc1461584629971publicip"
-              },
-              {
-                "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Network/virtualNetworks/jc1461584629971virtualnetwork",
-                "resourceType": "Microsoft.Network/virtualNetworks",
-                "resourceName": "jc1461584629971virtualnetwork"
-              }
-            ],
-            "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Network/networkInterfaces/jc1461584629971nic",
-            "resourceType": "Microsoft.Network/networkInterfaces",
-            "resourceName": "jc1461584629971nic"
-          },
-          {
-            "dependsOn": [
-              {
-                "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Storage/storageAccounts/jc1461584629971storage",
-                "resourceType": "Microsoft.Storage/storageAccounts",
-                "resourceName": "jc1461584629971storage"
-              },
-              {
-                "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Network/networkInterfaces/jc1461584629971nic",
-                "resourceType": "Microsoft.Network/networkInterfaces",
-                "resourceName": "jc1461584629971nic"
-              }
-            ],
-            "id": "/subscriptions/123abc12-1234-1234-1234-12345345234/resourceGroups/resourceGroup/providers/Microsoft.Compute/virtualMachines/jc1461584629971VirtualMachine",
-            "resourceType": "Microsoft.Compute/virtualMachines",
-            "resourceName": "jc1461584629971VirtualMachine"
-          }
-        ]
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/listdisks.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/listdisks.json b/azurecompute-arm/src/test/resources/listdisks.json
deleted file mode 100644
index c84c561..0000000
--- a/azurecompute-arm/src/test/resources/listdisks.json
+++ /dev/null
@@ -1,23 +0,0 @@
-{
-  "value": [
-    {
-      "sku": {
-        "name": "Standard_LRS",
-        "tier": "Standard"
-      },
-      "properties": {
-        "creationData": {
-          "createOption": "Empty"
-        },
-        "diskSizeGB": 2,
-        "timeCreated": "2017-03-01T09:48:27.4526118+00:00",
-        "provisioningState": "Succeeded",
-        "diskState": "Unattached"
-      },
-      "type": "Microsoft.Compute/disks",
-      "location": "westeurope",
-      "id": "/subscriptions/610bba05-d7a7-4567-96af-48ecbd09453b/resourceGroups/rg-diskapilivetest-andrea/providers/Microsoft.Compute/disks/jclouds-646",
-      "name": "jclouds-646"
-    }
-  ]
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/listnetworkinterfaces.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/listnetworkinterfaces.json b/azurecompute-arm/src/test/resources/listnetworkinterfaces.json
deleted file mode 100644
index de4b1e3..0000000
--- a/azurecompute-arm/src/test/resources/listnetworkinterfaces.json
+++ /dev/null
@@ -1,68 +0,0 @@
-{
-  "value": [
-    {
-      "name": "AnotherNIC",
-      "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/AnotherNIC",
-      "etag": "W/\"e4ed4253-64b6-4184-bfaa-554f470d20c5\"",
-      "type": "Microsoft.Network/networkInterfaces",
-      "location": "northeurope",
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "7fcf6704-21c5-4983-bd9f-017e0873f22f",
-        "ipConfigurations": [
-          {
-            "name": "ipconfig1",
-            "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/AnotherNIC/ipConfigurations/ipconfig1",
-            "etag": "W/\"e4ed4253-64b6-4184-bfaa-554f470d20c5\"",
-            "properties": {
-              "provisioningState": "Succeeded",
-              "privateIPAddress": "10.2.1.4",
-              "privateIPAllocationMethod": "Dynamic",
-              "subnet": {
-                "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/armlivetesting/providers/Microsoft.Network/virtualNetworks/jclouds-virtual-network-live-test/subnets/anothersubnet"
-              },
-              "primary": true
-            }
-          }
-        ],
-        "dnsSettings": {
-          "dnsServers": [],
-          "appliedDnsServers": []
-        },
-        "enableIPForwarding": false
-      }
-    },
-    {
-      "name": "MyNic",
-      "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/MyNic",
-      "etag": "W/\"a37d25ff-3f62-4ee2-a111-f355beb5ff69\"",
-      "type": "Microsoft.Network/networkInterfaces",
-      "location": "northeurope",
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "35908409-a081-4411-86a9-51f9ea99321f",
-        "ipConfigurations": [
-          {
-            "name": "ipconfig1",
-            "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/MyNic/ipConfigurations/ipconfig1",
-            "etag": "W/\"a37d25ff-3f62-4ee2-a111-f355beb5ff69\"",
-            "properties": {
-              "provisioningState": "Succeeded",
-              "privateIPAddress": "10.2.0.100",
-              "privateIPAllocationMethod": "Static",
-              "subnet": {
-                "id": "/subscriptions/12345678-2749-4e68-9dcf-123456789abc/resourceGroups/armlivetesting/providers/Microsoft.Network/virtualNetworks/jclouds-virtual-network-live-test/subnets/default"
-              },
-              "primary": true
-            }
-          }
-        ],
-        "dnsSettings": {
-          "dnsServers": [],
-          "appliedDnsServers": []
-        },
-        "enableIPForwarding": false
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/listsubnetswithinvirtualnetwork.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/listsubnetswithinvirtualnetwork.json b/azurecompute-arm/src/test/resources/listsubnetswithinvirtualnetwork.json
deleted file mode 100644
index 8aeef22..0000000
--- a/azurecompute-arm/src/test/resources/listsubnetswithinvirtualnetwork.json
+++ /dev/null
@@ -1,18 +0,0 @@
-{
-  "value": [
-    {
-      "name": "mysubnet",
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet",
-      "etag": "W/\"bc7e1d77-eec0-4b91-ae80-afc33cf3c867\"",
-      "properties": {
-        "provisioningState": "Succeeded",
-        "addressPrefix": "10.2.0.0/24",
-        "ipConfigurations": [
-          {
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-          }
-        ]
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/listvirtualnetworks.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/listvirtualnetworks.json b/azurecompute-arm/src/test/resources/listvirtualnetworks.json
deleted file mode 100644
index 38b9b39..0000000
--- a/azurecompute-arm/src/test/resources/listvirtualnetworks.json
+++ /dev/null
@@ -1,79 +0,0 @@
-{
-  "value": [
-    {
-      "name": "mockvirtualnetwork",
-      "id": "/subscriptions/6b6748c8-3e69-4e27-9b71-df97a81c0bbc/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/mockvirtualnetwork",
-      "etag": "W/\"0dcd223f-670c-49ca-abe7-5978d127c131\"",
-      "type": "Microsoft.Network/virtualNetworks",
-      "location": "westeurope",
-      "tags": {
-        "key": "value"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "1568c76a-73a4-4a60-8dfb-53b823197ccb",
-        "addressSpace": {
-          "addressPrefixes": [
-            "10.2.0.0/16"
-          ]
-        },
-        "subnets": []
-      }
-    },
-    {
-      "name": "anothervirtualnetworks",
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/anothervirtualnetworks",
-      "etag": "W/\"7604d8fe-f3b8-4fd4-ae52-ab503cc29097\"",
-      "type": "Microsoft.Network/virtualNetworks",
-      "location": "westeurope",
-      "tags": {
-        "key": "value"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "5192bdb3-f6ed-44ad-bf4c-059cff905791",
-        "addressSpace": {
-          "addressPrefixes": [
-            "10.2.0.0/16"
-          ]
-        },
-        "subnets": []
-      }
-    },
-    {
-      "name": "myvirtualnetwork",
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork",
-      "etag": "W/\"bc7e1d77-eec0-4b91-ae80-afc33cf3c867\"",
-      "type": "Microsoft.Network/virtualNetworks",
-      "location": "westeurope",
-      "tags": {
-        "key": "value"
-      },
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "8da85637-833c-4445-a681-81ca3fb90044",
-        "addressSpace": {
-          "addressPrefixes": [
-            "10.2.0.0/16"
-          ]
-        },
-        "subnets": [
-          {
-            "name": "mysubnet",
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/virtualNetworks/myvirtualnetwork/subnets/mysubnet",
-            "etag": "W/\"bc7e1d77-eec0-4b91-ae80-afc33cf3c867\"",
-            "properties": {
-              "provisioningState": "Succeeded",
-              "addressPrefix": "10.2.0.0/24",
-              "ipConfigurations": [
-                {
-                  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/azurearmtesting/providers/Microsoft.Network/networkInterfaces/myNic/ipConfigurations/myip1"
-                }
-              ]
-            }
-          }
-        ]
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/loadbalancercreate.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/loadbalancercreate.json b/azurecompute-arm/src/test/resources/loadbalancercreate.json
deleted file mode 100644
index b3fa339..0000000
--- a/azurecompute-arm/src/test/resources/loadbalancercreate.json
+++ /dev/null
@@ -1,28 +0,0 @@
-{
-  "name": "testLoadBalancer",
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer",
-  "etag": "W/\"406af4e7-b24b-4c00-b42f-b3c4399bf61d\"",
-  "type": "Microsoft.Network/loadBalancers",
-  "location": "westeurope",
-  "properties": {
-    "provisioningState": "Succeeded",
-    "resourceGuid": "112b7e75-f287-4789-9f6a-9a55a6fbe47c",
-    "frontendIPConfigurations": [
-      {
-        "name": "ipConfigs",
-        "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/frontendIPConfigurations/ipConfigs",
-        "etag": "W/\"406af4e7-b24b-4c00-b42f-b3c4399bf61d\"",
-        "properties": {
-          "provisioningState": "Succeeded",
-          "privateIPAllocationMethod": "Dynamic"
-        }
-      }
-    ],
-    "backendAddressPools": [],
-    "loadBalancingRules": [],
-    "probes": [],
-    "inboundNatRules": [],
-    "outboundNatRules": [],
-    "inboundNatPools": []
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/loadbalancerget.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/loadbalancerget.json b/azurecompute-arm/src/test/resources/loadbalancerget.json
deleted file mode 100644
index ef4e390..0000000
--- a/azurecompute-arm/src/test/resources/loadbalancerget.json
+++ /dev/null
@@ -1,54 +0,0 @@
-{
-  "name": "testLoadBalancer",
-  "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer",
-  "etag": "W/\"b2cfb60e-4ada-4546-a336-dd71e574ead6\"",
-  "type": "Microsoft.Network/loadBalancers",
-  "location": "westeurope",
-  "properties": {
-    "provisioningState": "Succeeded",
-    "resourceGuid": "0d53b121-95cc-47b5-bbc6-0391f5991028",
-    "frontendIPConfigurations": [
-      {
-        "name": "ipConfigs",
-        "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/frontendIPConfigurations/ipConfigs",
-        "etag": "W/\"b2cfb60e-4ada-4546-a336-dd71e574ead6\"",
-        "properties": {
-          "provisioningState": "Succeeded",
-          "privateIPAllocationMethod": "Dynamic",
-          "publicIPAddress": {
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/publicIPAddresses/Ip4LoadBalancer"
-          },
-          "loadBalancingRules": [
-            {
-              "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/loadBalancingRules/lbRule1"
-            }
-          ]
-        }
-      }
-    ],
-    "backendAddressPools": [],
-    "loadBalancingRules": [
-      {
-        "name": "lbRule1",
-        "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/loadBalancingRules/lbRule1",
-        "etag": "W/\"b2cfb60e-4ada-4546-a336-dd71e574ead6\"",
-        "properties": {
-          "provisioningState": "Succeeded",
-          "frontendIPConfiguration": {
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/frontendIPConfigurations/ipConfigs"
-          },
-          "frontendPort": 80,
-          "backendPort": 80,
-          "enableFloatingIP": false,
-          "idleTimeoutInMinutes": 4,
-          "protocol": "Tcp",
-          "loadDistribution": "Default"
-        }
-      }
-    ],
-    "probes": [],
-    "inboundNatRules": [],
-    "outboundNatRules": [],
-    "inboundNatPools": []
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/loadbalancerlist.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/loadbalancerlist.json b/azurecompute-arm/src/test/resources/loadbalancerlist.json
deleted file mode 100644
index 8272d39..0000000
--- a/azurecompute-arm/src/test/resources/loadbalancerlist.json
+++ /dev/null
@@ -1,35 +0,0 @@
-{
-  "value": [
-    {
-      "name": "testLoadBalancer",
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer",
-      "etag": "W/\"1107154b-8717-486b-80c1-af99ec62897b\"",
-      "type": "Microsoft.Network/loadBalancers",
-      "location": "westeurope",
-      "properties": {
-        "provisioningState": "Succeeded",
-        "resourceGuid": "383708b3-8d4e-474c-8908-9c4e311ac0bf",
-        "frontendIPConfigurations": [
-          {
-            "name": "ipConfigs",
-            "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/loadBalancers/testLoadBalancer/frontendIPConfigurations/ipConfigs",
-            "etag": "W/\"1107154b-8717-486b-80c1-af99ec62897b\"",
-            "properties": {
-              "provisioningState": "Succeeded",
-              "privateIPAllocationMethod": "Dynamic",
-              "publicIPAddress": {
-                "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/rg-loadbalancerapilivetest-nacx/providers/Microsoft.Network/publicIPAddresses/Ip4LoadBalancer"
-              }
-            }
-          }
-        ],
-        "backendAddressPools": [],
-        "loadBalancingRules": [],
-        "probes": [],
-        "inboundNatRules": [],
-        "outboundNatRules": [],
-        "inboundNatPools": []
-      }
-    }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/locations.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/locations.json b/azurecompute-arm/src/test/resources/locations.json
deleted file mode 100644
index ded0d8b..0000000
--- a/azurecompute-arm/src/test/resources/locations.json
+++ /dev/null
@@ -1,10 +0,0 @@
-{"value": [
-  {
-    "id":"/subscriptions/SUBSCRIPTIONID/locations/eastasia",
-    "name":"eastasia",
-    "displayName":"East Asia",
-    "longitude":"114.188",
-    "latitude":"22.267"
-  }
-  ]
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/logback-test.xml
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/logback-test.xml b/azurecompute-arm/src/test/resources/logback-test.xml
deleted file mode 100644
index b9e9616..0000000
--- a/azurecompute-arm/src/test/resources/logback-test.xml
+++ /dev/null
@@ -1,42 +0,0 @@
-<?xml version="1.0"?>
-<configuration scan="false">
-    <appender name="FILE" class="ch.qos.logback.core.FileAppender">
-        <file>target/test-data/jclouds.log</file>
-        <encoder>
-            <Pattern>%d %-5p [%c] [%thread] %m%n</Pattern>
-        </encoder>
-    </appender>
-    <appender name="WIREFILE" class="ch.qos.logback.core.FileAppender">
-        <file>target/test-data/jclouds-wire.log</file>
-        <encoder>
-            <Pattern>%d %-5p [%c] [%thread] %m%n</Pattern>
-        </encoder>
-    </appender>
-    <appender name="COMPUTEFILE" class="ch.qos.logback.core.FileAppender">
-        <file>target/test-data/jclouds-compute.log</file>
-        <encoder>
-            <Pattern>%d %-5p [%c] [%thread] %m%n</Pattern>
-        </encoder>
-    </appender>
-
-    <logger name="org.jclouds">
-        <level value="DEBUG" />
-        <appender-ref ref="FILE" />
-    </logger>
-    <logger name="jclouds.compute">
-        <level value="DEBUG" />
-        <appender-ref ref="COMPUTEFILE" />
-    </logger>
-    <logger name="jclouds.wire">
-        <level value="DEBUG" />
-        <appender-ref ref="WIREFILE" />
-    </logger>
-    <logger name="jclouds.headers">
-        <level value="DEBUG" />
-        <appender-ref ref="WIREFILE" />
-    </logger>
-
-    <root>
-        <level value="INFO" />
-    </root>
-</configuration>

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/metricdefinitions.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/metricdefinitions.json b/azurecompute-arm/src/test/resources/metricdefinitions.json
deleted file mode 100644
index 3df0a84..0000000
--- a/azurecompute-arm/src/test/resources/metricdefinitions.json
+++ /dev/null
@@ -1,25 +0,0 @@
-{
-  "value": [
-    {
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/virtualMachines/myvm/providers/microsoft.insights/metricdefinitions/Percentage CPU",
-      "resourceId": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/virtualMachines/myvm",
-      "name": {
-        "value": "Percentage CPU",
-        "localizedValue": "Percentage CPU"
-      },
-      "isDimensionRequired": false,
-      "unit": "Percent",
-      "primaryAggregationType": "Average",
-      "metricAvailabilities": [
-        {
-          "timeGrain": "PT1M",
-          "retention": "P30D"
-        },
-        {
-          "timeGrain": "PT1H",
-          "retention": "P30D"
-        }
-      ]
-    }
-  ]
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ac03bac4/azurecompute-arm/src/test/resources/metrics.json
----------------------------------------------------------------------
diff --git a/azurecompute-arm/src/test/resources/metrics.json b/azurecompute-arm/src/test/resources/metrics.json
deleted file mode 100644
index 754e5d1..0000000
--- a/azurecompute-arm/src/test/resources/metrics.json
+++ /dev/null
@@ -1,19 +0,0 @@
-{
-  "value": [
-    {
-      "data": [
-        {
-          "timeStamp": "2017-06-01T11:14:00Z",
-          "average": 0.295
-        }
-      ],
-      "id": "/subscriptions/SUBSCRIPTIONID/resourceGroups/myresourcegroup/providers/Microsoft.Compute/virtualMachines/myvm/providers/Microsoft.Insights/metrics/Percentage CPU",
-      "name": {
-        "value": "Percentage CPU",
-        "localizedValue": "Percentage CPU"
-      },
-      "type": "Microsoft.Insights/metrics",
-      "unit": "Percent"
-    }
-  ]
-}