You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@stratos.apache.org by im...@apache.org on 2014/11/29 17:41:16 UTC

[29/39] stratos git commit: Removing jclouds/cloudstack fork in dependencies

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Volume.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Volume.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Volume.java
deleted file mode 100644
index 563c0cc..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Volume.java
+++ /dev/null
@@ -1,739 +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.cloudstack.domain;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import java.beans.ConstructorProperties;
-import java.util.Date;
-import java.util.Map;
-
-import org.jclouds.javax.annotation.Nullable;
-
-import com.google.common.base.CaseFormat;
-import com.google.common.base.Function;
-import com.google.common.base.MoreObjects;
-import com.google.common.base.MoreObjects.ToStringHelper;
-import com.google.common.base.Objects;
-import com.google.common.collect.ImmutableSet;
-import com.google.common.collect.Maps;
-
-public class Volume {
-
-   /**
-    */
-   public static enum State {
-
-      /**
-       * indicates that the volume record is created in the DB, but not on the backend
-       */
-      ALLOCATED,
-      /**
-       * the volume is being created on the backend
-       */
-      CREATING,
-      /**
-       * the volume is ready to be used
-       */
-      READY,
-      /**
-       * the volume is destroyed (either as a result of deleteVolume command for DataDisk or as a part of destroyVm)
-       */
-      DESTROYED,
-      /**
-       * the volume has failed somehow, e.g. during creation (in cloudstack development)
-       */
-      FAILED,
-
-      UNRECOGNIZED;
-
-      @Override
-      public String toString() {
-         return CaseFormat.UPPER_UNDERSCORE.to(CaseFormat.UPPER_CAMEL, name());
-      }
-
-      public static State fromValue(String state) {
-         try {
-            return valueOf(CaseFormat.UPPER_CAMEL.to(CaseFormat.UPPER_UNDERSCORE, checkNotNull(state, "state")));
-         } catch (IllegalArgumentException e) {
-            return UNRECOGNIZED;
-         }
-      }
-   }
-
-   /**
-    */
-   public static enum Type {
-      ROOT(0),
-      DATADISK(1),
-      UNRECOGNIZED(Integer.MAX_VALUE);
-
-      private int code;
-
-      private static final Map<Integer, Type> INDEX = Maps.uniqueIndex(ImmutableSet.copyOf(Type.values()),
-            new Function<Type, Integer>() {
-
-               @Override
-               public Integer apply(Type input) {
-                  return input.code;
-               }
-
-            });
-
-      Type(int code) {
-         this.code = code;
-      }
-
-      @Override
-      public String toString() {
-         return name().toLowerCase();
-      }
-
-      public static Type fromValue(String resourceType) {
-         Integer code = Integer.valueOf(checkNotNull(resourceType, "resourcetype"));
-         return INDEX.containsKey(code) ? INDEX.get(code) : UNRECOGNIZED;
-      }
-
-   }
-
-   public static Builder<?> builder() {
-      return new ConcreteBuilder();
-   }
-
-   public Builder<?> toBuilder() {
-      return new ConcreteBuilder().fromVolume(this);
-   }
-
-   public abstract static class Builder<T extends Builder<T>> {
-      protected abstract T self();
-
-      protected String id;
-      protected String account;
-      protected Date attached;
-      protected Date created;
-      protected boolean destroyed;
-      protected String deviceId;
-      protected String diskOfferingDisplayText;
-      protected String diskOfferingId;
-      protected String diskOfferingName;
-      protected String domain;
-      protected String domainId;
-      protected String hypervisor;
-      protected boolean isExtractable;
-      protected String jobId;
-      protected String jobStatus;
-      protected String name;
-      protected String serviceOfferingDisplayText;
-      protected String serviceOfferingId;
-      protected String serviceOfferingName;
-      protected long size;
-      protected String snapshotId;
-      protected Volume.State state;
-      protected String storage;
-      protected String storageType;
-      protected Volume.Type type;
-      protected String virtualMachineId;
-      protected String vmDisplayName;
-      protected String vmName;
-      protected VirtualMachine.State vmState;
-      protected String zoneId;
-      protected String zoneName;
-
-      /**
-       * @see Volume#getId()
-       */
-      public T id(String id) {
-         this.id = id;
-         return self();
-      }
-
-      /**
-       * @see Volume#getAccount()
-       */
-      public T account(String account) {
-         this.account = account;
-         return self();
-      }
-
-      /**
-       * @see Volume#getAttached()
-       */
-      public T attached(Date attached) {
-         this.attached = attached;
-         return self();
-      }
-
-      /**
-       * @see Volume#getCreated()
-       */
-      public T created(Date created) {
-         this.created = created;
-         return self();
-      }
-
-      /**
-       * @see Volume#isDestroyed()
-       */
-      public T destroyed(boolean destroyed) {
-         this.destroyed = destroyed;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDeviceId()
-       */
-      public T deviceId(String deviceId) {
-         this.deviceId = deviceId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDiskOfferingDisplayText()
-       */
-      public T diskOfferingDisplayText(String diskOfferingDisplayText) {
-         this.diskOfferingDisplayText = diskOfferingDisplayText;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDiskOfferingId()
-       */
-      public T diskOfferingId(String diskOfferingId) {
-         this.diskOfferingId = diskOfferingId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDiskOfferingName()
-       */
-      public T diskOfferingName(String diskOfferingName) {
-         this.diskOfferingName = diskOfferingName;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDomain()
-       */
-      public T domain(String domain) {
-         this.domain = domain;
-         return self();
-      }
-
-      /**
-       * @see Volume#getDomainId()
-       */
-      public T domainId(String domainId) {
-         this.domainId = domainId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getHypervisor()
-       */
-      public T hypervisor(String hypervisor) {
-         this.hypervisor = hypervisor;
-         return self();
-      }
-
-      /**
-       * @see Volume#isExtractable()
-       */
-      public T isExtractable(boolean isExtractable) {
-         this.isExtractable = isExtractable;
-         return self();
-      }
-
-      /**
-       * @see Volume#getJobId()
-       */
-      public T jobId(String jobId) {
-         this.jobId = jobId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getJobStatus()
-       */
-      public T jobStatus(String jobStatus) {
-         this.jobStatus = jobStatus;
-         return self();
-      }
-
-      /**
-       * @see Volume#getName()
-       */
-      public T name(String name) {
-         this.name = name;
-         return self();
-      }
-
-      /**
-       * @see Volume#getServiceOfferingDisplayText()
-       */
-      public T serviceOfferingDisplayText(String serviceOfferingDisplayText) {
-         this.serviceOfferingDisplayText = serviceOfferingDisplayText;
-         return self();
-      }
-
-      /**
-       * @see Volume#getServiceOfferingId()
-       */
-      public T serviceOfferingId(String serviceOfferingId) {
-         this.serviceOfferingId = serviceOfferingId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getServiceOfferingName()
-       */
-      public T serviceOfferingName(String serviceOfferingName) {
-         this.serviceOfferingName = serviceOfferingName;
-         return self();
-      }
-
-      /**
-       * @see Volume#getSize()
-       */
-      public T size(long size) {
-         this.size = size;
-         return self();
-      }
-
-      /**
-       * @see Volume#getSnapshotId()
-       */
-      public T snapshotId(String snapshotId) {
-         this.snapshotId = snapshotId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getState()
-       */
-      public T state(Volume.State state) {
-         this.state = state;
-         return self();
-      }
-
-      /**
-       * @see Volume#getStorage()
-       */
-      public T storage(String storage) {
-         this.storage = storage;
-         return self();
-      }
-
-      /**
-       * @see Volume#getStorageType()
-       */
-      public T storageType(String storageType) {
-         this.storageType = storageType;
-         return self();
-      }
-
-      /**
-       * @see Volume#getType()
-       */
-      public T type(Volume.Type type) {
-         this.type = type;
-         return self();
-      }
-
-      /**
-       * @see Volume#getVirtualMachineId()
-       */
-      public T virtualMachineId(String virtualMachineId) {
-         this.virtualMachineId = virtualMachineId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getVmDisplayName()
-       */
-      public T vmDisplayName(String vmDisplayName) {
-         this.vmDisplayName = vmDisplayName;
-         return self();
-      }
-
-      /**
-       * @see Volume#getVmName()
-       */
-      public T vmName(String vmName) {
-         this.vmName = vmName;
-         return self();
-      }
-
-      /**
-       * @see Volume#getVmState()
-       */
-      public T vmState(VirtualMachine.State vmState) {
-         this.vmState = vmState;
-         return self();
-      }
-
-      /**
-       * @see Volume#getZoneId()
-       */
-      public T zoneId(String zoneId) {
-         this.zoneId = zoneId;
-         return self();
-      }
-
-      /**
-       * @see Volume#getZoneName()
-       */
-      public T zoneName(String zoneName) {
-         this.zoneName = zoneName;
-         return self();
-      }
-
-      public Volume build() {
-         return new Volume(id, account, attached, created, destroyed, deviceId, diskOfferingDisplayText, diskOfferingId, diskOfferingName, domain, domainId, hypervisor, isExtractable, jobId, jobStatus, name, serviceOfferingDisplayText, serviceOfferingId, serviceOfferingName, size, snapshotId, state, storage, storageType, type, virtualMachineId, vmDisplayName, vmName, vmState, zoneId, zoneName);
-      }
-
-      public T fromVolume(Volume in) {
-         return this
-               .id(in.getId())
-               .account(in.getAccount())
-               .attached(in.getAttached())
-               .created(in.getCreated())
-               .destroyed(in.isDestroyed())
-               .deviceId(in.getDeviceId())
-               .diskOfferingDisplayText(in.getDiskOfferingDisplayText())
-               .diskOfferingId(in.getDiskOfferingId())
-               .diskOfferingName(in.getDiskOfferingName())
-               .domain(in.getDomain())
-               .domainId(in.getDomainId())
-               .hypervisor(in.getHypervisor())
-               .isExtractable(in.isExtractable())
-               .jobId(in.getJobId())
-               .jobStatus(in.getJobStatus())
-               .name(in.getName())
-               .serviceOfferingDisplayText(in.getServiceOfferingDisplayText())
-               .serviceOfferingId(in.getServiceOfferingId())
-               .serviceOfferingName(in.getServiceOfferingName())
-               .size(in.getSize())
-               .snapshotId(in.getSnapshotId())
-               .state(in.getState())
-               .storage(in.getStorage())
-               .storageType(in.getStorageType())
-               .type(in.getType())
-               .virtualMachineId(in.getVirtualMachineId())
-               .vmDisplayName(in.getVmDisplayName())
-               .vmName(in.getVmName())
-               .vmState(in.getVmState())
-               .zoneId(in.getZoneId())
-               .zoneName(in.getZoneName());
-      }
-   }
-
-   private static class ConcreteBuilder extends Builder<ConcreteBuilder> {
-      @Override
-      protected ConcreteBuilder self() {
-         return this;
-      }
-   }
-
-   private final String id;
-   private final String account;
-   private final Date attached;
-   private final Date created;
-   private final boolean destroyed;
-   private final String deviceId;
-   private final String diskOfferingDisplayText;
-   private final String diskOfferingId;
-   private final String diskOfferingName;
-   private final String domain;
-   private final String domainId;
-   private final String hypervisor;
-   private final boolean isExtractable;
-   private final String jobId;
-   private final String jobStatus;
-   private final String name;
-   private final String serviceOfferingDisplayText;
-   private final String serviceOfferingId;
-   private final String serviceOfferingName;
-   private final long size;
-   private final String snapshotId;
-   private final Volume.State state;
-   private final String storage;
-   private final String storageType;
-   private final Volume.Type type;
-   private final String virtualMachineId;
-   private final String vmDisplayName;
-   private final String vmName;
-   private final VirtualMachine.State vmState;
-   private final String zoneId;
-   private final String zoneName;
-
-   @ConstructorProperties({
-         "id", "account", "attached", "created", "destroyed", "deviceid", "diskofferingdisplaytext", "diskofferingid", "diskofferingname", "domain", "domainid", "hypervisor", "isextractable", "jobid", "jobstatus", "name", "serviceofferingdisplaytext", "serviceofferingid", "serviceofferingname", "size", "snapshotid", "state", "storage", "storagetype", "type", "virtualmachineid", "vmdisplayname", "vmname", "vmstate", "zoneid", "zonename"
-   })
-   protected Volume(String id, @Nullable String account, @Nullable Date attached, @Nullable Date created, boolean destroyed,
-                    @Nullable String deviceId, @Nullable String diskOfferingDisplayText, @Nullable String diskOfferingId,
-                    @Nullable String diskOfferingName, @Nullable String domain, @Nullable String domainId, @Nullable String hypervisor,
-                    boolean isExtractable, @Nullable String jobId, @Nullable String jobStatus, @Nullable String name,
-                    @Nullable String serviceOfferingDisplayText, @Nullable String serviceOfferingId, @Nullable String serviceOfferingName,
-                    long size, @Nullable String snapshotId, @Nullable Volume.State state, @Nullable String storage,
-                    @Nullable String storageType, @Nullable Volume.Type type, @Nullable String virtualMachineId,
-                    @Nullable String vmDisplayName, @Nullable String vmName, @Nullable VirtualMachine.State vmState,
-                    @Nullable String zoneId, @Nullable String zoneName) {
-      this.id = checkNotNull(id, "id");
-      this.account = account;
-      this.attached = attached;
-      this.created = created;
-      this.destroyed = destroyed;
-      this.deviceId = deviceId;
-      this.diskOfferingDisplayText = diskOfferingDisplayText;
-      this.diskOfferingId = diskOfferingId;
-      this.diskOfferingName = diskOfferingName;
-      this.domain = domain;
-      this.domainId = domainId;
-      this.hypervisor = hypervisor;
-      this.isExtractable = isExtractable;
-      this.jobId = jobId;
-      this.jobStatus = jobStatus;
-      this.name = name;
-      this.serviceOfferingDisplayText = serviceOfferingDisplayText;
-      this.serviceOfferingId = serviceOfferingId;
-      this.serviceOfferingName = serviceOfferingName;
-      this.size = size;
-      this.snapshotId = snapshotId;
-      this.state = state;
-      this.storage = storage;
-      this.storageType = storageType;
-      this.type = type;
-      this.virtualMachineId = virtualMachineId;
-      this.vmDisplayName = vmDisplayName;
-      this.vmName = vmName;
-      this.vmState = vmState;
-      this.zoneId = zoneId;
-      this.zoneName = zoneName;
-   }
-
-   public String getId() {
-      return this.id;
-   }
-
-   @Nullable
-   public String getAccount() {
-      return this.account;
-   }
-
-   @Nullable
-   public Date getAttached() {
-      return this.attached;
-   }
-
-   @Nullable
-   public Date getCreated() {
-      return this.created;
-   }
-
-   public boolean isDestroyed() {
-      return this.destroyed;
-   }
-
-   @Nullable
-   public String getDeviceId() {
-      return this.deviceId;
-   }
-
-   @Nullable
-   public String getDiskOfferingDisplayText() {
-      return this.diskOfferingDisplayText;
-   }
-
-   @Nullable
-   public String getDiskOfferingId() {
-      return this.diskOfferingId;
-   }
-
-   @Nullable
-   public String getDiskOfferingName() {
-      return this.diskOfferingName;
-   }
-
-   @Nullable
-   public String getDomain() {
-      return this.domain;
-   }
-
-   @Nullable
-   public String getDomainId() {
-      return this.domainId;
-   }
-
-   @Nullable
-   public String getHypervisor() {
-      return this.hypervisor;
-   }
-
-   public boolean isExtractable() {
-      return this.isExtractable;
-   }
-
-   @Nullable
-   public String getJobId() {
-      return this.jobId;
-   }
-
-   @Nullable
-   public String getJobStatus() {
-      return this.jobStatus;
-   }
-
-   @Nullable
-   public String getName() {
-      return this.name;
-   }
-
-   @Nullable
-   public String getServiceOfferingDisplayText() {
-      return this.serviceOfferingDisplayText;
-   }
-
-   @Nullable
-   public String getServiceOfferingId() {
-      return this.serviceOfferingId;
-   }
-
-   @Nullable
-   public String getServiceOfferingName() {
-      return this.serviceOfferingName;
-   }
-
-   public long getSize() {
-      return this.size;
-   }
-
-   @Nullable
-   public String getSnapshotId() {
-      return this.snapshotId;
-   }
-
-   @Nullable
-   public Volume.State getState() {
-      return this.state;
-   }
-
-   @Nullable
-   public String getStorage() {
-      return this.storage;
-   }
-
-   @Nullable
-   public String getStorageType() {
-      return this.storageType;
-   }
-
-   @Nullable
-   public Volume.Type getType() {
-      return this.type;
-   }
-
-   @Nullable
-   public String getVirtualMachineId() {
-      return this.virtualMachineId;
-   }
-
-   @Nullable
-   public String getVmDisplayName() {
-      return this.vmDisplayName;
-   }
-
-   @Nullable
-   public String getVmName() {
-      return this.vmName;
-   }
-
-   @Nullable
-   public VirtualMachine.State getVmState() {
-      return this.vmState;
-   }
-
-   @Nullable
-   public String getZoneId() {
-      return this.zoneId;
-   }
-
-   @Nullable
-   public String getZoneName() {
-      return this.zoneName;
-   }
-
-   @Override
-   public int hashCode() {
-      return Objects.hashCode(id, account, attached, created, destroyed, deviceId, diskOfferingDisplayText, diskOfferingId, diskOfferingName, domain, domainId, hypervisor, isExtractable, jobId, jobStatus, name, serviceOfferingDisplayText, serviceOfferingId, serviceOfferingName, size, snapshotId, state, storage, storageType, type, virtualMachineId, vmDisplayName, vmName, vmState, zoneId, zoneName);
-   }
-
-   @Override
-   public boolean equals(Object obj) {
-      if (this == obj) return true;
-      if (obj == null || getClass() != obj.getClass()) return false;
-      Volume that = Volume.class.cast(obj);
-      return Objects.equal(this.id, that.id)
-            && Objects.equal(this.account, that.account)
-            && Objects.equal(this.attached, that.attached)
-            && Objects.equal(this.created, that.created)
-            && Objects.equal(this.destroyed, that.destroyed)
-            && Objects.equal(this.deviceId, that.deviceId)
-            && Objects.equal(this.diskOfferingDisplayText, that.diskOfferingDisplayText)
-            && Objects.equal(this.diskOfferingId, that.diskOfferingId)
-            && Objects.equal(this.diskOfferingName, that.diskOfferingName)
-            && Objects.equal(this.domain, that.domain)
-            && Objects.equal(this.domainId, that.domainId)
-            && Objects.equal(this.hypervisor, that.hypervisor)
-            && Objects.equal(this.isExtractable, that.isExtractable)
-            && Objects.equal(this.jobId, that.jobId)
-            && Objects.equal(this.jobStatus, that.jobStatus)
-            && Objects.equal(this.name, that.name)
-            && Objects.equal(this.serviceOfferingDisplayText, that.serviceOfferingDisplayText)
-            && Objects.equal(this.serviceOfferingId, that.serviceOfferingId)
-            && Objects.equal(this.serviceOfferingName, that.serviceOfferingName)
-            && Objects.equal(this.size, that.size)
-            && Objects.equal(this.snapshotId, that.snapshotId)
-            && Objects.equal(this.state, that.state)
-            && Objects.equal(this.storage, that.storage)
-            && Objects.equal(this.storageType, that.storageType)
-            && Objects.equal(this.type, that.type)
-            && Objects.equal(this.virtualMachineId, that.virtualMachineId)
-            && Objects.equal(this.vmDisplayName, that.vmDisplayName)
-            && Objects.equal(this.vmName, that.vmName)
-            && Objects.equal(this.vmState, that.vmState)
-            && Objects.equal(this.zoneId, that.zoneId)
-            && Objects.equal(this.zoneName, that.zoneName);
-   }
-
-   protected ToStringHelper string() {
-      return MoreObjects.toStringHelper(this)
-            .add("id", id).add("account", account).add("attached", attached).add("created", created).add("destroyed", destroyed)
-            .add("deviceId", deviceId).add("diskOfferingDisplayText", diskOfferingDisplayText).add("diskOfferingId", diskOfferingId)
-            .add("diskOfferingName", diskOfferingName).add("domain", domain).add("domainId", domainId).add("hypervisor", hypervisor)
-            .add("isExtractable", isExtractable).add("jobId", jobId).add("jobStatus", jobStatus).add("name", name)
-            .add("serviceOfferingDisplayText", serviceOfferingDisplayText).add("serviceOfferingId", serviceOfferingId)
-            .add("serviceOfferingName", serviceOfferingName).add("size", size).add("snapshotId", snapshotId).add("state", state)
-            .add("storage", storage).add("storageType", storageType).add("type", type).add("virtualMachineId", virtualMachineId)
-            .add("vmDisplayName", vmDisplayName).add("vmName", vmName).add("vmState", vmState).add("zoneId", zoneId).add("zoneName", zoneName);
-   }
-
-   @Override
-   public String toString() {
-      return string().toString();
-   }
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Zone.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Zone.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Zone.java
deleted file mode 100644
index 81cec1e..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/Zone.java
+++ /dev/null
@@ -1,435 +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.cloudstack.domain;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import java.beans.ConstructorProperties;
-import java.util.List;
-
-import org.jclouds.javax.annotation.Nullable;
-
-import com.google.common.base.MoreObjects;
-import com.google.common.base.MoreObjects.ToStringHelper;
-import com.google.common.base.Objects;
-import com.google.common.collect.ImmutableList;
-
-public class Zone implements Comparable<Zone> {
-
-   public static Builder<?> builder() {
-      return new ConcreteBuilder();
-   }
-
-   public Builder<?> toBuilder() {
-      return new ConcreteBuilder().fromZone(this);
-   }
-
-   public abstract static class Builder<T extends Builder<T>> {
-      protected abstract T self();
-
-      protected String id;
-      protected String description;
-      protected String displayText;
-      protected String DNS1;
-      protected String DNS2;
-      protected String domain;
-      protected String domainId;
-      protected String guestCIDRAddress;
-      protected String internalDNS1;
-      protected String internalDNS2;
-      protected String name;
-      protected NetworkType networkType;
-      protected String VLAN;
-      protected boolean securityGroupsEnabled;
-      protected AllocationState allocationState;
-      protected String dhcpProvider;
-      protected String zoneToken;
-
-      /**
-       * @see Zone#getId()
-       */
-      public T id(String id) {
-         this.id = id;
-         return self();
-      }
-
-      /**
-       * @see Zone#getDescription()
-       */
-      public T description(String description) {
-         this.description = description;
-         return self();
-      }
-
-      /**
-       * @see Zone#getDisplayText()
-       */
-      public T displayText(String displayText) {
-         this.displayText = displayText;
-         return self();
-      }
-
-      /**
-       * @see Zone#getDNS()
-       */
-      public T DNS(List<String> DNS) {
-         if (!DNS.isEmpty()) this.DNS1 = DNS.get(0);
-         if (DNS.size() > 1) this.DNS2 = DNS.get(1);
-         return self();
-      }
-
-      /**
-       * @see Zone#getDomain()
-       */
-      public T domain(String domain) {
-         this.domain = domain;
-         return self();
-      }
-
-      /**
-       * @see Zone#getDomainId()
-       */
-      public T domainId(String domainId) {
-         this.domainId = domainId;
-         return self();
-      }
-
-      /**
-       * @see Zone#getGuestCIDRAddress()
-       */
-      public T guestCIDRAddress(String guestCIDRAddress) {
-         this.guestCIDRAddress = guestCIDRAddress;
-         return self();
-      }
-
-      /**
-       * @see Zone#getInternalDNS()
-       */
-      public T internalDNS(List<String> DNS) {
-         if (!DNS.isEmpty()) this.internalDNS1 = DNS.get(0);
-         if (DNS.size() > 1) this.internalDNS2 = DNS.get(1);
-         return self();
-      }
-
-      /**
-       * @see Zone#getName()
-       */
-      public T name(String name) {
-         this.name = name;
-         return self();
-      }
-
-      /**
-       * @see Zone#getNetworkType()
-       */
-      public T networkType(NetworkType networkType) {
-         this.networkType = networkType;
-         return self();
-      }
-
-      /**
-       * @see Zone#getVLAN()
-       */
-      public T VLAN(String VLAN) {
-         this.VLAN = VLAN;
-         return self();
-      }
-
-      /**
-       * @see Zone#isSecurityGroupsEnabled()
-       */
-      public T securityGroupsEnabled(boolean securityGroupsEnabled) {
-         this.securityGroupsEnabled = securityGroupsEnabled;
-         return self();
-      }
-
-      /**
-       * @see Zone#getAllocationState()
-       */
-      public T allocationState(AllocationState allocationState) {
-         this.allocationState = allocationState;
-         return self();
-      }
-
-      /**
-       * @see Zone#getDhcpProvider()
-       */
-      public T dhcpProvider(String dhcpProvider) {
-         this.dhcpProvider = dhcpProvider;
-         return self();
-      }
-
-      /**
-       * @see Zone#getZoneToken()
-       */
-      public T zoneToken(String zoneToken) {
-         this.zoneToken = zoneToken;
-         return self();
-      }
-
-      public Zone build() {
-         return new Zone(id, description, displayText, DNS1, DNS2, domain, domainId, guestCIDRAddress, internalDNS1, internalDNS2,
-               name, networkType, VLAN, securityGroupsEnabled, allocationState, dhcpProvider, zoneToken);
-      }
-
-      public T fromZone(Zone in) {
-         return this
-               .id(in.getId())
-               .description(in.getDescription())
-               .displayText(in.getDisplayText())
-               .DNS(in.getDNS())
-               .domain(in.getDomain())
-               .domainId(in.getDomainId())
-               .guestCIDRAddress(in.getGuestCIDRAddress())
-               .internalDNS(in.getInternalDNS())
-               .name(in.getName())
-               .networkType(in.getNetworkType())
-               .VLAN(in.getVLAN())
-               .securityGroupsEnabled(in.isSecurityGroupsEnabled())
-               .allocationState(in.getAllocationState())
-               .dhcpProvider(in.getDhcpProvider())
-               .zoneToken(in.getZoneToken());
-      }
-   }
-
-   private static class ConcreteBuilder extends Builder<ConcreteBuilder> {
-      @Override
-      protected ConcreteBuilder self() {
-         return this;
-      }
-   }
-
-   private final String id;
-   private final String description;
-   private final String displayText;
-   private final String DNS1;
-   private final String DNS2;
-   private final String domain;
-   private final String domainId;
-   private final String guestCIDRAddress;
-   private final String internalDNS1;
-   private final String internalDNS2;
-   private final String name;
-   private final NetworkType networkType;
-   private final String VLAN;
-   private final boolean securityGroupsEnabled;
-   private final AllocationState allocationState;
-   private final String dhcpProvider;
-   private final String zoneToken;
-
-   @ConstructorProperties({
-         "id", "description", "displaytext", "dns1", "dns2", "domain", "domainid", "guestcidraddress", "internaldns1", "internaldns2", "name", "networktype", "vlan", "securitygroupsenabled", "allocationstate", "dhcpprovider", "zonetoken"
-   })
-   protected Zone(String id, @Nullable String description, @Nullable String displayText, @Nullable String DNS1, @Nullable String DNS2,
-                  @Nullable String domain, @Nullable String domainId, @Nullable String guestCIDRAddress, @Nullable String internalDNS1,
-                  @Nullable String internalDNS2, @Nullable String name, @Nullable NetworkType networkType, @Nullable String VLAN,
-                  boolean securityGroupsEnabled, @Nullable AllocationState allocationState, @Nullable String dhcpProvider,
-                  @Nullable String zoneToken) {
-      this.id = checkNotNull(id, "id");
-      this.description = description;
-      this.displayText = displayText;
-      this.DNS1 = DNS1;
-      this.DNS2 = DNS2;
-      this.domain = domain;
-      this.domainId = domainId;
-      this.guestCIDRAddress = guestCIDRAddress;
-      this.internalDNS1 = internalDNS1;
-      this.internalDNS2 = internalDNS2;
-      this.name = name;
-      this.networkType = networkType;
-      this.VLAN = VLAN;
-      this.securityGroupsEnabled = securityGroupsEnabled;
-      this.allocationState = allocationState;
-      this.dhcpProvider = dhcpProvider;
-      this.zoneToken = zoneToken;
-   }
-
-   /**
-    * @return Zone id
-    */
-   public String getId() {
-      return this.id;
-   }
-
-   /**
-    * @return Zone description
-    */
-   @Nullable
-   public String getDescription() {
-      return this.description;
-   }
-
-   /**
-    * @return the display text of the zone
-    */
-   @Nullable
-   public String getDisplayText() {
-      return this.displayText;
-   }
-
-   /**
-    * @return the external DNS for the Zone
-    */
-   public List<String> getDNS() {
-      ImmutableList.Builder<String> builder = ImmutableList.builder();
-      if (DNS1 != null && !"".equals(DNS1))
-         builder.add(DNS1);
-      if (DNS2 != null && !"".equals(DNS2))
-         builder.add(DNS2);
-      return builder.build();
-   }
-
-   /**
-    * @return Domain name for the Vms in the zone
-    */
-   @Nullable
-   public String getDomain() {
-      return this.domain;
-   }
-
-   /**
-    * @return the ID of the containing domain, null for public zones
-    */
-   @Nullable
-   public String getDomainId() {
-      return this.domainId;
-   }
-
-   /**
-    * @return the guest CIDR address for the Zone
-    */
-   @Nullable
-   public String getGuestCIDRAddress() {
-      return this.guestCIDRAddress;
-   }
-
-   /**
-    * @return the internal DNS for the Zone
-    */
-   public List<String> getInternalDNS() {
-      ImmutableList.Builder<String> builder = ImmutableList.builder();
-      if (internalDNS1 != null && !"".equals(internalDNS1))
-         builder.add(internalDNS1);
-      if (internalDNS2 != null && !"".equals(internalDNS2))
-         builder.add(internalDNS2);
-      return builder.build();
-   }
-
-   /**
-    * @return Zone name
-    */
-   @Nullable
-   public String getName() {
-      return this.name;
-   }
-
-   /**
-    * @return the network type of the zone; can be Basic or Advanced
-    */
-   @Nullable
-   public NetworkType getNetworkType() {
-      return this.networkType;
-   }
-
-   /**
-    * @return the vlan range of the zone
-    */
-   @Nullable
-   public String getVLAN() {
-      return this.VLAN;
-   }
-
-   /**
-    * @return true if this zone has security groups enabled
-    */
-   public boolean isSecurityGroupsEnabled() {
-      return this.securityGroupsEnabled;
-   }
-
-   /**
-    * @return the allocation state of the cluster
-    */
-   @Nullable
-   public AllocationState getAllocationState() {
-      return this.allocationState;
-   }
-
-   /**
-    * @return the dhcp Provider for the Zone
-    */
-   @Nullable
-   public String getDhcpProvider() {
-      return this.dhcpProvider;
-   }
-
-   /**
-    * @return Zone Token
-    */
-   @Nullable
-   public String getZoneToken() {
-      return this.zoneToken;
-   }
-
-   @Override
-   public int hashCode() {
-      return Objects.hashCode(id, description, displayText, DNS1, DNS2, domain, domainId, guestCIDRAddress, internalDNS1,
-            internalDNS2, name, networkType, VLAN, securityGroupsEnabled, allocationState, dhcpProvider, zoneToken);
-   }
-
-   @Override
-   public boolean equals(Object obj) {
-      if (this == obj) return true;
-      if (obj == null || getClass() != obj.getClass()) return false;
-      Zone that = Zone.class.cast(obj);
-      return Objects.equal(this.id, that.id)
-            && Objects.equal(this.description, that.description)
-            && Objects.equal(this.displayText, that.displayText)
-            && Objects.equal(this.DNS1, that.DNS1)
-            && Objects.equal(this.DNS2, that.DNS2)
-            && Objects.equal(this.domain, that.domain)
-            && Objects.equal(this.domainId, that.domainId)
-            && Objects.equal(this.guestCIDRAddress, that.guestCIDRAddress)
-            && Objects.equal(this.internalDNS1, that.internalDNS1)
-            && Objects.equal(this.internalDNS2, that.internalDNS2)
-            && Objects.equal(this.name, that.name)
-            && Objects.equal(this.networkType, that.networkType)
-            && Objects.equal(this.VLAN, that.VLAN)
-            && Objects.equal(this.securityGroupsEnabled, that.securityGroupsEnabled)
-            && Objects.equal(this.allocationState, that.allocationState)
-            && Objects.equal(this.dhcpProvider, that.dhcpProvider)
-            && Objects.equal(this.zoneToken, that.zoneToken);
-   }
-
-   protected ToStringHelper string() {
-      return MoreObjects.toStringHelper(this)
-            .add("id", id).add("description", description).add("displayText", displayText).add("DNS1", DNS1).add("DNS2", DNS2)
-            .add("domain", domain).add("domainId", domainId).add("guestCIDRAddress", guestCIDRAddress).add("internalDNS1", internalDNS1)
-            .add("internalDNS2", internalDNS2).add("name", name).add("networkType", networkType).add("VLAN", VLAN)
-            .add("securityGroupsEnabled", securityGroupsEnabled).add("allocationState", allocationState).add("dhcpProvider", dhcpProvider)
-            .add("zoneToken", zoneToken);
-   }
-
-   @Override
-   public String toString() {
-      return string().toString();
-   }
-
-   @Override
-   public int compareTo(Zone o) {
-      return id.compareTo(o.getId());
-   }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneAndName.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneAndName.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneAndName.java
deleted file mode 100644
index b6e7d2f..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneAndName.java
+++ /dev/null
@@ -1,93 +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.cloudstack.domain;
-
-import static com.google.common.base.Objects.equal;
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import com.google.common.base.Function;
-import com.google.common.base.MoreObjects;
-import com.google.common.base.MoreObjects.ToStringHelper;
-import com.google.common.base.Objects;
-
-/**
- * Helpful when looking for resources by zone and name
- */
-public class ZoneAndName {
-   
-   public static final Function<ZoneAndName, String> NAME_FUNCTION = new Function<ZoneAndName, String>() {
-
-      @Override
-      public String apply(ZoneAndName input) {
-         return input.getName();
-      }
-      
-   };
-   
-   public static final Function<ZoneAndName, String> ZONE_FUNCTION = new Function<ZoneAndName, String>() {
-
-      @Override
-      public String apply(ZoneAndName input) {
-         return input.getZone();
-      }
-      
-   };
-
-   public static ZoneAndName fromZoneAndName(String zoneId, String name) {
-      return new ZoneAndName(zoneId, name);
-   }
-
-   protected final String zoneId;
-   protected final String name;
-
-   protected ZoneAndName(String zoneId, String name) {
-      this.zoneId = checkNotNull(zoneId, "zoneId");
-      this.name = checkNotNull(name, "name");
-   }
-
-   public String getZone() {
-      return zoneId;
-   }
-
-   public String getName() {
-      return name;
-   }
-
-   @Override
-   public boolean equals(Object o) {
-      if (this == o)
-         return true;
-      if (o == null || getClass() != o.getClass())
-         return false;
-      ZoneAndName that = ZoneAndName.class.cast(o);
-      return equal(this.zoneId, that.zoneId) && equal(this.name, that.name);
-   }
-
-   @Override
-   public int hashCode() {
-      return Objects.hashCode(zoneId, name);
-   }
-
-   @Override
-   public String toString() {
-      return string().toString();
-   }
-
-   protected ToStringHelper string() {
-      return MoreObjects.toStringHelper("").add("zoneId", zoneId).add("name", name);
-   }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneSecurityGroupNamePortsCidrs.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneSecurityGroupNamePortsCidrs.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneSecurityGroupNamePortsCidrs.java
deleted file mode 100644
index 8d75264..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/domain/ZoneSecurityGroupNamePortsCidrs.java
+++ /dev/null
@@ -1,158 +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.cloudstack.domain;
-
-import static com.google.common.base.Preconditions.checkNotNull;
-
-import java.util.Set;
-
-
-import com.google.common.base.MoreObjects;
-import com.google.common.base.MoreObjects.ToStringHelper;
-import com.google.common.base.Objects;
-import com.google.common.collect.ImmutableSet;
-
-public class ZoneSecurityGroupNamePortsCidrs extends ZoneAndName {
-
-   public static Builder<?> builder() {
-      return new ConcreteBuilder();
-   }
-
-   public Builder<?> toBuilder() {
-      return new ConcreteBuilder().fromZoneSecurityGroupNamePortsCidrs(this);
-   }
-
-   public abstract static class Builder<T extends Builder<T>> {
-      protected abstract T self();
-
-      protected String zoneId;
-      protected String name;
-      protected Set<Integer> ports = ImmutableSet.of();
-      protected Set<String> cidrs = ImmutableSet.of();
-
-      /**
-       * @see ZoneSecurityGroupNamePortsCidrs#getZone()
-       */
-      public T zone(String zoneId) {
-         this.zoneId = zoneId;
-         return self();
-      }
-
-      /**
-       * @see ZoneSecurityGroupNamePortsCidrs#getName()
-       */
-      public T name(String name) {
-         this.name = name;
-         return self();
-      }
-      
-      /**
-       * @see ZoneSecurityGroupNamePortsCidrs#getPorts()
-       */
-      public T ports(Set<Integer> ports) {
-         this.ports = ImmutableSet.copyOf(checkNotNull(ports, "ports"));
-         return self();
-      }
-
-      public T ports(Integer... in) {
-         return ports(ImmutableSet.copyOf(in));
-      }
-      
-      /**
-       * @see ZoneSecurityGroupNamePortsCidrs#getCidrs()
-       */
-      public T cidrs(Set<String> cidrs) {
-         this.cidrs = ImmutableSet.copyOf(checkNotNull(cidrs, "cidrs"));
-         return self();
-      }
-
-      public T cidrs(String... in) {
-         return cidrs(ImmutableSet.copyOf(in));
-      }
-
-      public ZoneSecurityGroupNamePortsCidrs build() {
-         return new ZoneSecurityGroupNamePortsCidrs(zoneId, name, ports, cidrs);
-      }
-
-      public T fromZoneSecurityGroupNamePortsCidrs(ZoneSecurityGroupNamePortsCidrs in) {
-         return this.zone(in.getZone())
-            .name(in.getName())
-            .ports(in.getPorts())
-            .cidrs(in.getCidrs());
-      }
-   }
-   
-   private static class ConcreteBuilder extends Builder<ConcreteBuilder> {
-      @Override
-      protected ConcreteBuilder self() {
-         return this;
-      }
-   }
-
-   
-   private final Set<Integer> ports;
-   private final Set<String> cidrs;
-
-   protected ZoneSecurityGroupNamePortsCidrs(String zoneId, String name, Set<Integer> ports,
-                                             Set<String> cidrs) {
-      super(zoneId, name);
-      this.ports = ports == null ? ImmutableSet.<Integer>of() : ImmutableSet.copyOf(ports);
-      this.cidrs = cidrs == null ? ImmutableSet.<String>of() : ImmutableSet.copyOf(cidrs);
-   }
-
-   /**
-    *
-    * @return the set of ports to open in the security group
-    */
-   public Set<Integer> getPorts() {
-      return ports;
-   }
-   
-   /**
-    *
-    * @return the set of cidrs to give access to the open ports in the security group
-    */
-   public Set<String> getCidrs() {
-      return cidrs;
-   }
-
-   @Override
-   public int hashCode() {
-      return Objects.hashCode(zoneId, name, ports, cidrs);
-   }
-
-   @Override
-   public boolean equals(Object obj) {
-      if (this == obj) return true;
-      if (obj == null || getClass() != obj.getClass()) return false;
-      ZoneSecurityGroupNamePortsCidrs that = ZoneSecurityGroupNamePortsCidrs.class.cast(obj);
-      return Objects.equal(this.zoneId, that.zoneId)
-         && Objects.equal(this.name, that.name)
-         && Objects.equal(this.ports, that.ports)
-         && Objects.equal(this.cidrs, that.cidrs);
-   }
-
-   protected ToStringHelper string() {
-      return MoreObjects.toStringHelper(this)
-         .add("zoneId", zoneId).add("name", name).add("ports", ports).add("cidrs", cidrs);
-   }
-
-   @Override
-   public String toString() {
-      return string().toString();
-   }
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AccountApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AccountApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AccountApi.java
deleted file mode 100644
index b5eaaf5..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AccountApi.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.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.Account;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.options.ListAccountsOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.OnlyElement;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- * 
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface AccountApi {
-   /**
-    * Lists Accounts
-    * 
-    * @param options
-    *           if present, how to constrain the list.
-    * @return Accounts matching query, or empty set, if no Accounts are found
-    */
-   @Named("listAccounts")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listAccounts", "true" })
-   @SelectJson("account")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<Account> listAccounts(ListAccountsOptions... options);
-
-   /**
-    * get a specific Account by id
-    * 
-    * @param id
-    *           Account to get
-    * @return Account or null if not found
-    */
-   @Named("listAccounts")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listAccounts", "true" })
-   @SelectJson("account")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   Account getAccount(@QueryParam("id") String id);
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AddressApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AddressApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AddressApi.java
deleted file mode 100644
index 36a6c79..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AddressApi.java
+++ /dev/null
@@ -1,112 +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.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.AsyncCreateResponse;
-import org.jclouds.cloudstack.domain.PublicIPAddress;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.functions.CloudStackFallbacks.VoidOnNotFoundOr404OrUnableToFindAccountOwner;
-import org.jclouds.cloudstack.options.AssociateIPAddressOptions;
-import org.jclouds.cloudstack.options.ListPublicIPAddressesOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.OnlyElement;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-import org.jclouds.rest.annotations.Unwrap;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- * 
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface AddressApi {
-
-   /**
-    * Lists IPAddresses
-    * 
-    * @param options
-    *           if present, how to constrain the list.
-    * @return IPAddresses matching query, or empty set, if no IPAddresses are
-    *         found
-    */
-   @Named("listPublicIpAddresses")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listPublicIpAddresses", "true" })
-   @SelectJson("publicipaddress")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<PublicIPAddress> listPublicIPAddresses(ListPublicIPAddressesOptions... options);
-
-   /**
-    * get a specific IPAddress by id
-    * 
-    * @param id
-    *           IPAddress to get
-    * @return IPAddress or null if not found
-    */
-   @Named("listPublicIpAddresses")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listPublicIpAddresses", "true" })
-   @SelectJson("publicipaddress")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   PublicIPAddress getPublicIPAddress(@QueryParam("id") String id);
-
-   /**
-    * Acquires and associates a public IP to an account.
-    * 
-    * @param zoneId
-    *           the ID of the availability zone you want to acquire an public IP
-    *           address from
-    * @return IPAddress
-    */
-   @Named("associateIpAddress")
-   @GET
-   @QueryParams(keys = "command", values = "associateIpAddress")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse associateIPAddressInZone(@QueryParam("zoneid") String zoneId,
-         AssociateIPAddressOptions... options);
-
-   /**
-    * Disassociates an ip address from the account.
-    * 
-    * @param id
-    *           the id of the public ip address to disassociate
-    */
-   @Named("disassociateIpAddress")
-   @GET
-   @QueryParams(keys = "command", values = "disassociateIpAddress")
-   @Fallback(VoidOnNotFoundOr404OrUnableToFindAccountOwner.class)
-   void disassociateIPAddress(@QueryParam("id") String id);
-   
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AsyncJobApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AsyncJobApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AsyncJobApi.java
deleted file mode 100644
index 26867cd..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/AsyncJobApi.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.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.AsyncJob;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.functions.ParseAsyncJobFromHttpResponse;
-import org.jclouds.cloudstack.functions.ParseAsyncJobsFromHttpResponse;
-import org.jclouds.cloudstack.options.ListAsyncJobsOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.ResponseParser;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- * 
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface AsyncJobApi {
-
-   /**
-    * Lists asyncJobs
-    * 
-    * @param options
-    *           if present, how to constrain the list.
-    * @return asyncJobs matching query, or empty set, if no asyncJobs are found
-    */
-   @Named("listAsyncJobs")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listAsyncJobs", "true" })
-   @ResponseParser(ParseAsyncJobsFromHttpResponse.class)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<AsyncJob<?>> listAsyncJobs(ListAsyncJobsOptions... options);
-
-   /**
-    * get a specific asyncJob by id
-    * 
-    * @param id
-    *           asyncJob to get
-    * @return asyncJob or null if not found
-    */
-   @Named("queryAsyncJobResult")
-   @GET
-   @QueryParams(keys = "command", values = "queryAsyncJobResult")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @ResponseParser(ParseAsyncJobFromHttpResponse.class)
-   @Fallback(NullOnNotFoundOr404.class)
-   <T> AsyncJob<T> getAsyncJob(@QueryParam("jobid") String id);
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/ConfigurationApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/ConfigurationApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/ConfigurationApi.java
deleted file mode 100644
index 2ca59e3..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/ConfigurationApi.java
+++ /dev/null
@@ -1,53 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.cloudstack.features;
-
-import javax.inject.Named;
-import javax.ws.rs.Consumes;
-import javax.ws.rs.GET;
-import javax.ws.rs.core.MediaType;
-
-import org.jclouds.cloudstack.domain.Capabilities;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- * 
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = { "response", "listAll" }, values = { "json", "true" })
-public interface ConfigurationApi {
-
-   /**
-    * Lists capabilities
-    * 
-    * @return current capabilities of this cloud
-    * 
-    */
-   @Named("listCapabilities")
-   @GET
-   @QueryParams(keys = "command", values = "listCapabilities")
-   @SelectJson("capability")
-   @Consumes(MediaType.APPLICATION_JSON)
-   Capabilities listCapabilities();
-   
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainAccountApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainAccountApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainAccountApi.java
deleted file mode 100644
index 161789a..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainAccountApi.java
+++ /dev/null
@@ -1,83 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.cloudstack.features;
-
-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.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.Account;
-import org.jclouds.cloudstack.domain.AsyncCreateResponse;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-import org.jclouds.rest.annotations.Unwrap;
-
-/**
- * Provides synchronous access to CloudStack Account features available to Domain
- * Admin users.
- *
- * @see <a href=
- *      "http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_Domain_Admin.html"
- *      />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface DomainAccountApi extends AccountApi {
-
-   /**
-    * Enable an account
-    *
-    * @param accountName
-    *    the account name you are enabling
-    * @param domainId
-    *    the domain ID
-    */
-   @Named("enableAccount")
-   @GET
-   @QueryParams(keys = "command", values = "enableAccount")
-   @SelectJson("account")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   Account enableAccount(@QueryParam("account") String accountName, @QueryParam("domainid") String domainId);
-
-
-   /**
-    * Disable or lock an account
-    *
-    * @param accountName
-    *    the account name you are disabling
-    * @param domainId
-    *    the domain ID
-    * @param onlyLock
-    *    only lock if true disable otherwise
-    */
-   @Named("disableAccount")
-   @GET
-   @QueryParams(keys = "command", values = "disableAccount")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   AsyncCreateResponse disableAccount(@QueryParam("account") String accountName,
-      @QueryParam("domainid") String domainId, @QueryParam("lock") boolean onlyLock);
-   
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainDomainApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainDomainApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainDomainApi.java
deleted file mode 100644
index 30c697a..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainDomainApi.java
+++ /dev/null
@@ -1,99 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.Domain;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.options.ListDomainChildrenOptions;
-import org.jclouds.cloudstack.options.ListDomainsOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.OnlyElement;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-
-/**
- * Provides synchronous access to CloudStack Domain features available to Domain
- * Admin users.
- *
- * @see <a href=
- *      "http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_Domain_Admin.html"
- *      />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface DomainDomainApi {
-
-   /**
-    * List domains with detailed information
-    *
-    * @param options
-    *          list filtering optional arguments
-    * @return
-    *          set of domain instances or empty
-    */
-   @Named("listDomains")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listDomains", "true" })
-   @SelectJson("domain")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<Domain> listDomains(ListDomainsOptions... options);
-
-   /**
-    * Get a domain by ID
-    *
-    * @param domainId
-    *          domain ID
-    * @return
-    *          domain instance or null
-    */
-   @Named("listDomains")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listDomains", "true" })
-   @SelectJson("domain")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   Domain getDomainById(@QueryParam("id") String domainId);
-
-   /**
-    * Lists all children domains belonging to a specified domain
-    *
-    * @param options
-    *          list filtering optional arguments
-    * @return
-    *          set of domain instances or empty
-    */
-   @Named("listDomainChildren")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listDomainChildren", "true" })
-   @SelectJson("domain")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<Domain> listDomainChildren(ListDomainChildrenOptions... options);
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainLimitApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainLimitApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainLimitApi.java
deleted file mode 100644
index 3957955..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainLimitApi.java
+++ /dev/null
@@ -1,56 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.cloudstack.features;
-
-import javax.inject.Named;
-import javax.ws.rs.Consumes;
-import javax.ws.rs.GET;
-import javax.ws.rs.core.MediaType;
-
-import org.jclouds.cloudstack.binders.ResourceLimitToQueryParams;
-import org.jclouds.cloudstack.domain.ResourceLimit;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.rest.annotations.BinderParam;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-
-/**
- * Provides synchronous access to CloudStack Limit features available to Domain
- * Admin users.
- * 
- * @see <a href=
- *      "http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_Domain_Admin.html"
- *      />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface DomainLimitApi extends LimitApi {
-   /**
-    * Updates resource limits for an account in a domain.
-    * 
-    * @param limit
-    *           what you are updating
-    */
-   @Named("updateResourceLimit")
-   @GET
-   @QueryParams(keys = "command", values = "updateResourceLimit")
-   @SelectJson("resourcelimit")
-   @Consumes(MediaType.APPLICATION_JSON)
-   ResourceLimit updateResourceLimit(@BinderParam(ResourceLimitToQueryParams.class) ResourceLimit limit);
-   
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainUserApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainUserApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainUserApi.java
deleted file mode 100644
index 41e39b8..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/DomainUserApi.java
+++ /dev/null
@@ -1,91 +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.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.AsyncCreateResponse;
-import org.jclouds.cloudstack.domain.User;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.options.ListUsersOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-import org.jclouds.rest.annotations.Unwrap;
-
-/**
- * Provides synchronous access to CloudStack User features available to Domain
- * Admin users.
- *
- * @see <a href=
- *      "http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_Domain_Admin.html"
- *      />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface DomainUserApi {
-
-   /**
-    * Lists Users
-    *
-    * @param options
-    *           if present, how to constrain the list.
-    * @return Users matching query, or empty set, if no Accounts are found
-    */
-   @Named("listUsers")
-   @GET
-   @QueryParams(keys = "command", values = "listUsers")
-   @SelectJson("user")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<User> listUsers(ListUsersOptions... options);
-
-   /**
-    * Enable a user with a specific ID
-    *
-    * @param userId
-    *    the user ID to enable
-    */
-   @Named("enableUser")
-   @GET
-   @QueryParams(keys = "command", values = "enableUser")
-   @SelectJson("user")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   User enableUser(@QueryParam("id") String userId);
-
-   /**
-    * Disable a user with a specific ID
-    */
-   @Named("disableUser")
-   @GET
-   @QueryParams(keys = "command", values = "disableUser")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   AsyncCreateResponse disableUser(@QueryParam("id") String userId);
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/EventApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/EventApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/EventApi.java
deleted file mode 100644
index 2ab4d73..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/EventApi.java
+++ /dev/null
@@ -1,72 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.jclouds.cloudstack.features;
-
-import java.util.Set;
-
-import javax.inject.Named;
-import javax.ws.rs.Consumes;
-import javax.ws.rs.GET;
-import javax.ws.rs.core.MediaType;
-
-import org.jclouds.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.Event;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.functions.ParseEventTypesFromHttpResponse;
-import org.jclouds.cloudstack.options.ListEventsOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.ResponseParser;
-import org.jclouds.rest.annotations.SelectJson;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- *
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = { "response", "listAll" }, values = { "json", "true" })
-public interface EventApi {
-   /**
-    * List Event Types
-    *
-    * @return event types or null if not found
-    */
-   @Named("listEventTypes")
-   @GET
-   @QueryParams(keys = "command", values = "listEventTypes")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @ResponseParser(ParseEventTypesFromHttpResponse.class)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<String> listEventTypes();
-
-   /**
-    * List Events
-    *
-    * @return event list or null if not found
-    */
-   @Named("listEventTypes")
-   @GET
-   @QueryParams(keys = "command", values = "listEvents")
-   @SelectJson("event")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<Event> listEvents(ListEventsOptions...options);
-
-}

http://git-wip-us.apache.org/repos/asf/stratos/blob/1d88fdf4/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/FirewallApi.java
----------------------------------------------------------------------
diff --git a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/FirewallApi.java b/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/FirewallApi.java
deleted file mode 100644
index 4c6ad73..0000000
--- a/dependencies/jclouds/apis/cloudstack/1.8.0-stratos/src/main/java/org/jclouds/cloudstack/features/FirewallApi.java
+++ /dev/null
@@ -1,215 +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.cloudstack.features;
-
-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.Fallbacks.EmptySetOnNotFoundOr404;
-import org.jclouds.Fallbacks.NullOnNotFoundOr404;
-import org.jclouds.Fallbacks.VoidOnNotFoundOr404;
-import org.jclouds.cloudstack.domain.AsyncCreateResponse;
-import org.jclouds.cloudstack.domain.FirewallRule;
-import org.jclouds.cloudstack.domain.PortForwardingRule;
-import org.jclouds.cloudstack.filters.AuthenticationFilter;
-import org.jclouds.cloudstack.options.CreateFirewallRuleOptions;
-import org.jclouds.cloudstack.options.ListEgressFirewallRulesOptions;
-import org.jclouds.cloudstack.options.ListFirewallRulesOptions;
-import org.jclouds.cloudstack.options.ListPortForwardingRulesOptions;
-import org.jclouds.rest.annotations.Fallback;
-import org.jclouds.rest.annotations.OnlyElement;
-import org.jclouds.rest.annotations.QueryParams;
-import org.jclouds.rest.annotations.RequestFilters;
-import org.jclouds.rest.annotations.SelectJson;
-import org.jclouds.rest.annotations.Unwrap;
-
-/**
- * Provides synchronous access to cloudstack via their REST API.
- * <p/>
- *
- * @see <a href="http://download.cloud.com/releases/2.2.0/api_2.2.12/TOC_User.html" />
- */
-@RequestFilters(AuthenticationFilter.class)
-@QueryParams(keys = "response", values = "json")
-public interface FirewallApi {
-
-   /**
-    * @see FirewallApi#listFirewallRules
-    */
-   @Named("listFirewallRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listFirewallRules", "true" })
-   @SelectJson("firewallrule")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<FirewallRule> listFirewallRules(ListFirewallRulesOptions... options);
-
-   /**
-    * @see FirewallApi#getFirewallRule
-    */
-   @Named("listFirewallRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listFirewallRules", "true" })
-   @SelectJson("firewallrule")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   FirewallRule getFirewallRule(@QueryParam("id") String id);
-
-   /**
-    * @see FirewallApi#createFirewallRuleForIpAndProtocol
-    */
-   @Named("createFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "createFirewallRule")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse createFirewallRuleForIpAndProtocol(@QueryParam("ipaddressid") String ipAddressId,
-         @QueryParam("protocol") FirewallRule.Protocol protocol, CreateFirewallRuleOptions... options);
-
-   /**
-    * @see FirewallApi#createFirewallRuleForIpProtocolAndPort
-    */
-   @Named("createFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "createFirewallRule")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse createFirewallRuleForIpProtocolAndPort(@QueryParam("ipaddressid") String ipAddressId,
-                                                                            @QueryParam("protocol") FirewallRule.Protocol protocol,
-                                                                            @QueryParam("startPort") int startPort,
-                                                                                @QueryParam("endPort") int endPort);
-                                                                            
-
-   /**
-    * @see FirewallApi#deleteFirewallRule
-    */
-   @Named("deleteFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "deleteFirewallRule")
-   @Fallback(VoidOnNotFoundOr404.class)
-   void deleteFirewallRule(@QueryParam("id") String id);
-
-   /**
-    * @see FirewallApi#listEgressFirewallRules
-    */
-   @Named("listEgressFirewallRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listEgressFirewallRules", "true" })
-   @SelectJson("firewallrule")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<FirewallRule> listEgressFirewallRules(ListEgressFirewallRulesOptions... options);
-
-   /**
-    * @see FirewallApi#getEgressFirewallRule
-    */
-   @Named("listEgressFirewallRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listEgressFirewallRules", "true" })
-   @SelectJson("firewallrule")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   FirewallRule getEgressFirewallRule(@QueryParam("id") String id);
-
-   /**
-    * @see FirewallApi#createEgressFirewallRuleForNetworkAndProtocol
-    */
-   @Named("createEgressFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "createEgressFirewallRule")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse createEgressFirewallRuleForNetworkAndProtocol(@QueryParam("networkid") String networkId,
-                                                                @QueryParam("protocol") FirewallRule.Protocol protocol,
-                                                                CreateFirewallRuleOptions... options);
-
-   /**
-    * @see FirewallApi#createEgressFirewallRuleForNetworkProtocolAndPort
-    */
-   @Named("createEgressFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "createEgressFirewallRule")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse createEgressFirewallRuleForNetworkProtocolAndPort(@QueryParam("networkId") String networkId,
-                                                                    @QueryParam("protocol") FirewallRule.Protocol protocol,
-                                                                    @QueryParam("startPort") int startPort,
-                                                                    @QueryParam("endPort") int endPort);
-
-
-   /**
-    * @see FirewallApi#deleteEgressFirewallRule
-    */
-   @Named("deleteEgressFirewallRule")
-   @GET
-   @QueryParams(keys = "command", values = "deleteEgressFirewallRule")
-   @Fallback(VoidOnNotFoundOr404.class)
-   void deleteEgressFirewallRule(@QueryParam("id") String id);
-
-   /**
-    * @see FirewallApi#listPortForwardingRules
-    */
-   @Named("listPortForwardingRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listPortForwardingRules", "true" })
-   @SelectJson("portforwardingrule")
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(EmptySetOnNotFoundOr404.class)
-   Set<PortForwardingRule> listPortForwardingRules(ListPortForwardingRulesOptions... options);
-
-   /**
-    * @see FirewallApi#getPortForwardingRule
-    */
-   @Named("listPortForwardingRules")
-   @GET
-   @QueryParams(keys = { "command", "listAll" }, values = { "listPortForwardingRules", "true" })
-   @SelectJson("portforwardingrule")
-   @OnlyElement
-   @Consumes(MediaType.APPLICATION_JSON)
-   @Fallback(NullOnNotFoundOr404.class)
-   PortForwardingRule getPortForwardingRule(@QueryParam("id") String id);
-
-   /**
-    * @see FirewallApi#createPortForwardingRuleForVirtualMachine
-    */
-   @Named("createPortForwardingRule")
-   @GET
-   @QueryParams(keys = "command", values = "createPortForwardingRule")
-   @Unwrap
-   @Consumes(MediaType.APPLICATION_JSON)
-   AsyncCreateResponse createPortForwardingRuleForVirtualMachine(
-      @QueryParam("ipaddressid") String ipAddressId, @QueryParam("protocol") PortForwardingRule.Protocol protocol,
-      @QueryParam("publicport") int publicPort, @QueryParam("virtualmachineid") String virtualMachineId,
-      @QueryParam("privateport") int privatePort);
-
-   /**
-    * @see FirewallApi#deletePortForwardingRule
-    */
-   @Named("deletePortForwardingRule")
-   @GET
-   @QueryParams(keys = "command", values = "deletePortForwardingRule")
-   @Fallback(VoidOnNotFoundOr404.class)
-   void deletePortForwardingRule(@QueryParam("id") String id);
-
-}