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 2014/10/24 06:10:37 UTC

[4/8] JCLOUDS-757 drop fgcp provider.

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/services/VirtualSystemApi.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/services/VirtualSystemApi.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/services/VirtualSystemApi.java
deleted file mode 100644
index 8b19c4d..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/services/VirtualSystemApi.java
+++ /dev/null
@@ -1,184 +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.fujitsu.fgcp.services;
-
-import java.io.Closeable;
-import java.util.Set;
-
-import javax.inject.Named;
-import javax.ws.rs.Consumes;
-import javax.ws.rs.GET;
-import javax.ws.rs.QueryParam;
-import javax.ws.rs.core.MediaType;
-
-import org.jclouds.fujitsu.fgcp.FGCPApi;
-import org.jclouds.fujitsu.fgcp.binders.BindAlsoToSystemId;
-import org.jclouds.fujitsu.fgcp.compute.functions.SingleElementResponseToElement;
-import org.jclouds.fujitsu.fgcp.domain.BuiltinServer;
-import org.jclouds.fujitsu.fgcp.domain.PublicIP;
-import org.jclouds.fujitsu.fgcp.domain.VDisk;
-import org.jclouds.fujitsu.fgcp.domain.VServer;
-import org.jclouds.fujitsu.fgcp.domain.VSystem;
-import org.jclouds.fujitsu.fgcp.domain.VSystemStatus;
-import org.jclouds.fujitsu.fgcp.domain.VSystemWithDetails;
-import org.jclouds.fujitsu.fgcp.filters.RequestAuthenticator;
-import org.jclouds.fujitsu.fgcp.reference.RequestParameters;
-import org.jclouds.rest.annotations.BinderParam;
-import org.jclouds.rest.annotations.JAXBResponseParser;
-import org.jclouds.rest.annotations.PayloadParams;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.Transform;
-
-
-/**
- * API relating to virtual systems.
- */
-@RequestFilters(RequestAuthenticator.class)
-@QueryParams(keys = RequestParameters.VERSION, values = FGCPApi.VERSION)
-@PayloadParams(keys = RequestParameters.VERSION, values = FGCPApi.VERSION)
-@Consumes(MediaType.TEXT_XML)
-public interface VirtualSystemApi extends Closeable {
-
-   @Named("DestroyVSYS")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "DestroyVSYS")
-   void destroy(@QueryParam("vsysId") String id);
-
-   @Named("GetVSYSStatus")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "GetVSYSStatus")
-   @Transform(SingleElementResponseToElement.class)
-   VSystemStatus getStatus(@QueryParam("vsysId") String id);
-
-   @Named("GetVSYSAttributes")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "GetVSYSAttributes")
-   @Transform(SingleElementResponseToElement.class)
-   VSystem get(@QueryParam("vsysId") String id);
-
-   @Named("GetVSYSConfiguration")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "GetVSYSConfiguration")
-   @Transform(SingleElementResponseToElement.class)
-   VSystemWithDetails getDetails(
-         @QueryParam("vsysId") String id);
-
-   @Named("UpdateVSYSAttribute")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "UpdateVSYSAttribute")
-   void update(@QueryParam("vsysId") String id,
-         @QueryParam("attributeName") String name,
-         @QueryParam("attributeValue") String value);
-
-   @Named("UpdateVSYSConfiguration")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "UpdateVSYSConfiguration")
-   void updateConfiguration(@QueryParam("vsysId") String id,
-         @QueryParam("configurationName") String name,
-         @QueryParam("configurationValue") String value);
-
-   @Named("CreateVServer")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "CreateVServer")
-   @Transform(SingleElementResponseToElement.class)
-   String createServer(
-         @QueryParam("vserverName") String name,
-         @QueryParam("vserverType") String type,
-         @QueryParam("diskImageId") String diskImageId,
-         @BinderParam(BindAlsoToSystemId.class) @QueryParam("networkId") String networkId);
-
-   @Named("ListVServer")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "ListVServer")
-   Set<VServer> listServers(@QueryParam("vsysId") String id);
-
-   @Named("CreateVDisk")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "CreateVDisk")
-   @Transform(SingleElementResponseToElement.class)
-   String createDisk(@QueryParam("vsysId") String id,
-         @QueryParam("vdiskName") String name, @QueryParam("size") int size);
-
-   @Named("ListVDisk")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "ListVDisk")
-   Set<VDisk> listDisks(@QueryParam("vsysId") String id);
-
-   @Named("AllocatePublicIP")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "AllocatePublicIP")
-   void allocatePublicIP(@QueryParam("vsysId") String id);
-
-   /**
-    *
-    * @return
-    * @see VirtualDCApi#listPublicIPs()
-    */
-   @Named("ListPublicIP")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "ListPublicIP")
-   @Transform(SingleElementResponseToElement.class)
-   Set<PublicIP> listPublicIPs(
-         @QueryParam("vsysId") String id);
-
-   @Named("CreateEFM")
-   @GET
-   @JAXBResponseParser
-   // SLB is the only built-in server that can currently be created so
-   // hard-code it
-   @QueryParams(keys = { "Action", "efmType" }, values = { "CreateEFM", "SLB" })
-   @Transform(SingleElementResponseToElement.class)
-   String createBuiltinServer(
-         @QueryParam("efmName") String name,
-         @BinderParam(BindAlsoToSystemId.class) @QueryParam("networkId") String networkId);
-
-   @Named("ListEFM")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "ListEFM")
-   Set<BuiltinServer> listBuiltinServers(
-         @QueryParam("vsysId") String id, @QueryParam("efmType") String type);
-
-   @Named("StandByConsole")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "StandByConsole")
-   @Transform(SingleElementResponseToElement.class)
-   String standByConsole(@QueryParam("vsysId") String id,
-         @QueryParam("networkId") String networkId);
-
-   @Named("RegisterPrivateVSYSDescriptor")
-   @GET
-   @JAXBResponseParser
-   @QueryParams(keys = "Action", values = "RegisterPrivateVSYSDescriptor")
-   void registerAsPrivateVSYSDescriptor(
-         @QueryParam("vsysId") String id,
-         @QueryParam("vsysDescriptorXMLFilePath") String vsysDescriptorXMLFilePath);
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/FGCPCredentialsSupplier.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/FGCPCredentialsSupplier.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/FGCPCredentialsSupplier.java
deleted file mode 100644
index 90b2b54..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/FGCPCredentialsSupplier.java
+++ /dev/null
@@ -1,152 +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.fujitsu.fgcp.suppliers;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import java.io.ByteArrayInputStream;
-import java.io.IOException;
-import java.security.GeneralSecurityException;
-import java.security.KeyFactory;
-import java.security.PrivateKey;
-import java.security.cert.CertificateException;
-import java.security.cert.CertificateFactory;
-import java.security.cert.X509Certificate;
-import java.util.Collection;
-
-import javax.inject.Inject;
-
-import org.jclouds.crypto.Pems;
-import org.jclouds.domain.Credentials;
-import org.jclouds.fujitsu.fgcp.FGCPCredentials;
-import org.jclouds.location.Provider;
-
-import com.google.common.annotations.VisibleForTesting;
-import com.google.common.base.Charsets;
-import com.google.common.base.Supplier;
-import com.google.common.base.Throwables;
-import com.google.common.cache.CacheBuilder;
-import com.google.common.cache.CacheLoader;
-import com.google.common.cache.LoadingCache;
-import com.google.common.io.ByteSource;
-import com.google.common.io.CharSource;
-import com.google.common.io.LineProcessor;
-import com.google.common.util.concurrent.UncheckedExecutionException;
-
-/**
- * Loads {@link FGCPCredentials} from a pem file containing certificate and
- * private key.
- */
-public class FGCPCredentialsSupplier implements Supplier<FGCPCredentials> {
-   private final Supplier<Credentials> creds;
-   private final LoadingCache<Credentials, FGCPCredentials> keyCache;
-
-   @Inject
-   public FGCPCredentialsSupplier(@Provider Supplier<Credentials> creds, FGCPCredentialsForCredentials loader) {
-      this.creds = creds;
-      // throw out the private key related to old credentials
-      this.keyCache = CacheBuilder.newBuilder().maximumSize(2).build(checkNotNull(loader, "loader"));
-   }
-
-   /**
-    * It is relatively expensive to extract a certificate with private key from
-    * a PEM. Cache the relationship between current credentials so that they are
-    * only recalculated once.
-    */
-   @VisibleForTesting
-   public static class FGCPCredentialsForCredentials extends CacheLoader<Credentials, FGCPCredentials> {
-      @Override
-      public FGCPCredentials load(Credentials in) {
-         try {
-            String identity = in.identity;
-            String pem = in.credential;
-
-            // extract private key
-            KeyFactory keyFactory = KeyFactory.getInstance("RSA");
-            PrivateKey privateKey = keyFactory.generatePrivate(Pems.privateKeySpec(ByteSource.wrap(pem.getBytes(Charsets.UTF_8))));
-
-            // extract certificate(s)
-            Collection<X509Certificate> certs = x509Certificates(pem);
-
-            return new FGCPCredentials.Builder().identity(identity).credential(pem)
-                  .privateKey(privateKey).certificates(certs).build();
-         } catch (IOException e) {
-            throw Throwables.propagate(e);
-         } catch (GeneralSecurityException e) {
-            throw new IllegalArgumentException("security exception parsing pem. " + e.getMessage(), e);
-         } catch (IllegalArgumentException e) {
-            throw new IllegalArgumentException("not a valid pem: cannot parse pk. " + e.getMessage(), e);
-         }
-      }
-
-      /**
-       * Returns the collection of X509Certificates that are pem encoded in the
-       * input string.<br>
-       * Other elements except for pem encoded certificates, e.g. private keys
-       * and metadata such as bag attributes are ignored in the pem are ignored.
-       *
-       * @param pem
-       *           encoded certificate(s)
-       * @return collection of certificates
-       * @throws IOException
-       *            in an I/O error occurs
-       * @throws CertificateException
-       *            on parsing errors
-       */
-      @SuppressWarnings("unchecked")
-      public static Collection<X509Certificate> x509Certificates(String pem) throws IOException, CertificateException {
-         // in : pem with Bagattributes metadata and pk
-         // out: pem with only certs
-         LineProcessor<String> callback = new LineProcessor<String>() {
-            static final String CERTIFICATE_X509_END_MARKER = "-----END CERTIFICATE-----";
-            StringBuilder result = new StringBuilder();
-            boolean insideCert = false;
-
-            public boolean processLine(String line) {
-               if (line.startsWith(Pems.CERTIFICATE_X509_MARKER)) {
-                  insideCert = true;
-               }
-               if (insideCert) {
-                  result.append(line).append('\n');
-               }
-               if (line.startsWith(CERTIFICATE_X509_END_MARKER)) {
-                  insideCert = false;
-               }
-               return true; // keep going
-            }
-
-            public String getResult() {
-               return result.toString();
-            }
-         };
-         String filteredPem = CharSource.wrap(pem).readLines(callback);
-         CertificateFactory fact = CertificateFactory.getInstance("X.509");
-         return (Collection<X509Certificate>) fact.generateCertificates(new ByteArrayInputStream(filteredPem
-               .getBytes(Charsets.UTF_8)));
-      }
-   }
-
-   @Override
-   public FGCPCredentials get() {
-      try {
-         return keyCache.getUnchecked(checkNotNull(creds.get(), "credential supplier returned null"));
-      } catch (UncheckedExecutionException e) {
-         throw Throwables.propagate(e.getCause());
-      }
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/SSLContextWithKeysSupplier.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/SSLContextWithKeysSupplier.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/SSLContextWithKeysSupplier.java
deleted file mode 100644
index c4be5ce..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/suppliers/SSLContextWithKeysSupplier.java
+++ /dev/null
@@ -1,81 +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.fujitsu.fgcp.suppliers;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-import static com.google.common.base.Throwables.propagate;
-
-import java.io.IOException;
-import java.security.GeneralSecurityException;
-import java.security.KeyStore;
-import java.security.PrivateKey;
-import java.security.SecureRandom;
-import java.security.cert.Certificate;
-import java.security.cert.X509Certificate;
-import java.util.Collection;
-
-import javax.inject.Inject;
-import javax.inject.Singleton;
-import javax.net.ssl.KeyManagerFactory;
-import javax.net.ssl.SSLContext;
-import javax.net.ssl.TrustManager;
-
-import org.jclouds.fujitsu.fgcp.FGCPCredentials;
-import org.jclouds.http.HttpUtils;
-import org.jclouds.http.config.SSLModule.TrustAllCerts;
-
-import com.google.common.base.Supplier;
-
-/**
- * Takes PK and chain from credentials to build a SSLContext for HTTPS with
- * client authentication.
- */
-@Singleton
-public class SSLContextWithKeysSupplier implements Supplier<SSLContext> {
-   private final Supplier<FGCPCredentials> creds;
-   private final TrustManager[] trustManager;
-
-   @Inject
-   SSLContextWithKeysSupplier(Supplier<FGCPCredentials> creds, HttpUtils utils,
-         TrustAllCerts trustAllCerts) {
-      this.creds = creds;
-      this.trustManager = utils.trustAllCerts() ? new TrustManager[] { trustAllCerts } : null;
-   }
-
-   @Override
-   public SSLContext get() {
-      FGCPCredentials currentCreds = checkNotNull(creds.get(), "fgcpcredential supplier returned null");
-      PrivateKey privateKey = checkNotNull(currentCreds.privateKey, "fgcpcredential's privateKey is null");
-      Collection<X509Certificate> certs = checkNotNull(currentCreds.certificates, "fgcpcredential's certificates returned null");
-
-      try {
-         KeyManagerFactory kmf = KeyManagerFactory.getInstance("SunX509");
-         KeyStore keyStore = KeyStore.getInstance("pkcs12");
-         keyStore.load(null, null);
-         keyStore.setKeyEntry("dummy alias", privateKey, null, (Certificate[]) certs.toArray(new Certificate[0]));
-         kmf.init(keyStore, null);
-
-         SSLContext sc = SSLContext.getInstance("TLS");
-         sc.init(kmf.getKeyManagers(), trustManager, new SecureRandom());
-         return sc;
-      } catch (GeneralSecurityException e) {
-         throw propagate(e);
-      } catch (IOException e) {
-         throw propagate(e);
-      }
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/BindParamsToXmlPayload.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/BindParamsToXmlPayload.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/BindParamsToXmlPayload.java
deleted file mode 100644
index 3c5075d..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/BindParamsToXmlPayload.java
+++ /dev/null
@@ -1,95 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.fujitsu.fgcp.xml;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import java.net.URI;
-import java.net.URISyntaxException;
-import java.util.Map;
-
-import javax.ws.rs.core.MediaType;
-
-import org.jclouds.fujitsu.fgcp.reference.RequestParameters;
-import org.jclouds.http.HttpRequest;
-import org.jclouds.rest.MapBinder;
-import org.jclouds.rest.binders.BindToStringPayload;
-
-import com.google.common.base.Strings;
-
-/**
- * Not currently used but leaving for reference when implementing multipart POST
- * methods.
- */
-public class BindParamsToXmlPayload extends BindToStringPayload implements
-      MapBinder {
-
-   @SuppressWarnings("unchecked")
-   @Override
-   public <R extends HttpRequest> R bindToRequest(R request,
-         Map<String, Object> mapParams) {
-      String action = checkNotNull(
-            mapParams.remove(RequestParameters.ACTION),
-            RequestParameters.ACTION).toString();
-      String version = Strings.nullToEmpty((String) mapParams
-            .remove(RequestParameters.VERSION));
-
-      StringBuilder xml = new StringBuilder();
-      xml.append("<?xml version=\"1.0\" encoding=\"UTF-8\"?>\r\n");
-      xml.append("<OViSSRequest>\r\n");
-      xml.append("  <Action>" + action + "</Action>\r\n");
-
-      for (Map.Entry<String, Object> entry : mapParams.entrySet()) {
-         String key = entry.getKey();
-         xml.append("  <" + key + ">" + checkNotNull(mapParams.get(key))
-               + "</" + key + ">\r\n");
-      }
-
-      xml.append("  <Version>" + version + "</Version>\r\n");
-      xml.append("  <Locale></Locale>\r\n"); // value inserted in
-                                    // RequestAuthenticator#filter
-      xml.append("  <AccessKeyId></AccessKeyId>\r\n"); // value inserted in
-                                           // RequestAuthenticator#filter
-      xml.append("  <Signature></Signature>\r\n"); // value inserted in
-                                        // RequestAuthenticator#filter
-      xml.append("</OViSSRequest>");
-
-      request = super.bindToRequest(request, xml);
-      request.getPayload().getContentMetadata()
-            .setContentType(MediaType.TEXT_XML);
-
-      // remove version query param if set as it was moved to the xml body
-      URI uri = request.getEndpoint();
-      URI uriWithoutQueryParams;
-      try {
-         uriWithoutQueryParams = new URI(uri.getScheme(), uri.getUserInfo(),
-               uri.getHost(), uri.getPort(), uri.getPath(), null,
-               uri.getFragment());
-      } catch (URISyntaxException e) {
-         // should never happen as we're copying the components from a URI
-         uriWithoutQueryParams = uri;
-      }
-
-      return (R) request.toBuilder().endpoint(uriWithoutQueryParams).build();
-   }
-
-   @Override
-   public <R extends HttpRequest> R bindToRequest(R request, Object toBind) {
-      throw new IllegalArgumentException(
-            "BindParamsToXmlPayload needs bind parameters");
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/FGCPJAXBParser.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/FGCPJAXBParser.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/FGCPJAXBParser.java
deleted file mode 100644
index 88a94ce..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/FGCPJAXBParser.java
+++ /dev/null
@@ -1,78 +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.fujitsu.fgcp.xml;
-
-import java.io.IOException;
-import java.io.StringReader;
-
-import javax.inject.Singleton;
-import javax.xml.bind.JAXBContext;
-import javax.xml.bind.JAXBException;
-import javax.xml.bind.Unmarshaller;
-
-import org.jclouds.fujitsu.fgcp.domain.VServerWithDetails;
-import org.jclouds.fujitsu.fgcp.xml.internal.ListServerTypeResponse;
-import org.jclouds.xml.XMLParser;
-
-/**
- * Parses XML documents using JAXB.
- * 
- * @see org.jclouds.http.functions.ParseXMLWithJAXB
- */
-@Singleton
-public class FGCPJAXBParser implements XMLParser {
-   JAXBContext context;
-
-   public FGCPJAXBParser() throws JAXBException {
-      context = JAXBContext.newInstance(VServerWithDetails.class.getPackage()
-            .getName()
-            + ":"
-            + ListServerTypeResponse.class.getPackage().getName(),
-            VServerWithDetails.class.getClassLoader());
-   }
-
-   @Override
-   public String toXML(final Object src) throws IOException {
-      return toXML(src, src.getClass());
-   }
-
-   @Override
-   public <T> String toXML(final Object src, final Class<T> type)
-         throws IOException {
-      throw new UnsupportedOperationException(
-            "only marshaling from XML is implemented");
-   }
-
-   @SuppressWarnings("unchecked")
-   @Override
-   public <T> T fromXML(final String xml, final Class<T> type)
-         throws IOException {
-      T response = null;
-      try {
-         StringReader reader = new StringReader(xml);
-
-         Unmarshaller unmarshaller = context.createUnmarshaller();
-
-         response = (T) unmarshaller.unmarshal(reader);
-      } catch (Exception ex) {
-         throw new IOException("Could not unmarshal document", ex);
-      }
-
-      return response;
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateEFMResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateEFMResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateEFMResponse.java
deleted file mode 100644
index a5d3f6b..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateEFMResponse.java
+++ /dev/null
@@ -1,40 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * Wrapper for CreateEFMResponse.
- */
-@XmlRootElement(name = "CreateEFMResponse")
-public class CreateEFMResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private String efmId;
-
-   @Override
-   public String toString() {
-      return getElement();
-   }
-
-   @Override
-   public String getElement() {
-      return efmId;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVDiskResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVDiskResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVDiskResponse.java
deleted file mode 100644
index b822b9c..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVDiskResponse.java
+++ /dev/null
@@ -1,40 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * Wrapper for CreateVDiskResponse.
- */
-@XmlRootElement(name = "CreateVDiskResponse")
-public class CreateVDiskResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private String vdiskId;
-
-   @Override
-   public String toString() {
-      return getElement();
-   }
-
-   @Override
-   public String getElement() {
-      return vdiskId;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVSYSResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVSYSResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVSYSResponse.java
deleted file mode 100644
index d8dd167..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVSYSResponse.java
+++ /dev/null
@@ -1,40 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * Wrapper for CreateVSYSResponse.
- */
-@XmlRootElement(name = "CreateVSYSResponse")
-public class CreateVSYSResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private String vsysId;
-
-   @Override
-   public String toString() {
-      return getElement();
-   }
-
-   @Override
-   public String getElement() {
-      return vsysId;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVServerResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVServerResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVServerResponse.java
deleted file mode 100644
index fcb4fb4..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/CreateVServerResponse.java
+++ /dev/null
@@ -1,40 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * Wrapper for CreateVServerResponse.
- */
-@XmlRootElement(name = "CreateVServerResponse")
-public class CreateVServerResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private String vserverId;
-
-   @Override
-   public String toString() {
-      return getElement();
-   }
-
-   @Override
-   public String getElement() {
-      return vserverId;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetAddressRangeResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetAddressRangeResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetAddressRangeResponse.java
deleted file mode 100644
index e332d2e..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetAddressRangeResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.AddressRange;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for GetAddressRangeResponse.
- */
-@XmlRootElement(name = "GetAddressRangeResponse")
-public class GetAddressRangeResponse extends
-      SetWithStatusResponse<AddressRange> {
-   @XmlElementWrapper(name = "addressranges")
-   @XmlElement(name = "addressrange")
-   private Set<AddressRange> ranges = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<AddressRange> delegate() {
-      return ranges == null ? ImmutableSet.<AddressRange> of() : Collections
-            .unmodifiableSet(ranges);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetDiskImageAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetDiskImageAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetDiskImageAttributesResponse.java
deleted file mode 100644
index 0d50a50..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetDiskImageAttributesResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.DiskImage;
-
-/**
- * Wrapper for GetDiskImageAttributesResponse.
- */
-@XmlRootElement(name = "GetDiskImageAttributesResponse")
-public class GetDiskImageAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(name = "diskimage")
-   private DiskImage diskImage;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public DiskImage getElement() {
-      return diskImage;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMAttributesResponse.java
deleted file mode 100644
index 19ab6cb..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMAttributesResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.BuiltinServer;
-
-/**
- * Wrapper for GetEFMAttributesResponse.
- */
-@XmlRootElement(name = "GetEFMAttributesResponse")
-public class GetEFMAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private BuiltinServer efm;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return efm;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMStatusResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMStatusResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMStatusResponse.java
deleted file mode 100644
index 7a92094..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEFMStatusResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.BuiltinServerStatus;
-
-/**
- * Wrapper for GetEFMStatusResponse.
- */
-@XmlRootElement(name = "GetEFMStatusResponse")
-public class GetEFMStatusResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private BuiltinServerStatus efmStatus;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return efmStatus;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEventLogResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEventLogResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEventLogResponse.java
deleted file mode 100644
index 80bb764..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetEventLogResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.EventLog;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for GetEventLogResponse.
- */
-@XmlRootElement(name = "GetEventLogResponse")
-public class GetEventLogResponse extends SetWithStatusResponse<EventLog> {
-   @XmlElementWrapper(name = "eventlogs")
-   @XmlElement(name = "eventlog")
-   private Set<EventLog> logs = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<EventLog> delegate() {
-      return logs == null ? ImmutableSet.<EventLog> of() : Collections
-            .unmodifiableSet(logs);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPerformanceInformationResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPerformanceInformationResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPerformanceInformationResponse.java
deleted file mode 100644
index 4dcbea2..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPerformanceInformationResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.PerformanceInfo;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for GetPerformanceInformationResponse.
- */
-@XmlRootElement(name = "GetPerformanceInformationResponse")
-public class GetPerformanceInformationResponse extends
-      SetWithStatusResponse<PerformanceInfo> {
-   @XmlElementWrapper(name = "performanceinfos")
-   @XmlElement(name = "performanceinfo")
-   private Set<PerformanceInfo> stats = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<PerformanceInfo> delegate() {
-      return stats == null ? ImmutableSet.<PerformanceInfo> of()
-            : Collections.unmodifiableSet(stats);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPAttributesResponse.java
deleted file mode 100644
index 3e3da33..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPAttributesResponse.java
+++ /dev/null
@@ -1,48 +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.fujitsu.fgcp.xml.internal;
-
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.PublicIP;
-
-import com.google.common.collect.Iterables;
-
-/**
- * Wrapper for GetPublicIPAttributesResponse.
- */
-@XmlRootElement(name = "GetPublicIPAttributesResponse")
-public class GetPublicIPAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElementWrapper(name = "publicips")
-   @XmlElement(name = "publicip")
-   private Set<PublicIP> publicIPs;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return Iterables.getOnlyElement(publicIPs);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPStatusResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPStatusResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPStatusResponse.java
deleted file mode 100644
index 317f869..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetPublicIPStatusResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.PublicIPStatus;
-
-/**
- * Wrapper for GetPublicIPStatusResponse.
- */
-@XmlRootElement(name = "GetPublicIPStatusResponse")
-public class GetPublicIPStatusResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private PublicIPStatus publicipStatus;
-
-   @Override
-   public String toString() {
-      return publicipStatus.toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return publicipStatus;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVDiskAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVDiskAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVDiskAttributesResponse.java
deleted file mode 100644
index d4ca4e1..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVDiskAttributesResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VDisk;
-
-/**
- * Wrapper for GetVDiskAttributesResponse.
- */
-@XmlRootElement(name = "GetVDiskAttributesResponse")
-public class GetVDiskAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private VDisk vdisk;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vdisk;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSAttributesResponse.java
deleted file mode 100644
index 951aa9b..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSAttributesResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VSystem;
-
-/**
- * Wrapper for GetVSYSAttributesResponse.
- */
-@XmlRootElement(name = "GetVSYSAttributesResponse")
-public class GetVSYSAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(name = "vsys")
-   private VSystem system;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return system;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSConfigurationResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSConfigurationResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSConfigurationResponse.java
deleted file mode 100644
index 04925a4..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSConfigurationResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VSystemWithDetails;
-
-/**
- * Wrapper for GetVSYSConfigurationResponse.
- */
-@XmlRootElement(name = "GetVSYSConfigurationResponse")
-public class GetVSYSConfigurationResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(name = "vsys")
-   private VSystemWithDetails system;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return system;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSDescriptorConfigurationResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSDescriptorConfigurationResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSDescriptorConfigurationResponse.java
deleted file mode 100644
index 7e7636b..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSDescriptorConfigurationResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VSystemDescriptor;
-
-/**
- * Wrapper for GetVSYSDescriptorConfigurationResponse.
- */
-@XmlRootElement(name = "GetVSYSDescriptorConfigurationResponse")
-public class GetVSYSDescriptorConfigurationResponse extends StatusResponse
-      implements SingleElementResponse {
-   @XmlElement
-   private VSystemDescriptor vsysdescriptor;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vsysdescriptor;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSStatusResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSStatusResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSStatusResponse.java
deleted file mode 100644
index 349f0ec..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVSYSStatusResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VSystemStatus;
-
-/**
- * Wrapper for GetVSYSStatusResponse.
- */
-@XmlRootElement(name = "GetVSYSStatusResponse")
-public class GetVSYSStatusResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private VSystemStatus vsysStatus;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vsysStatus;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerAttributesResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerAttributesResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerAttributesResponse.java
deleted file mode 100644
index 82d37ab..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerAttributesResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VServer;
-
-/**
- * Wrapper for GetVServerAttributesResponse.
- */
-@XmlRootElement(name = "GetVServerAttributesResponse")
-public class GetVServerAttributesResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private VServer vserver;
-
-   @Override
-   public String toString() {
-      return vserver.toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vserver;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerConfigurationResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerConfigurationResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerConfigurationResponse.java
deleted file mode 100644
index 4384277..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerConfigurationResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VServerWithDetails;
-
-/**
- * Wrapper for GetVServerConfigurationResponse.
- */
-@XmlRootElement(name = "GetVServerConfigurationResponse")
-public class GetVServerConfigurationResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private VServerWithDetails vserver;
-
-   @Override
-   public String toString() {
-      return vserver.toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vserver;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerInitialPasswordResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerInitialPasswordResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerInitialPasswordResponse.java
deleted file mode 100644
index 435db60..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerInitialPasswordResponse.java
+++ /dev/null
@@ -1,35 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-/**
- * Wrapper for GetVServerInitialPasswordResponse.
- */
-@XmlRootElement(name = "GetVServerInitialPasswordResponse")
-public class GetVServerInitialPasswordResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private String initialPassword;
-
-   @Override
-   public Object getElement() {
-      return initialPassword;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerStatusResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerStatusResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerStatusResponse.java
deleted file mode 100644
index 1f5c60e..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/GetVServerStatusResponse.java
+++ /dev/null
@@ -1,42 +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.fujitsu.fgcp.xml.internal;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VServerStatus;
-
-/**
- * Wrapper for GetVServerStatusResponse.
- */
-@XmlRootElement(name = "GetVServerStatusResponse")
-public class GetVServerStatusResponse extends StatusResponse implements
-      SingleElementResponse {
-   @XmlElement(required = true)
-   private VServerStatus vserverStatus;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   public Object getElement() {
-      return vserverStatus;
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListDiskImageResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListDiskImageResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListDiskImageResponse.java
deleted file mode 100644
index e1e74fe..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListDiskImageResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.DiskImage;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListDiskImageResponse.
- */
-@XmlRootElement(name = "ListDiskImageResponse")
-public class ListDiskImageResponse extends SetWithStatusResponse<DiskImage> {
-   @XmlElementWrapper(name = "diskimages")
-   @XmlElement(name = "diskimage")
-   private Set<DiskImage> diskImages = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<DiskImage> delegate() {
-      return diskImages == null ? ImmutableSet.<DiskImage> of() : Collections
-            .unmodifiableSet(diskImages);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMBackupResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMBackupResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMBackupResponse.java
deleted file mode 100644
index 48a183e..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMBackupResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.BuiltinServerBackup;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListEFMBackupResponse.
- */
-@XmlRootElement(name = "ListEFMBackupResponse")
-public class ListEFMBackupResponse extends
-      SetWithStatusResponse<BuiltinServerBackup> {
-   @XmlElementWrapper(name = "backups")
-   @XmlElement(name = "backup")
-   private Set<BuiltinServerBackup> backup = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<BuiltinServerBackup> delegate() {
-      return backup == null ? ImmutableSet.<BuiltinServerBackup> of()
-            : Collections.unmodifiableSet(backup);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMResponse.java
deleted file mode 100644
index 0105e9c..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListEFMResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.BuiltinServer;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListEFMResponse.
- */
-@XmlRootElement(name = "ListEFMResponse")
-public class ListEFMResponse extends SetWithStatusResponse<BuiltinServer> {
-   @XmlElementWrapper(name = "efms")
-   @XmlElement(name = "efm")
-   private Set<BuiltinServer> efm = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<BuiltinServer> delegate() {
-      return efm == null ? ImmutableSet.<BuiltinServer> of() : Collections
-            .unmodifiableSet(efm);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListPublicIPResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListPublicIPResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListPublicIPResponse.java
deleted file mode 100644
index ba6f131..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListPublicIPResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Map;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.PublicIP;
-
-import com.google.common.collect.ImmutableMap;
-import com.google.common.collect.ImmutableMap.Builder;
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Wrapper for ListPublicIPResponse.
- */
-@XmlRootElement(name = "ListPublicIPResponse")
-public class ListPublicIPResponse extends
-      MapWithStatusResponse<PublicIP, String> implements
-      SingleElementResponse {
-   @XmlElementWrapper(name = "publicips")
-   @XmlElement(name = "publicip")
-   private Set<PublicIPWithSystemId> ips;
-
-   @Override
-   public String toString() {
-      return getElement().toString();
-   }
-
-   @Override
-   protected Map<PublicIP, String> delegate() {
-      Builder<PublicIP, String> returnVal = ImmutableMap.builder();
-      if (ips != null) {
-
-         for (PublicIPWithSystemId ip : ips) {
-            returnVal.put(ip, ip.getVsysId());
-         }
-      }
-      return returnVal.build();
-   }
-
-   @Override
-   public Set<? extends PublicIP> getElement() {
-      return ips == null ? ImmutableSet.<PublicIP> of() : Collections
-            .unmodifiableSet(ips);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListServerTypeResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListServerTypeResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListServerTypeResponse.java
deleted file mode 100644
index 12d4873..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListServerTypeResponse.java
+++ /dev/null
@@ -1,44 +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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.ServerType;
-
-import com.google.common.collect.ImmutableSet;
-
-/**
- * Wrapper for ListServerTypeResponse.
- */
-@XmlRootElement(name = "ListServerTypeResponse")
-public class ListServerTypeResponse extends SetWithStatusResponse<ServerType> {
-   @XmlElementWrapper(name = "servertypes")
-   @XmlElement(name = "servertype")
-   private Set<ServerType> serverTypes;
-
-   @Override
-   protected Set<ServerType> delegate() {
-      return serverTypes == null ? ImmutableSet.<ServerType> of()
-            : Collections.unmodifiableSet(serverTypes);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVDiskResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVDiskResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVDiskResponse.java
deleted file mode 100644
index d4d0254..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVDiskResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VDisk;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListVDiskResponse.
- */
-@XmlRootElement(name = "ListVDiskResponse")
-public class ListVDiskResponse extends SetWithStatusResponse<VDisk> {
-   @XmlElementWrapper(name = "vdisks")
-   @XmlElement(name = "vdisk")
-   private Set<VDisk> disks = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<VDisk> delegate() {
-      return disks == null ? ImmutableSet.<VDisk> of() : Collections
-            .unmodifiableSet(disks);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVSYSResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVSYSResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVSYSResponse.java
deleted file mode 100644
index 55b94b5..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVSYSResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VSystem;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListVSYSResponse.
- */
-@XmlRootElement(name = "ListVSYSResponse")
-public class ListVSYSResponse extends SetWithStatusResponse<VSystem> {
-   @XmlElementWrapper(name = "vsyss")
-   @XmlElement(name = "vsys")
-   private Set<VSystem> systems = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<VSystem> delegate() {
-      return systems == null ? ImmutableSet.<VSystem> of() : Collections
-            .unmodifiableSet(systems);
-   }
-}

http://git-wip-us.apache.org/repos/asf/jclouds-labs/blob/ba795261/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVServerResponse.java
----------------------------------------------------------------------
diff --git a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVServerResponse.java b/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVServerResponse.java
deleted file mode 100644
index 526f146..0000000
--- a/fgcp/src/main/java/org/jclouds/fujitsu/fgcp/xml/internal/ListVServerResponse.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.fujitsu.fgcp.xml.internal;
-
-import java.util.Collections;
-import java.util.Set;
-
-import javax.xml.bind.annotation.XmlElement;
-import javax.xml.bind.annotation.XmlElementWrapper;
-import javax.xml.bind.annotation.XmlRootElement;
-
-import org.jclouds.fujitsu.fgcp.domain.VServer;
-
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Sets;
-
-/**
- * Wrapper for ListVServerResponse.
- */
-@XmlRootElement(name = "ListVServerResponse")
-public class ListVServerResponse extends SetWithStatusResponse<VServer> {
-   @XmlElementWrapper(name = "vservers")
-   @XmlElement(name = "vserver")
-   private Set<VServer> servers = Sets.newLinkedHashSet();
-
-   @Override
-   protected Set<VServer> delegate() {
-      return servers == null ? ImmutableSet.<VServer> of() : Collections
-            .unmodifiableSet(servers);
-   }
-}