You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ml...@apache.org on 2014/03/10 22:37:33 UTC

[05/18] git commit: updated refs/heads/resize-root to 6d6e790

CLOUDSTACK-6147: Adding first set of test caess for Dynamic Compute Offering feature

Signed-off-by: SrikanteswaraRao Talluri <ta...@apache.org>


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

Branch: refs/heads/resize-root
Commit: 3f7b628c707cd9c30542efd670416be5fbb473f0
Parents: 3b3ae02
Author: Gaurav Aradhye <ga...@clogeny.com>
Authored: Fri Feb 28 01:46:24 2014 -0500
Committer: SrikanteswaraRao Talluri <ta...@apache.org>
Committed: Mon Mar 10 11:20:44 2014 +0530

----------------------------------------------------------------------
 .../component/test_dynamic_compute_offering.py  | 409 +++++++++++++++++++
 tools/marvin/marvin/integration/lib/base.py     |  29 +-
 tools/marvin/marvin/integration/lib/common.py   |  14 +
 3 files changed, 451 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/3f7b628c/test/integration/component/test_dynamic_compute_offering.py
----------------------------------------------------------------------
diff --git a/test/integration/component/test_dynamic_compute_offering.py b/test/integration/component/test_dynamic_compute_offering.py
new file mode 100644
index 0000000..75cf0d6
--- /dev/null
+++ b/test/integration/component/test_dynamic_compute_offering.py
@@ -0,0 +1,409 @@
+# 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.
+
+""" Tests for Dynamic Compute Offering Feature
+
+    Test Plan: https://cwiki.apache.org/confluence/display/CLOUDSTACK/Dynamic+ComputeOffering
+
+    Issue Link: https://issues.apache.org/jira/browse/CLOUDSTACK-6147
+
+    Feature Specifications: https://cwiki.apache.org/confluence/display/CLOUDSTACK/Dynamic+Compute+Offering+FS
+"""
+from marvin.cloudstackTestCase import cloudstackTestCase
+from marvin.integration.lib.utils import (cleanup_resources,
+                                          validateList)
+from marvin.integration.lib.base import (ServiceOffering,
+                                         VirtualMachine,
+                                         Account)
+from marvin.integration.lib.common import (get_domain,
+                                           get_zone,
+                                           get_template,
+                                           verifyComputeOfferingCreation)
+
+from nose.plugins.attrib import attr
+from marvin.codes import PASS, ADMIN_ACCOUNT, USER_ACCOUNT
+from ddt import ddt, data
+
+@ddt
+class TestDynamicServiceOffering(cloudstackTestCase):
+    """Test Dynamic Service Offerings
+    """
+
+    @classmethod
+    def setUpClass(cls):
+        cloudstackTestClient = super(TestDynamicServiceOffering,cls).getClsTestClient()
+        cls.api_client = cloudstackTestClient.getApiClient()
+
+        # Fill services from the external config file
+        cls.services = cloudstackTestClient.getConfigParser().parsedDict
+
+        # Get Zone, Domain and templates
+        cls.domain = get_domain(cls.api_client, cls.services)
+        cls.zone = get_zone(cls.api_client, cls.services)
+        cls.mode = str(cls.zone.networktype).lower()
+        cls.template = get_template(
+                            cls.api_client,
+                            cls.zone.id,
+                            cls.services["ostype"]
+                            )
+        cls.services["virtual_machine"]["zoneid"] = cls.zone.id
+        cls.services["virtual_machine"]["template"] = cls.template.id
+        cls._cleanup = []
+        return
+
+    @classmethod
+    def tearDownClass(cls):
+        try:
+            # Cleanup resources used
+            cleanup_resources(cls.api_client, cls._cleanup)
+        except Exception as e:
+            raise Exception("Warning: Exception during cleanup : %s" % e)
+        return
+
+    def setUp(self):
+        self.apiclient = self.testClient.getApiClient()
+        self.dbclient = self.testClient.getDbConnection()
+        self.cleanup_co = []
+        self.cleanup = []
+        return
+
+    def tearDown(self):
+        try:
+            # Clean up compute offerings
+            cleanup_resources(self.apiclient, self.cleanup)
+
+            # Clean up compute offerings
+            cleanup_resources(self.apiclient, self.cleanup_co)
+
+            self.cleanup_co[:] = []
+            self.cleanup[:] = []
+        except Exception as e:
+            raise Exception("Warning: Exception during cleanup : %s" % e)
+        return
+
+    @attr(tags=["basic","advanced"])
+    def test_create_normal_compute_offering(self):
+        """ Create normal compute offering with non zero values for cpu,
+            cpu number and memory"""
+
+        # Steps:
+        # 1. Create normal compute offering with non zero values for cpu number,
+        #    cpu speed, memory
+
+        # Validations:
+        # 1. Compute offering should be created
+
+        self.services["service_offering"]["cpunumber"] = 2
+        self.services["service_offering"]["cpuspeed"] = 256
+        self.services["service_offering"]["memory"] = 128
+
+        serviceOffering = ServiceOffering.create(self.api_client,
+                                                 self.services["service_offering"]
+                                                 )
+        self.assertEqual(verifyComputeOfferingCreation(self.apiclient, serviceOffering.id),
+                         PASS, "Compute Offering verification failed")
+
+        self.cleanup_co.append(serviceOffering)
+        return
+
+    @attr(tags=["basic","advanced"])
+    def test_create_dynamic_compute_offering(self):
+        """ Create dynamic compute offering with cpunumber, cpuspeed and memory
+            not specified"""
+
+        # Steps:
+        # 1. Create dynamic compute offering with values for cpu number,
+        #    cpu speed, memory not specified
+
+        # Validations:
+        # 1. Compute offering should be created
+
+        self.services["service_offering"]["cpunumber"] = ""
+        self.services["service_offering"]["cpuspeed"] = ""
+        self.services["service_offering"]["memory"] = ""
+
+        serviceOffering = ServiceOffering.create(self.api_client,
+                                                 self.services["service_offering"]
+                                                 )
+        self.assertEqual(verifyComputeOfferingCreation(self.apiclient, serviceOffering.id),
+                         PASS, "Compute Offering verification failed")
+
+        self.cleanup_co.append(serviceOffering)
+        return
+
+    @attr(tags=["basic","advanced"])
+    def test_create_dynamic_compute_offering_no_cpunumber(self):
+        """ Create dynamic compute offering with only cpunumber unspecified"""
+
+        # Validations:
+        # 1. Compute Offering creation should fail
+
+        self.services["service_offering"]["cpunumber"] = ""
+        self.services["service_offering"]["cpuspeed"] = 256
+        self.services["service_offering"]["memory"] = 128
+
+        try:
+            serviceOffering = ServiceOffering.create(self.api_client,
+                                                 self.services["service_offering"]
+                                                 )
+            self.cleanup_co.append(serviceOffering)
+            self.fail("Compute Offering creation succeded, it should have failed")
+        except Exception:
+            self.debug("Compute Offering Creation failed as expected")
+        return
+
+    @attr(tags=["basic","advanced"])
+    def test_create_dynamic_compute_offering_no_cpuspeed(self):
+        """ Create dynamic compute offering with only cpuspeed unspecified"""
+
+        # Validations:
+        # 1. Compute offering creation should fail
+
+        self.services["service_offering"]["cpunumber"] = 2
+        self.services["service_offering"]["cpuspeed"] = ""
+        self.services["service_offering"]["memory"] = 128
+
+        try:
+            serviceOffering = ServiceOffering.create(self.api_client,
+                                                 self.services["service_offering"]
+                                                 )
+            self.cleanup_co.append(serviceOffering)
+            self.fail("Compute Offering creation succeded, it should have failed")
+        except Exception:
+            self.debug("Compute Offering Creation failed as expected")
+        return
+
+    @attr(tags=["basic","advanced"])
+    def test_create_dynamic_compute_offering_no_memory(self):
+        """ Create dynamic compute offering with only memory unspecified"""
+
+        # Validations:
+        # 1. Compute offering creation should fail
+
+        self.services["service_offering"]["cpunumber"] = 2
+        self.services["service_offering"]["cpuspeed"] = 256
+        self.services["service_offering"]["memory"] = ""
+
+        try:
+            serviceOffering = ServiceOffering.create(self.api_client,
+                                                 self.services["service_offering"]
+                                                 )
+            self.cleanup_co.append(serviceOffering)
+            self.fail("Compute Offering creation succeded, it should have failed")
+        except Exception:
+            self.debug("Compute Offering Creation failed as expected")
+        return
+
+    @data(ADMIN_ACCOUNT, USER_ACCOUNT)
+    @attr(tags=["basic","advanced"])
+    def test_deploy_virtual_machines_static_offering(self, value):
+        """Test deploy VM with static offering"""
+
+        # Steps:
+        # 1. Create admin/user account and create its user api client
+        # 2. Create a static compute offering
+        # 3. Deploy a VM with account api client and static service offering
+        # 4. Repeat step 3 but also pass custom values for cpu number, cpu speed and memory
+        #    while deploying VM
+
+        # Validations:
+        # 1. Step 3 should succeed
+        # 2. Step 4 should fail
+
+        isadmin=True
+        if value == USER_ACCOUNT:
+            isadmin=False
+
+        # Create Account
+        self.account = Account.create(self.apiclient,self.services["account"],domainid=self.domain.id, admin=isadmin)
+        apiclient = self.testClient.createUserApiClient(
+                                    UserName=self.account.name,
+                                    DomainName=self.account.domain)
+        self.cleanup.append(self.account)
+
+        # Create service offering
+        self.services["service_offering"]["cpunumber"] = 2
+        self.services["service_offering"]["cpuspeed"] = 256
+        self.services["service_offering"]["memory"] = 128
+
+        serviceOffering = ServiceOffering.create(self.apiclient,
+                                                 self.services["service_offering"])
+
+        self.cleanup_co.append(serviceOffering)
+
+        # Deploy VM with static service offering
+        try:
+            VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                                                    serviceofferingid=serviceOffering.id,
+                                                    accountid=self.account.name,domainid=self.account.domainid)
+        except Exception as e:
+            self.fail("vm creation failed: %s" % e)
+
+        # Deploy VM with static service offering, also with custom values
+        try:
+            VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                serviceofferingid=serviceOffering.id,
+                customcpunumber=4,
+                customcpuspeed=512,
+                custommemory=256,
+                accountid=self.account.name,domainid=self.account.domainid)
+            self.fail("VM creation should have failed, it succeeded")
+        except Exception as e:
+            self.debug("vm creation failed as expected: %s" % e)
+        return
+
+    @data(ADMIN_ACCOUNT, USER_ACCOUNT)
+    @attr(tags=["basic","advanced"])
+    def test_deploy_virtual_machines_dynamic_offering(self, value):
+        """Test deploy VM with dynamic compute offering"""
+
+        # Steps:
+        # 1. Create admin/user account and create its user api client
+        # 2. Create a dynamic service offering
+        # 3. Deploy a VM with account api client and dynamic service offering
+        #    without providing custom values for cpu number, cpu speed and memory
+        # 4. Deploy a VM with account api client and dynamic service offering providing
+        #    custom values for cpu number, cpu speed and memory
+        # 5. Deploy a VM with account api client and dynamic service offering providing
+        #    custom values only for cpu number
+
+        # Validations:
+        # 1. Step 3 should fail
+        # 2. Step 4 should succeed
+        # 3. Step 5 should fail
+
+        isadmin=True
+        if value == USER_ACCOUNT:
+            isadmin=False
+
+        # Create Account and its api client
+        self.account = Account.create(self.apiclient,self.services["account"],domainid=self.domain.id, admin=isadmin)
+        apiclient = self.testClient.createUserApiClient(
+                                    UserName=self.account.name,
+                                    DomainName=self.account.domain)
+        self.cleanup.append(self.account)
+
+        # Create dynamic service offering
+        self.services["service_offering"]["cpunumber"] = ""
+        self.services["service_offering"]["cpuspeed"] = ""
+        self.services["service_offering"]["memory"] = ""
+
+        serviceOffering = ServiceOffering.create(self.apiclient,
+                                                 self.services["service_offering"])
+
+        self.cleanup_co.append(serviceOffering)
+
+        # Deploy VM with dynamic compute offering without providing custom values for
+        # cpu number, cpu speed and memory
+        try:
+            VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                                                    serviceofferingid=serviceOffering.id,
+                                                    accountid=self.account.name,domainid=self.account.domainid)
+            self.fail("VM creation succeded, it should have failed")
+        except Exception as e:
+            self.debug("vm creation failed as expected with error: %s" % e)
+
+        # Deploy VM with dynamic compute offering providing custom values for
+        # cpu number, cpu speed and memory
+        try:
+            VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                serviceofferingid=serviceOffering.id,
+                customcpunumber=2,
+                customcpuspeed=256,
+                custommemory=128,
+                accountid=self.account.name,domainid=self.account.domainid)
+        except Exception as e:
+            self.fail("vm creation failed: %s" % e)
+
+        # Deploy VM with dynamic compute offering providing custom values for only
+        # cpu number
+        try:
+            VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                serviceofferingid=serviceOffering.id,
+                customcpunumber=2,
+                accountid=self.account.name,domainid=self.account.domainid)
+            self.fail("VM deployment should have failed, it succeded")
+        except Exception as e:
+            self.debug("vm creation failed as expected: %s" % e)
+        return
+
+    @data(ADMIN_ACCOUNT, USER_ACCOUNT)
+    @attr(tags=["basic","advanced"])
+    def test_check_vm_stats(self, value):
+        """Deploy VM with dynamic service offering and check VM stats"""
+
+        # Steps:
+        # 1. Create admin/user account and create its user api client
+        # 2. Create a dynamic service offering
+        # 3. Deploy a VM with account api client and dynamic service offering
+        #    providing custom values for cpu number, cpu speed and memory
+        # 4. List the VM and verify the dynamic parameters are same as passed
+
+        isadmin=True
+        if value == USER_ACCOUNT:
+            isadmin=False
+
+        # Create Account and api client
+        self.account = Account.create(self.apiclient,self.services["account"],domainid=self.domain.id, admin=isadmin)
+        apiclient = self.testClient.createUserApiClient(
+                                    UserName=self.account.name,
+                                    DomainName=self.account.domain)
+        self.cleanup.append(self.account)
+
+        # Create dynamic compute offering
+        self.services["service_offering"]["cpunumber"] = ""
+        self.services["service_offering"]["cpuspeed"] = ""
+        self.services["service_offering"]["memory"] = ""
+
+        serviceOffering = ServiceOffering.create(self.apiclient,
+                                                 self.services["service_offering"])
+
+        self.cleanup_co.append(serviceOffering)
+
+        # Custom values
+        customcpunumber = 2
+        customcpuspeed = 256
+        custommemory = 128
+
+        # Deploy VM with dynamic service offering and the custom values
+        try:
+            virtualMachine = VirtualMachine.create(apiclient,self.services["virtual_machine"],
+                serviceofferingid=serviceOffering.id,
+                customcpunumber=customcpunumber,
+                customcpuspeed=customcpuspeed,
+                custommemory=custommemory,
+                accountid=self.account.name,domainid=self.account.domainid)
+        except Exception as e:
+            self.fail("vm creation failed: %s" % e)
+
+        vmlist = VirtualMachine.list(self.apiclient, id=virtualMachine.id)
+        self.assertEqual(validateList(vmlist)[0], PASS, "vm list validation failed")
+        vm = vmlist[0]
+
+        # Verify the custom values
+        self.assertEqual(str(vm.cpunumber), str(customcpunumber), "vm cpu number %s\
+                 not matching with provided custom cpu number %s" % \
+                 (vm.cpunumber, customcpunumber))
+
+        self.assertEqual(str(vm.cpuspeed), str(customcpuspeed), "vm cpu speed %s\
+                 not matching with provided custom cpu speed %s" % \
+                 (vm.cpuspeed, customcpuspeed))
+
+        self.assertEqual(str(vm.memory), str(custommemory), "vm memory %s\
+                 not matching with provided custom memory %s" % \
+                 (vm.memory, custommemory))
+        return

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/3f7b628c/tools/marvin/marvin/integration/lib/base.py
----------------------------------------------------------------------
diff --git a/tools/marvin/marvin/integration/lib/base.py b/tools/marvin/marvin/integration/lib/base.py
index 0a7ad94..7449d8c 100755
--- a/tools/marvin/marvin/integration/lib/base.py
+++ b/tools/marvin/marvin/integration/lib/base.py
@@ -324,7 +324,8 @@ class VirtualMachine:
                     domainid=None, zoneid=None, networkids=None, serviceofferingid=None,
                     securitygroupids=None, projectid=None, startvm=None,
                     diskofferingid=None, affinitygroupnames=None, affinitygroupids=None, group=None,
-                    hostid=None, keypair=None, ipaddress=None, mode='default', method='GET'):
+                    hostid=None, keypair=None, ipaddress=None, mode='default', method='GET',
+                    customcpunumber=None, customcpuspeed=None, custommemory=None):
         """Create the instance"""
 
         cmd = deployVirtualMachine.deployVirtualMachineCmd()
@@ -412,6 +413,17 @@ class VirtualMachine:
         if "userdata" in services:
             cmd.userdata = base64.urlsafe_b64encode(services["userdata"])
 
+        cmd.details = [{"cpuNumber": "","cpuSpeed":"","memory":""}]
+
+        if customcpunumber:
+            cmd.details[0]["cpuNumber"] = customcpunumber
+
+        if customcpuspeed:
+            cmd.details[0]["cpuSpeed"] = customcpuspeed
+
+        if custommemory:
+            cmd.details[0]["memory"] = custommemory
+
         if group:
             cmd.group = group
 
@@ -636,6 +648,21 @@ class VirtualMachine:
 
         return apiclient.updateVMAffinityGroup(cmd)
 
+    def scale(self, apiclient, serviceOfferingId,
+            customcpunumber=None, customcpuspeed=None, custommemory=None):
+        """Change service offering of the instance"""
+        cmd = scaleVirtualMachine.scaleVirtualMachineCmd()
+        cmd.id = self.id
+        cmd.serviceofferingid = serviceOfferingId
+        cmd.details = [{"cpuNumber": "","cpuSpeed":"","memory":""}]
+        if customcpunumber:
+            cmd.details[0]["cpuNumber"] = customcpunumber
+        if customcpuspeed:
+            cmd.details[0]["cpuSpeed"] = customcpuspeed
+        if custommemory:
+            cmd.details[0]["memory"] = custommemory
+        return apiclient.scaleVirtualMachine(cmd)
+
 
 class Volume:
     """Manage Volume Life cycle

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/3f7b628c/tools/marvin/marvin/integration/lib/common.py
----------------------------------------------------------------------
diff --git a/tools/marvin/marvin/integration/lib/common.py b/tools/marvin/marvin/integration/lib/common.py
index d3d634b..3b292bf 100644
--- a/tools/marvin/marvin/integration/lib/common.py
+++ b/tools/marvin/marvin/integration/lib/common.py
@@ -985,3 +985,17 @@ def verifyNetworkState(apiclient, networkid, state):
     assert validateList(networks)[0] == PASS, "Networks list validation failed, list is %s" % networks
     assert str(networks[0].state).lower() == state, "network state should be %s, it is %s" % (state, networks[0].state)
     return
+
+def verifyComputeOfferingCreation(apiclient, computeofferingid):
+    """List Compute offerings by ID and verify that the offering exists"""
+
+    cmd = listServiceOfferings.listServiceOfferingsCmd()
+    cmd.id = computeofferingid
+    serviceOfferings = None
+    try:
+        serviceOfferings = apiclient.listServiceOfferings(cmd)
+    except Exception as e:
+       return FAIL
+    if not (isinstance(serviceOfferings, list) and len(serviceOfferings) > 0):
+       return FAIL
+    return PASS