You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ah...@apache.org on 2012/08/31 01:00:41 UTC

git commit: Here's the actual object model. This will allow developers to follow how CloudStack works by following the object model

Updated Branches:
  refs/heads/javelin b9ddcf8cf -> c0ccabb5a


Here's the actual object model.  This will allow developers to follow how CloudStack works by following the object model


Project: http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/commit/c0ccabb5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/tree/c0ccabb5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/diff/c0ccabb5

Branch: refs/heads/javelin
Commit: c0ccabb5a3d1d5f0a8e18dd21727a4ff96c60558
Parents: b9ddcf8
Author: Alex Huang <al...@citrix.com>
Authored: Thu Aug 30 16:00:20 2012 -0700
Committer: Alex Huang <al...@citrix.com>
Committed: Thu Aug 30 16:00:20 2012 -0700

----------------------------------------------------------------------
 framework/ipc/.settings/org.eclipse.m2e.core.prefs |    4 +
 platform/api/.settings/org.eclipse.jdt.core.prefs  |    5 +
 platform/api/.settings/org.eclipse.m2e.core.prefs  |    4 +
 .../platform/cloud/entity/api/NetworkEntity.java   |   24 +++
 .../platform/cloud/entity/api/NicEntity.java       |   29 ++++
 .../platform/cloud/entity/api/SnapshotEntity.java  |   27 ++++
 .../platform/cloud/entity/api/TemplateEntity.java  |   27 ++++
 .../cloud/entity/api/VirtualMachineEntity.java     |  113 +++++++++++++++
 .../platform/cloud/entity/api/VolumeEntity.java    |   34 +++++
 .../platform/entity/api/CloudEntity.java           |   90 ++++++++++++
 .../exception/InsufficientCapacityException.java   |   24 +++
 .../compute/.settings/org.eclipse.jdt.core.prefs   |    5 +
 .../compute/.settings/org.eclipse.m2e.core.prefs   |    4 +
 .../storage/.settings/org.eclipse.jdt.core.prefs   |    5 +
 .../storage/.settings/org.eclipse.m2e.core.prefs   |    4 +
 .../.settings/org.eclipse.core.resources.prefs     |    2 +
 .../.settings/org.eclipse.m2e.core.prefs           |    4 +
 17 files changed, 405 insertions(+), 0 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/framework/ipc/.settings/org.eclipse.m2e.core.prefs
----------------------------------------------------------------------
diff --git a/framework/ipc/.settings/org.eclipse.m2e.core.prefs b/framework/ipc/.settings/org.eclipse.m2e.core.prefs
new file mode 100755
index 0000000..f897a7f
--- /dev/null
+++ b/framework/ipc/.settings/org.eclipse.m2e.core.prefs
@@ -0,0 +1,4 @@
+activeProfiles=
+eclipse.preferences.version=1
+resolveWorkspaceProjects=true
+version=1

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/.settings/org.eclipse.jdt.core.prefs
----------------------------------------------------------------------
diff --git a/platform/api/.settings/org.eclipse.jdt.core.prefs b/platform/api/.settings/org.eclipse.jdt.core.prefs
new file mode 100755
index 0000000..abec6ca
--- /dev/null
+++ b/platform/api/.settings/org.eclipse.jdt.core.prefs
@@ -0,0 +1,5 @@
+eclipse.preferences.version=1
+org.eclipse.jdt.core.compiler.codegen.targetPlatform=1.5
+org.eclipse.jdt.core.compiler.compliance=1.5
+org.eclipse.jdt.core.compiler.problem.forbiddenReference=warning
+org.eclipse.jdt.core.compiler.source=1.5

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/.settings/org.eclipse.m2e.core.prefs
----------------------------------------------------------------------
diff --git a/platform/api/.settings/org.eclipse.m2e.core.prefs b/platform/api/.settings/org.eclipse.m2e.core.prefs
new file mode 100755
index 0000000..f897a7f
--- /dev/null
+++ b/platform/api/.settings/org.eclipse.m2e.core.prefs
@@ -0,0 +1,4 @@
+activeProfiles=
+eclipse.preferences.version=1
+resolveWorkspaceProjects=true
+version=1

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NetworkEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NetworkEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NetworkEntity.java
new file mode 100755
index 0000000..3092905
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NetworkEntity.java
@@ -0,0 +1,24 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+public interface NetworkEntity extends CloudEntity {
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NicEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NicEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NicEntity.java
new file mode 100755
index 0000000..b710db9
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/NicEntity.java
@@ -0,0 +1,29 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+/**
+ * @author ahuang
+ *
+ */
+public interface NicEntity extends CloudEntity {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/SnapshotEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/SnapshotEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/SnapshotEntity.java
new file mode 100755
index 0000000..13bc727
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/SnapshotEntity.java
@@ -0,0 +1,27 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+import com.cloud.storage.Snapshot;
+
+public interface SnapshotEntity extends CloudEntity, Snapshot {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/TemplateEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/TemplateEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/TemplateEntity.java
new file mode 100755
index 0000000..873f125
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/TemplateEntity.java
@@ -0,0 +1,27 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+import com.cloud.template.VirtualMachineTemplate;
+
+public interface TemplateEntity extends CloudEntity, VirtualMachineTemplate {
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VirtualMachineEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VirtualMachineEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VirtualMachineEntity.java
new file mode 100755
index 0000000..75fdaee
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VirtualMachineEntity.java
@@ -0,0 +1,113 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import java.util.List;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+import com.cloud.deploy.DeployDestination;
+import com.cloud.deploy.DeploymentPlanner.ExcludeList;
+import com.cloud.vm.VirtualMachine;
+
+/**
+ * VirtualMachineEntity represents a Virtual Machine in Cloud Orchestration 
+ * Platform.  
+ *
+ */
+public interface VirtualMachineEntity extends CloudEntity, VirtualMachine {
+
+    /**
+     * @return the list of tags associated with the virtual machine
+     */
+    List<String> getTags();
+
+    /**
+     * Start the virtual machine with a given deploy destination
+     * @param dest destination to which to deploy the machine
+     * @param exclude list of areas to exclude
+     * @param plannerToUse the Deployment Planner that should be used 
+     */
+    void startIn(DeployDestination dest, ExcludeList exclude, String plannerToUse);
+
+    /**
+     * Migrate this VM to a certain destination.
+     * 
+     * @param dest
+     * @param exclude
+     * @param plannerToUse
+     */
+    void migrateTo(DeployDestination dest, ExcludeList exclude);
+
+    /**
+     * Stop the virtual machine
+     * 
+     */
+    void stop();
+
+    /**
+     * Cleans up after any botched starts.  CloudStack Orchestration Platform
+     * will attempt a best effort to actually shutdown any resource but
+     * even if it cannot, it releases the resource from its database.
+     */
+    void cleanup();
+
+    /**
+     * Destroys the VM.
+     */
+    void destroy();
+
+    /**
+     * Duplicate this VM in the database so that it will start new
+     * @param externalId
+     * @return a new VirtualMachineEntity
+     */
+    VirtualMachineEntity duplicate(String externalId);
+
+    /**
+     * Take a VM snapshot
+     */
+    void takeSnapshotOf();
+
+    /**
+     * Attach volume to this VM
+     * @param volume volume to attach
+     * @param deviceId deviceId to use
+     */
+    void attach(VolumeEntity volume, short deviceId);
+
+    /**
+     * Detach the volume from this VM
+     * @param volume volume to detach
+     */
+    void detach(VolumeEntity volume);
+
+    /**
+     * Connect the VM to a network
+     * @param network network to attach
+     * @param deviceId device id to use when a nic is created
+     */
+    void connectTo(NetworkEntity network, short deviceId);
+
+    /**
+     * Disconnect the VM from this network
+     * @param netowrk network to disconnect from
+     */
+    void disconnectFrom(NetworkEntity netowrk);
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VolumeEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VolumeEntity.java b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VolumeEntity.java
new file mode 100755
index 0000000..4ba204c
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/cloud/entity/api/VolumeEntity.java
@@ -0,0 +1,34 @@
+/*
+ * 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.apache.cloudstack.platform.cloud.entity.api;
+
+import org.apache.cloudstack.platform.entity.api.CloudEntity;
+
+import com.cloud.storage.Volume;
+
+public interface VolumeEntity extends CloudEntity, Volume {
+
+    /**
+     * Take a snapshot of the volume
+     */
+    void takeSnapshotOf();
+
+
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/entity/api/CloudEntity.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/entity/api/CloudEntity.java b/platform/api/src/org/apache/cloudstack/platform/entity/api/CloudEntity.java
new file mode 100755
index 0000000..27ff543
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/entity/api/CloudEntity.java
@@ -0,0 +1,90 @@
+/*
+ * 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.apache.cloudstack.platform.entity.api;
+
+import java.lang.reflect.Method;
+import java.util.Date;
+import java.util.List;
+import java.util.Map;
+
+/**
+ * All entities returned by the Cloud Orchestration Platform must implement
+ * this interface.  CloudValueEntity is an immutable representation of 
+ * an entity exposed by Cloud Orchestration Platform.  For each object, it
+ * defines two ids:  uuid, generated by CloudStack Orchestration Platform, and 
+ * an external id that is set by the caller when the entity is created.  All 
+ * ids must be unique for that entity.  CloudValueEntity also can be converted 
+ * to a CloudActionableEntity which contains actions the object can perform.
+ */
+public interface CloudEntity {
+    /**
+     * @return the uuid of the object.
+     */
+    String getUuid();
+
+    /**
+     * @return the id which is often the database id.
+     */
+    long getId();
+
+    /**
+     * @return external id set by the caller
+     */
+    String getExternalId();
+
+    /**
+     * @return current state for the entity
+     */
+    String getCurrentState();
+
+    /**
+     * @return desired state for the entity
+     */
+    String getDesiredState();
+
+    /**
+     * Get the time the entity was created
+     */
+    Date getCreatedTime();
+
+    /**
+     * Get the time the entity was last updated
+     */
+    Date getLastUpdatedTime();
+
+    /**
+     * @return reference to the owner of this entity
+     */
+    String getOwner();
+
+    /**
+     * @return details stored for this entity when created.
+     */
+    Map<String, String> getDetails(String source);
+
+    /**
+     * @return a list of sources that have added to the details.
+     */
+    List<String> getDetailSources();
+
+    /**
+     * @return list of actions that can be performed on the object in its current state
+     */
+    List<Method> getApplicableActions();
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/api/src/org/apache/cloudstack/platform/exception/InsufficientCapacityException.java
----------------------------------------------------------------------
diff --git a/platform/api/src/org/apache/cloudstack/platform/exception/InsufficientCapacityException.java b/platform/api/src/org/apache/cloudstack/platform/exception/InsufficientCapacityException.java
new file mode 100755
index 0000000..d2f9112
--- /dev/null
+++ b/platform/api/src/org/apache/cloudstack/platform/exception/InsufficientCapacityException.java
@@ -0,0 +1,24 @@
+/*
+ * 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.apache.cloudstack.platform.exception;
+
+public class InsufficientCapacityException {
+    
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/compute/.settings/org.eclipse.jdt.core.prefs
----------------------------------------------------------------------
diff --git a/platform/compute/.settings/org.eclipse.jdt.core.prefs b/platform/compute/.settings/org.eclipse.jdt.core.prefs
new file mode 100755
index 0000000..abec6ca
--- /dev/null
+++ b/platform/compute/.settings/org.eclipse.jdt.core.prefs
@@ -0,0 +1,5 @@
+eclipse.preferences.version=1
+org.eclipse.jdt.core.compiler.codegen.targetPlatform=1.5
+org.eclipse.jdt.core.compiler.compliance=1.5
+org.eclipse.jdt.core.compiler.problem.forbiddenReference=warning
+org.eclipse.jdt.core.compiler.source=1.5

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/compute/.settings/org.eclipse.m2e.core.prefs
----------------------------------------------------------------------
diff --git a/platform/compute/.settings/org.eclipse.m2e.core.prefs b/platform/compute/.settings/org.eclipse.m2e.core.prefs
new file mode 100755
index 0000000..f897a7f
--- /dev/null
+++ b/platform/compute/.settings/org.eclipse.m2e.core.prefs
@@ -0,0 +1,4 @@
+activeProfiles=
+eclipse.preferences.version=1
+resolveWorkspaceProjects=true
+version=1

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/storage/.settings/org.eclipse.jdt.core.prefs
----------------------------------------------------------------------
diff --git a/platform/storage/.settings/org.eclipse.jdt.core.prefs b/platform/storage/.settings/org.eclipse.jdt.core.prefs
new file mode 100755
index 0000000..abec6ca
--- /dev/null
+++ b/platform/storage/.settings/org.eclipse.jdt.core.prefs
@@ -0,0 +1,5 @@
+eclipse.preferences.version=1
+org.eclipse.jdt.core.compiler.codegen.targetPlatform=1.5
+org.eclipse.jdt.core.compiler.compliance=1.5
+org.eclipse.jdt.core.compiler.problem.forbiddenReference=warning
+org.eclipse.jdt.core.compiler.source=1.5

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/platform/storage/.settings/org.eclipse.m2e.core.prefs
----------------------------------------------------------------------
diff --git a/platform/storage/.settings/org.eclipse.m2e.core.prefs b/platform/storage/.settings/org.eclipse.m2e.core.prefs
new file mode 100755
index 0000000..f897a7f
--- /dev/null
+++ b/platform/storage/.settings/org.eclipse.m2e.core.prefs
@@ -0,0 +1,4 @@
+activeProfiles=
+eclipse.preferences.version=1
+resolveWorkspaceProjects=true
+version=1

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.core.resources.prefs
----------------------------------------------------------------------
diff --git a/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.core.resources.prefs b/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.core.resources.prefs
new file mode 100755
index 0000000..99f26c0
--- /dev/null
+++ b/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.core.resources.prefs
@@ -0,0 +1,2 @@
+eclipse.preferences.version=1
+encoding/<project>=UTF-8

http://git-wip-us.apache.org/repos/asf/incubator-cloudstack/blob/c0ccabb5/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.m2e.core.prefs
----------------------------------------------------------------------
diff --git a/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.m2e.core.prefs b/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.m2e.core.prefs
new file mode 100755
index 0000000..f897a7f
--- /dev/null
+++ b/plugins/deployment-planners/user-dispersing/.settings/org.eclipse.m2e.core.prefs
@@ -0,0 +1,4 @@
+activeProfiles=
+eclipse.preferences.version=1
+resolveWorkspaceProjects=true
+version=1