You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ro...@apache.org on 2022/08/03 10:13:54 UTC

[cloudstack] branch main updated: Fix spelling (#6597)

This is an automated email from the ASF dual-hosted git repository.

rohit pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/cloudstack.git


The following commit(s) were added to refs/heads/main by this push:
     new f9347ecf2c Fix spelling (#6597)
f9347ecf2c is described below

commit f9347ecf2cb92b940c26b64025ff58ded08bfb35
Author: John Bampton <jb...@users.noreply.github.com>
AuthorDate: Wed Aug 3 20:13:47 2022 +1000

    Fix spelling (#6597)
---
 api/src/main/java/org/apache/cloudstack/api/BaseCmd.java       |  2 +-
 .../api/command/user/snapshot/UpdateSnapshotPolicyCmd.java     |  2 +-
 .../apache/cloudstack/api/command/user/vm/RestoreVMCmd.java    |  2 +-
 .../src/main/java/com/cloud/upgrade/dao/Upgrade2214to30.java   |  2 +-
 .../src/main/java/com/cloud/upgrade/dao/Upgrade305to306.java   |  4 ++--
 .../src/main/java/com/cloud/upgrade/dao/Upgrade410to420.java   |  2 +-
 .../cloudstack/storage/endpoint/DefaultEndPointSelector.java   |  2 +-
 .../apache/cloudstack/storage/volume/VolumeServiceImpl.java    |  2 +-
 .../main/java/com/cloud/deploy/UserConcentratedPodPlanner.java |  2 +-
 .../hyperv/DotNet/ServerResource/HypervResource/Utils.cs       |  2 +-
 .../hyperv/DotNet/ServerResource/HypervResource/WmiCallsV2.cs  |  6 +++---
 .../java/com/cloud/agent/manager/MockStorageManagerImpl.java   |  6 +++---
 .../hypervisor/xenserver/resource/CitrixResourceBase.java      |  2 +-
 .../cluster/actionworkers/KubernetesClusterStartWorker.java    |  2 +-
 .../java/com/cloud/network/resource/NetscalerResource.java     |  2 +-
 .../org/apache/cloudstack/ldap/LdapManagerImplSpec.groovy      |  2 +-
 .../org/apache/cloudstack/ldap/LinkDomainToLdapCmdSpec.groovy  |  4 ++--
 .../cloudstack/api/command/LinkAccountToLdapCmdTest.java       |  2 +-
 .../apache/cloudstack/api/command/LinkDomainToLdapCmdTest.java |  2 +-
 .../org/apache/cloudstack/saml/SAML2AuthManagerImplTest.java   |  6 +++---
 scripts/storage/secondary/cloud-install-sys-tmplt              |  2 +-
 scripts/storage/secondary/setup-sysvm-tmplt                    |  2 +-
 scripts/vm/network/ovs-pvlan-kvm-vm.sh                         |  2 +-
 server/src/main/java/com/cloud/api/query/QueryManagerImpl.java |  2 +-
 .../main/java/com/cloud/api/query/dao/VolumeJoinDaoImpl.java   |  2 +-
 .../src/main/java/com/cloud/capacity/CapacityManagerImpl.java  |  2 +-
 .../java/com/cloud/configuration/ConfigurationManagerImpl.java |  2 +-
 .../java/com/cloud/deploy/DeploymentPlanningManagerImpl.java   |  4 ++--
 server/src/main/java/com/cloud/deploy/FirstFitPlanner.java     |  2 +-
 server/src/main/java/com/cloud/network/NetworkServiceImpl.java |  2 +-
 .../main/java/com/cloud/storage/StoragePoolAutomationImpl.java |  2 +-
 .../src/main/java/com/cloud/storage/VolumeApiServiceImpl.java  |  2 +-
 .../java/com/cloud/template/HypervisorTemplateAdapter.java     |  2 +-
 .../apache/cloudstack/affinity/AffinityGroupServiceImpl.java   |  2 +-
 server/src/test/java/com/cloud/vm/FirstFitPlannerTest.java     |  2 +-
 .../apache/cloudstack/storage/template/UploadManagerImpl.java  |  2 +-
 test/integration/broken/test_ps_resource_limits_volume.py      |  4 ++--
 test/integration/component/test_public_ip.py                   | 10 +++++-----
 test/integration/smoke/test_create_network.py                  |  2 +-
 test/integration/smoke/test_update_security_group.py           |  2 +-
 test/integration/testpaths/testpath_volumelifecycle.py         |  2 +-
 test/metadata/func/regression_new.xml                          |  2 +-
 test/metadata/func/vmapi.xml                                   |  4 ++--
 tools/ngui/static/js/lib/jquery-1.7.2.js                       |  2 +-
 44 files changed, 59 insertions(+), 59 deletions(-)

diff --git a/api/src/main/java/org/apache/cloudstack/api/BaseCmd.java b/api/src/main/java/org/apache/cloudstack/api/BaseCmd.java
index 4d297cffe4..c2ff5a844f 100644
--- a/api/src/main/java/org/apache/cloudstack/api/BaseCmd.java
+++ b/api/src/main/java/org/apache/cloudstack/api/BaseCmd.java
@@ -381,7 +381,7 @@ public abstract class BaseCmd {
     }
 
     /**
-     * display flag is used to control the display of the resource only to the end user. It doesnt affect Root Admin.
+     * display flag is used to control the display of the resource only to the end user. It doesn't affect Root Admin.
      * @return display flag
      */
     public boolean isDisplay(){
diff --git a/api/src/main/java/org/apache/cloudstack/api/command/user/snapshot/UpdateSnapshotPolicyCmd.java b/api/src/main/java/org/apache/cloudstack/api/command/user/snapshot/UpdateSnapshotPolicyCmd.java
index 8b62230e17..a0bf118110 100644
--- a/api/src/main/java/org/apache/cloudstack/api/command/user/snapshot/UpdateSnapshotPolicyCmd.java
+++ b/api/src/main/java/org/apache/cloudstack/api/command/user/snapshot/UpdateSnapshotPolicyCmd.java
@@ -92,7 +92,7 @@ public class UpdateSnapshotPolicyCmd extends BaseAsyncCustomIdCmd {
         }
         Volume volume = _responseGenerator.findVolumeById(policy.getVolumeId());
         if (volume == null) {
-            throw new InvalidParameterValueException("Snapshot policy's volume id doesnt exist");
+            throw new InvalidParameterValueException("Snapshot policy's volume id doesn't exist");
         }else{
             return volume.getAccountId();
         }
diff --git a/api/src/main/java/org/apache/cloudstack/api/command/user/vm/RestoreVMCmd.java b/api/src/main/java/org/apache/cloudstack/api/command/user/vm/RestoreVMCmd.java
index 18e95e9f8c..4b59bf560c 100644
--- a/api/src/main/java/org/apache/cloudstack/api/command/user/vm/RestoreVMCmd.java
+++ b/api/src/main/java/org/apache/cloudstack/api/command/user/vm/RestoreVMCmd.java
@@ -107,7 +107,7 @@ public class RestoreVMCmd extends BaseAsyncCmd implements UserCmd {
         return templateId;
     }
 
-    // TODO - Remove vmid param and make it "id" in 5.0 so that we dont have two getters
+    // TODO - Remove vmid param and make it "id" in 5.0 so that we don't have two getters
     public Long getId() {
         return getVmId();
     }
diff --git a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade2214to30.java b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade2214to30.java
index 7de60bff8d..27304953d1 100644
--- a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade2214to30.java
+++ b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade2214to30.java
@@ -286,7 +286,7 @@ public class Upgrade2214to30 extends Upgrade30xBase implements DbUpgrade {
                         pstmt3.close();
 
                         // add the reference to this physical network for the default public network entries in vlan / user_ip_address tables
-                        // add first physicalNetworkId to op_dc_vnet_alloc for this zone - just a placeholder since direct networking dont need this
+                        // add first physicalNetworkId to op_dc_vnet_alloc for this zone - just a placeholder since direct networking don't need this
                         if (isFirstPhysicalNtwk) {
                             s_logger.debug("Adding PhysicalNetwork to default Public network entries in vlan and user_ip_address");
                             pstmt3 = conn.prepareStatement("SELECT id FROM `cloud`.`networks` where traffic_type = 'Public' and data_center_id = " + zoneId);
diff --git a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade305to306.java b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade305to306.java
index 79e69e0ad5..796287697a 100644
--- a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade305to306.java
+++ b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade305to306.java
@@ -76,7 +76,7 @@ public class Upgrade305to306 extends Upgrade30xBase {
 
     private void addIndexForAlert(Connection conn) {
 
-        //First drop if it exists. (Due to patches shipped to customers some will have the index and some wont.)
+        //First drop if it exists. (Due to patches shipped to customers some will have the index and some won't.)
         List<String> indexList = new ArrayList<String>();
         s_logger.debug("Dropping index i_alert__last_sent if it exists");
         indexList.add("i_alert__last_sent");
@@ -115,7 +115,7 @@ public class Upgrade305to306 extends Upgrade30xBase {
 
     private void addIndexForHostDetails(Connection conn) {
 
-        //First drop if it exists. (Due to patches shipped to customers some will have the index and some wont.)
+        //First drop if it exists. (Due to patches shipped to customers some will have the index and some won't.)
         List<String> indexList = new ArrayList<String>();
         s_logger.debug("Dropping index fk_host_details__host_id if it exists");
         indexList.add("fk_host_details__host_id");
diff --git a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade410to420.java b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade410to420.java
index e2cfc116ac..915f22ba41 100644
--- a/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade410to420.java
+++ b/engine/schema/src/main/java/com/cloud/upgrade/dao/Upgrade410to420.java
@@ -443,7 +443,7 @@ public class Upgrade410to420 implements DbUpgrade {
     }
 
     private void addIndexForAlert(Connection conn) {
-        //First drop if it exists. (Due to patches shipped to customers some will have the index and some wont.)
+        //First drop if it exists. (Due to patches shipped to customers some will have the index and some won't.)
         List<String> indexList = new ArrayList<String>();
         s_logger.debug("Dropping index i_alert__last_sent if it exists");
         indexList.add("last_sent"); // in 4.1, we created this index that is not in convention.
diff --git a/engine/storage/src/main/java/org/apache/cloudstack/storage/endpoint/DefaultEndPointSelector.java b/engine/storage/src/main/java/org/apache/cloudstack/storage/endpoint/DefaultEndPointSelector.java
index 6a903e4235..30d24f9acc 100644
--- a/engine/storage/src/main/java/org/apache/cloudstack/storage/endpoint/DefaultEndPointSelector.java
+++ b/engine/storage/src/main/java/org/apache/cloudstack/storage/endpoint/DefaultEndPointSelector.java
@@ -388,7 +388,7 @@ public class DefaultEndPointSelector implements EndPointSelector {
             s_logger.debug("Received URISyntaxException for url" +downloadUrl);
         }
 
-        // If ssvm doesnt exist then find any ssvm in the zone.
+        // If ssvm doesn't exist then find any ssvm in the zone.
         s_logger.debug("Coudn't find ssvm for url" +downloadUrl);
         return findEndpointForImageStorage(store);
     }
diff --git a/engine/storage/volume/src/main/java/org/apache/cloudstack/storage/volume/VolumeServiceImpl.java b/engine/storage/volume/src/main/java/org/apache/cloudstack/storage/volume/VolumeServiceImpl.java
index 08b0c063b3..f74ef7a387 100644
--- a/engine/storage/volume/src/main/java/org/apache/cloudstack/storage/volume/VolumeServiceImpl.java
+++ b/engine/storage/volume/src/main/java/org/apache/cloudstack/storage/volume/VolumeServiceImpl.java
@@ -357,7 +357,7 @@ public class VolumeServiceImpl implements VolumeService {
         VolumeDataStoreVO volumeStore = _volumeStoreDao.findByVolume(volume.getId());
         if (volumeStore != null) {
             if (volumeStore.getDownloadState() == VMTemplateStorageResourceAssoc.Status.DOWNLOAD_IN_PROGRESS) {
-                String msg = "Volume: " + volume.getName() + " is currently being uploaded; cant' delete it.";
+                String msg = "Volume: " + volume.getName() + " is currently being uploaded; can't delete it.";
                 s_logger.debug(msg);
                 result.setSuccess(false);
                 result.setResult(msg);
diff --git a/plugins/deployment-planners/user-concentrated-pod/src/main/java/com/cloud/deploy/UserConcentratedPodPlanner.java b/plugins/deployment-planners/user-concentrated-pod/src/main/java/com/cloud/deploy/UserConcentratedPodPlanner.java
index d39e4db645..bc56740eec 100644
--- a/plugins/deployment-planners/user-concentrated-pod/src/main/java/com/cloud/deploy/UserConcentratedPodPlanner.java
+++ b/plugins/deployment-planners/user-concentrated-pod/src/main/java/com/cloud/deploy/UserConcentratedPodPlanner.java
@@ -127,7 +127,7 @@ public class UserConcentratedPodPlanner extends FirstFitPlanner implements Deplo
         //UserConcentratedPod strategy
         List<Long> podIds = listPodsByUserConcentration(plan.getDataCenterId(), accountId);
         if (!podIds.isEmpty()) {
-            //remove pods that dont have capacity for this vm
+            //remove pods that don't have capacity for this vm
             podIds.retainAll(podIdsByCapacity);
             podIdsByCapacity.removeAll(podIds);
             podIds.addAll(podIdsByCapacity);
diff --git a/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/Utils.cs b/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/Utils.cs
index 5c57239a4f..1751f31af8 100644
--- a/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/Utils.cs
+++ b/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/Utils.cs
@@ -91,7 +91,7 @@ namespace HypervResource
                 dest = Utils.NormalizePath(dest);
             }
             // if the filePathRelativeToShare string don't have filename and only a dir point then find the vhd files in that folder and use
-            // In the clean setup, first copy command wont be having the filename it contains onlyu dir path.
+            // In the clean setup, first copy command won't be having the filename it contains onlyu dir path.
             // we need to scan the folder point and then copy the file to destination.
             else if (!filePathRelativeToShare.EndsWith(".vhd") || !filePathRelativeToShare.EndsWith(".vhdx"))
             {
diff --git a/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/WmiCallsV2.cs b/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/WmiCallsV2.cs
index a83b6df09c..6272c4eb1c 100644
--- a/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/WmiCallsV2.cs
+++ b/plugins/hypervisors/hyperv/DotNet/ServerResource/HypervResource/WmiCallsV2.cs
@@ -955,7 +955,7 @@ namespace HypervResource
 
             if (vlanSettings == null)
             {
-                // when modifying  nic to not connected dont create vlan
+                // when modifying  nic to not connected don't create vlan
                 if (enable)
                 {
                     if (vlanid != null)
@@ -1024,7 +1024,7 @@ namespace HypervResource
                 index++;
             }
 
-            //TODO: make sure the index wont be out of range.
+            //TODO: make sure the index won't be out of range.
 
             EthernetPortAllocationSettingData[] ethernetConnections = GetEthernetConnections(vm);
             EthernetSwitchPortVlanSettingData vlanSettings = GetVlanSettings(ethernetConnections[index]);
@@ -1119,7 +1119,7 @@ namespace HypervResource
 
             if (vlanSettings == null)
             {
-                // when modifying  nic to not connected dont create vlan
+                // when modifying  nic to not connected don't create vlan
                 if (enable)
                 {
                     if (vlanid != null)
diff --git a/plugins/hypervisors/simulator/src/main/java/com/cloud/agent/manager/MockStorageManagerImpl.java b/plugins/hypervisors/simulator/src/main/java/com/cloud/agent/manager/MockStorageManagerImpl.java
index efa9510a8e..27b4a716af 100644
--- a/plugins/hypervisors/simulator/src/main/java/com/cloud/agent/manager/MockStorageManagerImpl.java
+++ b/plugins/hypervisors/simulator/src/main/java/com/cloud/agent/manager/MockStorageManagerImpl.java
@@ -1086,7 +1086,7 @@ public class MockStorageManagerImpl extends ManagerBase implements MockStorageMa
             txn.start();
             MockVolumeVO volume = _mockVolumeDao.findByName(cmd.getTemplatePath());
             if (volume == null) {
-                return new Answer(cmd, false, "cant' find volume:" + cmd.getTemplatePath());
+                return new Answer(cmd, false, "can't find volume:" + cmd.getTemplatePath());
             }
             String md5 = null;
             try {
@@ -1113,7 +1113,7 @@ public class MockStorageManagerImpl extends ManagerBase implements MockStorageMa
             txn.start();
             volume = _mockVolumeDao.findByStoragePathAndType(cmd.getVolumePath());
             if (volume == null) {
-                return new CreatePrivateTemplateAnswer(cmd, false, "cant' find volume" + cmd.getVolumePath());
+                return new CreatePrivateTemplateAnswer(cmd, false, "can't find volume" + cmd.getVolumePath());
             }
 
             sec = _mockSecStorageDao.findByUrl(cmd.getSecondaryStorageUrl());
@@ -1200,7 +1200,7 @@ public class MockStorageManagerImpl extends ManagerBase implements MockStorageMa
             txn.start();
             volume = _mockVolumeDao.findByStoragePathAndType(cmd.getVolumePath());
             if (volume == null) {
-                return new CopyVolumeAnswer(cmd, false, "cant' find volume" + cmd.getVolumePath(), null, null);
+                return new CopyVolumeAnswer(cmd, false, "can't find volume" + cmd.getVolumePath(), null, null);
             }
             txn.commit();
         } catch (Exception ex) {
diff --git a/plugins/hypervisors/xenserver/src/main/java/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java b/plugins/hypervisors/xenserver/src/main/java/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
index 7462761cd0..49af92cd51 100644
--- a/plugins/hypervisors/xenserver/src/main/java/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
+++ b/plugins/hypervisors/xenserver/src/main/java/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
@@ -3163,7 +3163,7 @@ public abstract class CitrixResourceBase extends ServerResourceBase implements S
         // stability
         if (dynamicMaxRam > staticMax) { // XS contraint that dynamic max <=
             // static max
-            s_logger.warn("dynamic max " + toHumanReadableSize(dynamicMaxRam) + " cant be greater than static max " + toHumanReadableSize(staticMax) + ", this can lead to stability issues. Setting static max as much as dynamic max ");
+            s_logger.warn("dynamic max " + toHumanReadableSize(dynamicMaxRam) + " can't be greater than static max " + toHumanReadableSize(staticMax) + ", this can lead to stability issues. Setting static max as much as dynamic max ");
             return dynamicMaxRam;
         }
         return staticMax;
diff --git a/plugins/integrations/kubernetes-service/src/main/java/com/cloud/kubernetes/cluster/actionworkers/KubernetesClusterStartWorker.java b/plugins/integrations/kubernetes-service/src/main/java/com/cloud/kubernetes/cluster/actionworkers/KubernetesClusterStartWorker.java
index 6612a76083..5cb9c08a20 100644
--- a/plugins/integrations/kubernetes-service/src/main/java/com/cloud/kubernetes/cluster/actionworkers/KubernetesClusterStartWorker.java
+++ b/plugins/integrations/kubernetes-service/src/main/java/com/cloud/kubernetes/cluster/actionworkers/KubernetesClusterStartWorker.java
@@ -476,7 +476,7 @@ public class KubernetesClusterStartWorker extends KubernetesClusterResourceModif
                 startKubernetesVM(vm);
             } catch (ManagementServerException ex) {
                 LOGGER.warn(String.format("Failed to start VM : %s in Kubernetes cluster : %s due to ", vm.getDisplayName(), kubernetesCluster.getName()) + ex);
-                // dont bail out here. proceed further to stop the reset of the VM's
+                // don't bail out here. proceed further to stop the reset of the VM's
             }
         }
         for (final UserVm userVm : clusterVms) {
diff --git a/plugins/network-elements/netscaler/src/main/java/com/cloud/network/resource/NetscalerResource.java b/plugins/network-elements/netscaler/src/main/java/com/cloud/network/resource/NetscalerResource.java
index ac9b0c6b99..506fc282fe 100644
--- a/plugins/network-elements/netscaler/src/main/java/com/cloud/network/resource/NetscalerResource.java
+++ b/plugins/network-elements/netscaler/src/main/java/com/cloud/network/resource/NetscalerResource.java
@@ -3616,7 +3616,7 @@ public class NetscalerResource implements ServerResource {
 
     private String generateAutoScaleServiceGroupName(final LoadBalancerTO lbTO) {
         /*
-         *  ServiceGroup name in NetScaler wont support long names. Providing special name.
+         *  ServiceGroup name in NetScaler won't support long names. Providing special name.
          *  Need for introducing uuid because every vmgroup creation should be distinguished.
          *  Ex. (1) create a vm group, delete a vmgroup, create a vmgroup on same lb ip and port
          *  This will reuse all vms from the original vm group in step (1)
diff --git a/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LdapManagerImplSpec.groovy b/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LdapManagerImplSpec.groovy
index 2cdac7d1bf..6f4c9cdb30 100644
--- a/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LdapManagerImplSpec.groovy
+++ b/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LdapManagerImplSpec.groovy
@@ -533,7 +533,7 @@ class LdapManagerImplSpec extends spock.lang.Specification {
             user.isDisabled() == true
     }
 
-    def "test getUser(username,type,group) when username doesnt exist in ldap"(){
+    def "test getUser(username,type,group) when username doesn't exist in ldap"(){
         def ldapUserManager = Mock(LdapUserManager)
         def ldapUserManagerFactory = Mock(LdapUserManagerFactory)
         ldapUserManagerFactory.getInstance(_) >> ldapUserManager
diff --git a/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LinkDomainToLdapCmdSpec.groovy b/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LinkDomainToLdapCmdSpec.groovy
index 2be7d3c3df..257cf7b26f 100644
--- a/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LinkDomainToLdapCmdSpec.groovy
+++ b/plugins/user-authenticators/ldap/src/test/groovy/org/apache/cloudstack/ldap/LinkDomainToLdapCmdSpec.groovy
@@ -128,7 +128,7 @@ class LinkDomainToLdapCmdSpec extends Specification {
         result.getAdminId() == null
     }
 
-    def "test with valid params and with admin who doesnt exist in cloudstack"() {
+    def "test with valid params and with admin who doesn't exist in cloudstack"() {
         def domainId = 1L;
         def type = "GROUP";
         def name = "CN=test,DC=ccp,DC=Citrix,DC=com"
@@ -163,7 +163,7 @@ class LinkDomainToLdapCmdSpec extends Specification {
         result.getAdminId() == String.valueOf(accountId)
     }
 
-    def "test when admin doesnt exist in ldap"() {
+    def "test when admin doesn't exist in ldap"() {
         def domainId = 1L;
         def type = "GROUP";
         def name = "CN=test,DC=ccp,DC=Citrix,DC=com"
diff --git a/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkAccountToLdapCmdTest.java b/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkAccountToLdapCmdTest.java
index 7386ec9f9d..a200dd82bb 100644
--- a/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkAccountToLdapCmdTest.java
+++ b/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkAccountToLdapCmdTest.java
@@ -56,7 +56,7 @@ public class LinkAccountToLdapCmdTest implements LdapConfigurationChanger {
 
     @Test
     public void execute() throws Exception {
-        //      test with valid params and with admin who doesnt exist in cloudstack
+        //      test with valid params and with admin who doesn't exist in cloudstack
         long domainId = 1;
         String type = "GROUP";
         String ldapDomain = "CN=test,DC=ccp,DC=Citrix,DC=com";
diff --git a/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkDomainToLdapCmdTest.java b/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkDomainToLdapCmdTest.java
index 24ee930dc6..04594e2cec 100644
--- a/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkDomainToLdapCmdTest.java
+++ b/plugins/user-authenticators/ldap/src/test/java/org/apache/cloudstack/api/command/LinkDomainToLdapCmdTest.java
@@ -60,7 +60,7 @@ public class LinkDomainToLdapCmdTest implements LdapConfigurationChanger
 
     @Test
     public void execute() throws Exception {
-//      test with valid params and with admin who doesnt exist in cloudstack
+//      test with valid params and with admin who doesn't exist in cloudstack
         Long domainId = 1L;
         String type = "GROUP";
         String ldapDomain = "CN=test,DC=ccp,DC=Citrix,DC=com";
diff --git a/plugins/user-authenticators/saml2/src/test/java/org/apache/cloudstack/saml/SAML2AuthManagerImplTest.java b/plugins/user-authenticators/saml2/src/test/java/org/apache/cloudstack/saml/SAML2AuthManagerImplTest.java
index 8e811d0c5b..073face6e2 100755
--- a/plugins/user-authenticators/saml2/src/test/java/org/apache/cloudstack/saml/SAML2AuthManagerImplTest.java
+++ b/plugins/user-authenticators/saml2/src/test/java/org/apache/cloudstack/saml/SAML2AuthManagerImplTest.java
@@ -61,15 +61,15 @@ public class SAML2AuthManagerImplTest {
     public void testStart() {
         when(saml2AuthManager.getSAMLIdentityProviderMetadataURL()).thenReturn("file://does/not/exist");
         boolean started = saml2AuthManager.start();
-        assertFalse("saml2authmanager should not start as the file doesnt exist", started);
+        assertFalse("saml2authmanager should not start as the file doesn't exist", started);
 
         when(saml2AuthManager.getSAMLIdentityProviderMetadataURL()).thenReturn(" ");
         started = saml2AuthManager.start();
-        assertFalse("saml2authmanager should not start as the file doesnt exist", started);
+        assertFalse("saml2authmanager should not start as the file doesn't exist", started);
 
         when(saml2AuthManager.getSAMLIdentityProviderMetadataURL()).thenReturn("");
         started = saml2AuthManager.start();
-        assertFalse("saml2authmanager should not start as the file doesnt exist", started);
+        assertFalse("saml2authmanager should not start as the file doesn't exist", started);
 
     }
 }
diff --git a/scripts/storage/secondary/cloud-install-sys-tmplt b/scripts/storage/secondary/cloud-install-sys-tmplt
index cc4435475d..7ff05b1161 100755
--- a/scripts/storage/secondary/cloud-install-sys-tmplt
+++ b/scripts/storage/secondary/cloud-install-sys-tmplt
@@ -29,7 +29,7 @@ failed() {
   local returnval=$1
   local returnmsg=$2
   
-  # check for an message, if there is no one dont print anything
+  # check for an message, if there is no one don't print anything
   if [[ -z $returnmsg ]]; then
     :
   else
diff --git a/scripts/storage/secondary/setup-sysvm-tmplt b/scripts/storage/secondary/setup-sysvm-tmplt
index 89195e406e..905d0d54cc 100755
--- a/scripts/storage/secondary/setup-sysvm-tmplt
+++ b/scripts/storage/secondary/setup-sysvm-tmplt
@@ -24,7 +24,7 @@ failed() {
   local returnval=$1
   local returnmsg=$2
 
-  # check for an message, if there is no one dont print anything
+  # check for an message, if there is no one don't print anything
   if [[ -z $returnmsg ]]; then
     :
   else
diff --git a/scripts/vm/network/ovs-pvlan-kvm-vm.sh b/scripts/vm/network/ovs-pvlan-kvm-vm.sh
index 7b4e2740f3..3b79d6733e 100644
--- a/scripts/vm/network/ovs-pvlan-kvm-vm.sh
+++ b/scripts/vm/network/ovs-pvlan-kvm-vm.sh
@@ -119,7 +119,7 @@ vm_port=$(find_port $vm_mac)
 pri_vlan_header=$((4096 + $pri_vlan))
 sec_vlan_header=$((4096 + $sec_vlan))
 
-# Get the groups for broadcast. Ensure we end the group id with ',' so that we wont accidentally match groupid 111 with 1110.
+# Get the groups for broadcast. Ensure we end the group id with ',' so that we won't accidentally match groupid 111 with 1110.
 # We're using the header value for the pri vlan port group, as anything from a promiscuous device has to go to every device in the vlan.
 # Since we're creating a separate group for just the promiscuous devices, adding 4096 so that it'll be unique. Hence we're restricted to 4096 vlans!
 # Not a big deal because if you have vxlan, why do you even need pvlan!!
diff --git a/server/src/main/java/com/cloud/api/query/QueryManagerImpl.java b/server/src/main/java/com/cloud/api/query/QueryManagerImpl.java
index 19997cc576..67666bef33 100644
--- a/server/src/main/java/com/cloud/api/query/QueryManagerImpl.java
+++ b/server/src/main/java/com/cloud/api/query/QueryManagerImpl.java
@@ -4294,7 +4294,7 @@ public class QueryManagerImpl extends MutualExclusiveIdsManagerBase implements Q
         String value = cmd.getValue();
         Long resourceId = null;
 
-        //Validation - 1.1 - resourceId and value cant be null.
+        //Validation - 1.1 - resourceId and value can't be null.
         if (resourceIdStr == null && value == null) {
             throw new InvalidParameterValueException("Insufficient parameters passed for listing by resourceId OR key,value pair. Please check your params and try again.");
         }
diff --git a/server/src/main/java/com/cloud/api/query/dao/VolumeJoinDaoImpl.java b/server/src/main/java/com/cloud/api/query/dao/VolumeJoinDaoImpl.java
index 656e82e672..3aa4aff231 100644
--- a/server/src/main/java/com/cloud/api/query/dao/VolumeJoinDaoImpl.java
+++ b/server/src/main/java/com/cloud/api/query/dao/VolumeJoinDaoImpl.java
@@ -230,7 +230,7 @@ public class VolumeJoinDaoImpl extends GenericDaoBaseWithTagInformation<VolumeJo
         volResponse.setAttached(volume.getAttached());
         volResponse.setDestroyed(volume.getState() == Volume.State.Destroy);
         boolean isExtractable = true;
-        if (volume.getVolumeType() != Volume.Type.DATADISK) { // Datadisk dont
+        if (volume.getVolumeType() != Volume.Type.DATADISK) { // Datadisk don't
             // have any
             // template
             // dependence.
diff --git a/server/src/main/java/com/cloud/capacity/CapacityManagerImpl.java b/server/src/main/java/com/cloud/capacity/CapacityManagerImpl.java
index 726161740c..9c5f3e0fd3 100644
--- a/server/src/main/java/com/cloud/capacity/CapacityManagerImpl.java
+++ b/server/src/main/java/com/cloud/capacity/CapacityManagerImpl.java
@@ -357,7 +357,7 @@ public class CapacityManagerImpl extends ManagerBase implements CapacityManager,
                         /* alloc from free resource */
                         if (!((reservedCpu + usedCpu + cpu <= totalCpu) && (reservedMem + usedMem + ram <= totalMem))) {
                             if (s_logger.isDebugEnabled()) {
-                                s_logger.debug("Host doesnt seem to have enough free capacity, but increasing the used capacity anyways, " +
+                                s_logger.debug("Host doesn't seem to have enough free capacity, but increasing the used capacity anyways, " +
                                     "since the VM is already starting on this host ");
                             }
                         }
diff --git a/server/src/main/java/com/cloud/configuration/ConfigurationManagerImpl.java b/server/src/main/java/com/cloud/configuration/ConfigurationManagerImpl.java
index 7f6126c349..b297c76046 100755
--- a/server/src/main/java/com/cloud/configuration/ConfigurationManagerImpl.java
+++ b/server/src/main/java/com/cloud/configuration/ConfigurationManagerImpl.java
@@ -459,7 +459,7 @@ public class ConfigurationManagerImpl extends ManagerBase implements Configurati
     public final static ConfigKey<Long> IOPS_MAX_WRITE_LENGTH = new ConfigKey<Long>(Long.class, "vm.disk.iops.maximum.write.length", "Advanced", "0",
             "Maximum IOPS write burst duration (seconds). If '0' (zero) then does not check for maximum burst length.", true, ConfigKey.Scope.Global, null);
     public static final ConfigKey<Boolean> ADD_HOST_ON_SERVICE_RESTART_KVM = new ConfigKey<Boolean>(Boolean.class, "add.host.on.service.restart.kvm", "Advanced", "true",
-            "Indicates whether the host will be added back to cloudstack after restarting agent service on host. If false it wont be added back even after service restart",
+            "Indicates whether the host will be added back to cloudstack after restarting agent service on host. If false it won't be added back even after service restart",
             true, ConfigKey.Scope.Global, null);
     public static final ConfigKey<Boolean> SET_HOST_DOWN_TO_MAINTENANCE = new ConfigKey<Boolean>(Boolean.class, "set.host.down.to.maintenance", "Advanced", "false",
                         "Indicates whether the host in down state can be put into maintenance state so thats its not enabled after it comes back.",
diff --git a/server/src/main/java/com/cloud/deploy/DeploymentPlanningManagerImpl.java b/server/src/main/java/com/cloud/deploy/DeploymentPlanningManagerImpl.java
index 1c3c59bcf3..dda96592b2 100644
--- a/server/src/main/java/com/cloud/deploy/DeploymentPlanningManagerImpl.java
+++ b/server/src/main/java/com/cloud/deploy/DeploymentPlanningManagerImpl.java
@@ -1647,7 +1647,7 @@ StateListener<State, VirtualMachine.Event, VirtualMachine>, Configurable {
                     // this volume since allocation_state is disabled.
                     // - remove any suitable pools found for other volumes.
                     // All volumes should get suitable pools under this cluster;
-                    // else we cant use this cluster.
+                    // else we can't use this cluster.
                     suitableVolumeStoragePools.clear();
                     break;
                 }
@@ -1698,7 +1698,7 @@ StateListener<State, VirtualMachine.Event, VirtualMachine>, Configurable {
                 // No suitable storage pools found under this cluster for this
                 // volume. - remove any suitable pools found for other volumes.
                 // All volumes should get suitable pools under this cluster;
-                // else we cant use this cluster.
+                // else we can't use this cluster.
                 suitableVolumeStoragePools.clear();
                 break;
             }
diff --git a/server/src/main/java/com/cloud/deploy/FirstFitPlanner.java b/server/src/main/java/com/cloud/deploy/FirstFitPlanner.java
index 7dc2a50382..695521e527 100644
--- a/server/src/main/java/com/cloud/deploy/FirstFitPlanner.java
+++ b/server/src/main/java/com/cloud/deploy/FirstFitPlanner.java
@@ -297,7 +297,7 @@ public class FirstFitPlanner extends AdapterBase implements DeploymentClusterPla
     }
 
     private Map<Short, Float> getCapacityThresholdMap() {
-        // Lets build this real time so that the admin wont have to restart MS
+        // Lets build this real time so that the admin won't have to restart MS
         // if anyone changes these values
         Map<Short, Float> disableThresholdMap = new HashMap<Short, Float>();
 
diff --git a/server/src/main/java/com/cloud/network/NetworkServiceImpl.java b/server/src/main/java/com/cloud/network/NetworkServiceImpl.java
index a3a3e4d970..795489c696 100644
--- a/server/src/main/java/com/cloud/network/NetworkServiceImpl.java
+++ b/server/src/main/java/com/cloud/network/NetworkServiceImpl.java
@@ -4588,7 +4588,7 @@ public class NetworkServiceImpl extends ManagerBase implements NetworkService, C
         }
         // For Storage, Control, Management, Public check if the zone has any other physical network with this
         // traffictype already present
-        // If yes, we cant add these traffics to one more physical network in the zone.
+        // If yes, we can't add these traffics to one more physical network in the zone.
 
         if (TrafficType.isSystemNetwork(trafficType) || TrafficType.Public.equals(trafficType) || TrafficType.Storage.equals(trafficType)) {
             if (!_physicalNetworkDao.listByZoneAndTrafficType(network.getDataCenterId(), trafficType).isEmpty()) {
diff --git a/server/src/main/java/com/cloud/storage/StoragePoolAutomationImpl.java b/server/src/main/java/com/cloud/storage/StoragePoolAutomationImpl.java
index 772b947128..7b5ebc455c 100644
--- a/server/src/main/java/com/cloud/storage/StoragePoolAutomationImpl.java
+++ b/server/src/main/java/com/cloud/storage/StoragePoolAutomationImpl.java
@@ -173,7 +173,7 @@ public class StoragePoolAutomationImpl implements StoragePoolAutomation {
             }
             // check to see if other ps exist
             // if they do, then we can migrate over the system vms to them
-            // if they dont, then just stop all vms on this one
+            // if they don't, then just stop all vms on this one
             List<StoragePoolVO> upPools = primaryDataStoreDao.listByStatusInZone(pool.getDataCenterId(), StoragePoolStatus.Up);
             boolean restart = true;
             if (upPools == null || upPools.size() == 0) {
diff --git a/server/src/main/java/com/cloud/storage/VolumeApiServiceImpl.java b/server/src/main/java/com/cloud/storage/VolumeApiServiceImpl.java
index ea10043e41..4b5e263494 100644
--- a/server/src/main/java/com/cloud/storage/VolumeApiServiceImpl.java
+++ b/server/src/main/java/com/cloud/storage/VolumeApiServiceImpl.java
@@ -3527,7 +3527,7 @@ public class VolumeApiServiceImpl extends ManagerBase implements VolumeApiServic
         }
 
         if (volume.getVolumeType() != Volume.Type.DATADISK) {
-            // Datadisk dont have any template dependence.
+            // Datadisk don't have any template dependence.
 
             VMTemplateVO template = ApiDBUtils.findTemplateById(volume.getTemplateId());
             if (template != null) { // For ISO based volumes template = null and
diff --git a/server/src/main/java/com/cloud/template/HypervisorTemplateAdapter.java b/server/src/main/java/com/cloud/template/HypervisorTemplateAdapter.java
index b7e449dcd7..1ca9ca7303 100644
--- a/server/src/main/java/com/cloud/template/HypervisorTemplateAdapter.java
+++ b/server/src/main/java/com/cloud/template/HypervisorTemplateAdapter.java
@@ -528,7 +528,7 @@ public class HypervisorTemplateAdapter extends TemplateAdapterBase {
                 for (TemplateDataStoreVO templateStore : templateStores) {
                     if (templateStore.getDownloadState() == Status.DOWNLOAD_IN_PROGRESS) {
                         String errorMsg = "Please specify a template that is not currently being downloaded.";
-                        s_logger.debug("Template: " + template.getName() + " is currently being downloaded to secondary storage host: " + store.getName() + "; cant' delete it.");
+                        s_logger.debug("Template: " + template.getName() + " is currently being downloaded to secondary storage host: " + store.getName() + "; can't delete it.");
                         throw new CloudRuntimeException(errorMsg);
                     }
                 }
diff --git a/server/src/main/java/org/apache/cloudstack/affinity/AffinityGroupServiceImpl.java b/server/src/main/java/org/apache/cloudstack/affinity/AffinityGroupServiceImpl.java
index db16f7372f..076740965c 100644
--- a/server/src/main/java/org/apache/cloudstack/affinity/AffinityGroupServiceImpl.java
+++ b/server/src/main/java/org/apache/cloudstack/affinity/AffinityGroupServiceImpl.java
@@ -341,7 +341,7 @@ public class AffinityGroupServiceImpl extends ManagerBase implements AffinityGro
 
         for (AffinityGroupProcessor processor : _affinityProcessors) {
             if (processor.isAdminControlledGroup()) {
-                continue; // we dont list the type if this group can be
+                continue; // we don't list the type if this group can be
                 // created only as an admin/system operation.
             }
             types.add(processor.getType());
diff --git a/server/src/test/java/com/cloud/vm/FirstFitPlannerTest.java b/server/src/test/java/com/cloud/vm/FirstFitPlannerTest.java
index f70f9b88d4..bb6487fb11 100644
--- a/server/src/test/java/com/cloud/vm/FirstFitPlannerTest.java
+++ b/server/src/test/java/com/cloud/vm/FirstFitPlannerTest.java
@@ -209,7 +209,7 @@ public class FirstFitPlannerTest {
         List<Long> clusterList = planner.orderClusters(vmProfile, plan, avoids);
 
         assertTrue("Reordered cluster list have clusters which has hosts with specified host tag on offering", (clusterList.containsAll(matchingClusters)));
-        assertTrue("Reordered cluster list does not have clusters which dont have hosts with matching host tag on offering", (!clusterList.contains(2L)));
+        assertTrue("Reordered cluster list does not have clusters which don't have hosts with matching host tag on offering", (!clusterList.contains(2L)));
     }
 
     private List<Long> initializeForClusterListBasedOnHostTag(ServiceOffering offering) {
diff --git a/services/secondary-storage/server/src/main/java/org/apache/cloudstack/storage/template/UploadManagerImpl.java b/services/secondary-storage/server/src/main/java/org/apache/cloudstack/storage/template/UploadManagerImpl.java
index cdda8161ba..8e3f0b211f 100644
--- a/services/secondary-storage/server/src/main/java/org/apache/cloudstack/storage/template/UploadManagerImpl.java
+++ b/services/secondary-storage/server/src/main/java/org/apache/cloudstack/storage/template/UploadManagerImpl.java
@@ -314,7 +314,7 @@ public class UploadManagerImpl extends ManagerBase implements UploadManager {
             command.add("unlink /var/www/html/userdata/" + extractUrl.substring(extractUrl.lastIndexOf(File.separator) + 1));
             result = command.execute();
             if (result != null) {
-                // FIXME - Ideally should bail out if you cant delete symlink. Not doing it right now.
+                // FIXME - Ideally should bail out if you can't delete symlink. Not doing it right now.
                 // This is because the ssvm might already be destroyed and the symlinks do not exist.
                 s_logger.warn("Error in deleting symlink :" + result);
             }
diff --git a/test/integration/broken/test_ps_resource_limits_volume.py b/test/integration/broken/test_ps_resource_limits_volume.py
index 753f3f165c..c07487bc27 100644
--- a/test/integration/broken/test_ps_resource_limits_volume.py
+++ b/test/integration/broken/test_ps_resource_limits_volume.py
@@ -124,9 +124,9 @@ class TestPrimaryResourceLimitsVolume(cloudstackTestCase):
         # 1. create a normal user account and update primary store limits to the current resource count
         # 2. Upload a volume of any size
         # 3. Verify that upload volume succeeds
-        # 4. Verify that primary storage count doesnt change
+        # 4. Verify that primary storage count doesn't change
         # 6. Try attaching volume to VM and verify that the attach fails (as the resource limits exceed)
-        # 7. Verify that primary storage count doesnt change
+        # 7. Verify that primary storage count doesn't change
         # done
         """
         # create an account, launch a vm with default template and custom disk offering, update the primary store limits to the current primary store resource count
diff --git a/test/integration/component/test_public_ip.py b/test/integration/component/test_public_ip.py
index 242b1cf188..d8241a7edf 100644
--- a/test/integration/component/test_public_ip.py
+++ b/test/integration/component/test_public_ip.py
@@ -362,7 +362,7 @@ class TestPublicIp(cloudstackTestCase):
         Step 7: Try to display public ip address from shared networks
         Step 8: It should not return any result
         Step 9: Try to display ip address of domain1 from domain2
-        Step 10: Ensure that it doesnt not return any result
+        Step 10: Ensure that it doesn't not return any result
         :return:
         """
         # Step 1. Create isolated network
@@ -467,7 +467,7 @@ class TestPublicIp(cloudstackTestCase):
             # Step 10
             self.fail("Domain should not access public ip of sibling domain")
         except Exception as e:
-            self.info("Got exception as expected since domain2 cant access network of domain1")
+            self.info("Got exception as expected since domain2 can't access network of domain1")
 
     @attr(tags=["advanced", "basic", "sg"], required_hardware="false")
     def test_03_list_publicip_user_domain(self):
@@ -604,7 +604,7 @@ class TestPublicIp(cloudstackTestCase):
             # Step 14
             self.fail("Domain should not access public ip of sibling domain")
         except Exception as e:
-            self.info("Got exception as expected since domain2 cant access network of domain1")
+            self.info("Got exception as expected since domain2 can't access network of domain1")
 
     @attr(tags=["advanced", "basic", "sg"], required_hardware="false")
     def test_04_list_publicip_all_subdomains(self):
@@ -764,7 +764,7 @@ class TestPublicIp(cloudstackTestCase):
             # Step 6
             self.fail("Domain should not access public ip of sibling domain")
         except Exception as e:
-            self.info("Got exception as expected since domain2 cant access network of domain1")
+            self.info("Got exception as expected since domain2 can't access network of domain1")
 
         self.vpc_off.update(self.apiclient, state='Disabled')
         self.cleanup.append(vpc_1)
@@ -826,7 +826,7 @@ class TestPublicIp(cloudstackTestCase):
             # Step 6
             self.fail("Domain should not access public ip of sibling domain")
         except Exception as e:
-            self.info("Got exception as expected since domain2 cant access network of domain1")
+            self.info("Got exception as expected since domain2 can't access network of domain1")
 
     def get_free_ipaddress(self, vlanId, domainId, account):
         ipaddresses = PublicIPAddress.list(
diff --git a/test/integration/smoke/test_create_network.py b/test/integration/smoke/test_create_network.py
index 497679fc0e..19c63e94bf 100644
--- a/test/integration/smoke/test_create_network.py
+++ b/test/integration/smoke/test_create_network.py
@@ -201,7 +201,7 @@ class TestNetworkManagement(cloudstackTestCase):
             # 4. No exception should be thrown as multiple networks with same name can be created
             # 5. Now update the global setting allow.duplicate.networkname to false
             # 6. Try to create another shared network with same name in the same account
-            # 7. Exception should be thrown as network with same name cant be created in the same account
+            # 7. Exception should be thrown as network with same name can't be created in the same account
         :return:
         """
         # Update the global setting to true
diff --git a/test/integration/smoke/test_update_security_group.py b/test/integration/smoke/test_update_security_group.py
index 95bf7b2d92..47fb01ba81 100644
--- a/test/integration/smoke/test_update_security_group.py
+++ b/test/integration/smoke/test_update_security_group.py
@@ -296,7 +296,7 @@ class TestUpdateSecurityGroup(cloudstackTestCase):
         #
         # 1. Create a security group
         # 2. Update the security group and change its name to "default"
-        # 3. Exception should be thrown as "default" name cant be used
+        # 3. Exception should be thrown as "default" name can't be used
 
         security_group = SecurityGroup.create(
             self.apiclient,
diff --git a/test/integration/testpaths/testpath_volumelifecycle.py b/test/integration/testpaths/testpath_volumelifecycle.py
index e896f6e596..42dd7c05e9 100644
--- a/test/integration/testpaths/testpath_volumelifecycle.py
+++ b/test/integration/testpaths/testpath_volumelifecycle.py
@@ -995,7 +995,7 @@ class TestPathVolume(cloudstackTestCase):
                                                  )
             self.fail("Volume got attached to a destroyed vm ")
         except Exception:
-            self.debug("Volume cant not be attached to a destroyed vm ")
+            self.debug("Volume can't not be attached to a destroyed vm ")
 
         # 11.Upload the volume  by providing the URL of the downloaded
         # volume, but specify a wrong format (not supported by the hypervisor)
diff --git a/test/metadata/func/regression_new.xml b/test/metadata/func/regression_new.xml
index c6b84c9836..3d14dcfe5d 100644
--- a/test/metadata/func/regression_new.xml
+++ b/test/metadata/func/regression_new.xml
@@ -27,7 +27,7 @@ under the License.
 		internal dns and CIDR are given
 	-->
 	<!--
-		Test case 13: It doesnt contain user_data, size, network_group_list
+		Test case 13: It doesn't contain user_data, size, network_group_list
 	-->
 
 	<!-- Test case #3 - createUser command -->
diff --git a/test/metadata/func/vmapi.xml b/test/metadata/func/vmapi.xml
index ff2e05e9fa..1dcf5a3cb1 100644
--- a/test/metadata/func/vmapi.xml
+++ b/test/metadata/func/vmapi.xml
@@ -26,7 +26,7 @@ under the License.
 		2. Destroy the Virtual Machine
 		3. List the Destroyed Virtual Machine
 		4. Check that the Destroyed VM cannot be started
-		5. Check that a non-existing VM cannot be listed (Id doesnt exist)
+		5. Check that a non-existing VM cannot be listed (Id doesn't exist)
 		6. Create the Account and a User for the account (List VM for a Removed User exercise BEGIN)
 		7. List the Created User
 		8. Creating default network
@@ -164,7 +164,7 @@ under the License.
 <!-- Test case #73 - verify that listVm returns nothing when id of non-existing VM is specified -->
 	<command>
 		<name>listVirtualMachines</name>
-		<testcase>73  [Check that a non-existing VM cannot be listed (Id doesnt exist)]</testcase>
+		<testcase>73  [Check that a non-existing VM cannot be listed (Id doesn't exist)]</testcase>
 		<parameters>
 			<item>
 				<name>account</name>
diff --git a/tools/ngui/static/js/lib/jquery-1.7.2.js b/tools/ngui/static/js/lib/jquery-1.7.2.js
index 75ce261777..877f0b2e9e 100644
--- a/tools/ngui/static/js/lib/jquery-1.7.2.js
+++ b/tools/ngui/static/js/lib/jquery-1.7.2.js
@@ -8521,7 +8521,7 @@ jQuery.fn.extend({
 					replace = hooks.expand( prop[ name ] );
 					delete prop[ name ];
 
-					// not quite $.extend, this wont overwrite keys already present.
+					// not quite $.extend, this won't overwrite keys already present.
 					// also - reusing 'p' from above because we have the correct "name"
 					for ( p in replace ) {
 						if ( ! ( p in prop ) ) {