You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@cloudstack.apache.org by ra...@apache.org on 2017/02/28 00:21:39 UTC

[1/9] git commit: updated refs/heads/4.9 to b95bf8f

Repository: cloudstack
Updated Branches:
  refs/heads/4.9 c6f0ba76b -> b95bf8fcd


Fix HVM VM restart bug in XenServer


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

Branch: refs/heads/4.9
Commit: 966814b07d438c3d9eac415c54c1b4bdbf1911f9
Parents: 7da95172
Author: Syed <sy...@gmail.com>
Authored: Thu Dec 15 14:12:59 2016 -0500
Committer: Syed <sy...@gmail.com>
Committed: Thu Dec 15 14:12:59 2016 -0500

----------------------------------------------------------------------
 .../cloud/hypervisor/xenserver/resource/CitrixResourceBase.java  | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/966814b0/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
----------------------------------------------------------------------
diff --git a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
index 2865e56..5746536 100644
--- a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
+++ b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
@@ -1149,8 +1149,8 @@ public abstract class CitrixResourceBase implements ServerResource, HypervisorRe
             vbdr.unpluggable = (volume.getType() == Volume.Type.ROOT) ? false : true;
             vbdr.userdevice = "autodetect";
             final Long deviceId = volume.getDiskSeq();
-            if (deviceId != null && !isDeviceUsed(conn, vm, deviceId)) {
-                vbdr.userdevice = deviceId.toString();
+            if (deviceId != null && (!isDeviceUsed(conn, vm, deviceId) || deviceId > 3)) {
+                    vbdr.userdevice = deviceId.toString();
             }
         }
         final VBD vbd = VBD.create(conn, vbdr);


[3/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
CLOUDSTACK-9788: Fix exception listNetworks with pagesize=0


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

Branch: refs/heads/4.9
Commit: c883e294d36f64d09bed2f7e22086ab413f28d33
Parents: 6dced70
Author: Wei Zhou <w....@tech.leaseweb.com>
Authored: Thu Feb 16 12:01:44 2017 +0100
Committer: Wei Zhou <w....@tech.leaseweb.com>
Committed: Thu Feb 16 14:08:21 2017 +0100

----------------------------------------------------------------------
 utils/src/main/java/com/cloud/utils/StringUtils.java | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/c883e294/utils/src/main/java/com/cloud/utils/StringUtils.java
----------------------------------------------------------------------
diff --git a/utils/src/main/java/com/cloud/utils/StringUtils.java b/utils/src/main/java/com/cloud/utils/StringUtils.java
index 71cebe1..9554e87 100644
--- a/utils/src/main/java/com/cloud/utils/StringUtils.java
+++ b/utils/src/main/java/com/cloud/utils/StringUtils.java
@@ -296,8 +296,8 @@ public class StringUtils {
     public static <T> List<T> applyPagination(final List<T> originalList, final Long startIndex, final Long pageSizeVal) {
         // Most likely pageSize will never exceed int value, and we need integer to partition the listToReturn
         final boolean applyPagination = startIndex != null && pageSizeVal != null
-                && startIndex <= Integer.MAX_VALUE && startIndex >= Integer.MIN_VALUE && pageSizeVal <= Integer.MAX_VALUE
-                && pageSizeVal >= Integer.MIN_VALUE;
+                && startIndex <= Integer.MAX_VALUE && startIndex >= 0 && pageSizeVal <= Integer.MAX_VALUE
+                && pageSizeVal > 0;
                 List<T> listWPagination = null;
                 if (applyPagination) {
                     listWPagination = new ArrayList<>();


[8/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
Merge pull request #1915 from serbaut/CLOUDSTACK-9746

CLOUDSTACK-9746 system-vm: logrotate config causes critical failures* rotate both daily and by size by using maxsize in stead of size
* decrease the max size to 10M for rsyslog files
* remove delaycompress for rsyslog files
* increase rotate to 10 for cloud.log

* pr/1915:
  CLOUDSTACK-9746 system-vm: logrotate config causes critical failures

Signed-off-by: Rajani Karuturi <ra...@accelerite.com>


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

Branch: refs/heads/4.9
Commit: 113ce13bda9d4a095ff3a22d6fedf925117f4f6f
Parents: a13ee85 5604b4c
Author: Rajani Karuturi <ra...@accelerite.com>
Authored: Tue Feb 28 05:44:47 2017 +0530
Committer: Rajani Karuturi <ra...@accelerite.com>
Committed: Tue Feb 28 05:44:47 2017 +0530

----------------------------------------------------------------------
 systemvm/patches/debian/config/etc/logrotate.d/apache2    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/cloud      | 4 ++--
 systemvm/patches/debian/config/etc/logrotate.d/conntrackd | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/dnsmasq    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/haproxy    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/ppp        | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/rsyslog    | 6 ++----
 7 files changed, 9 insertions(+), 11 deletions(-)
----------------------------------------------------------------------



[2/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
CLOUDSTACK-8663: Fixed various issues to allow VM snapshots and volume
snapshots to exist together

Reverting VM to disk only snapshot in Xenserver corrupts VM

Stale NFS secondary storage on XS leads to volume creation failure from snapshot


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

Branch: refs/heads/4.9
Commit: ca84fd4ffd5d80aef9c7624365d29d7b2aeb3225
Parents: abd7860
Author: Anshul Gangwar <an...@citrix.com>
Authored: Fri Jul 24 14:45:20 2015 +0530
Committer: Anshul Gangwar <an...@accelerite.com>
Committed: Wed Feb 15 12:56:39 2017 +0530

----------------------------------------------------------------------
 .../xenserver/resource/CitrixResourceBase.java  | 30 ++++++++++++++++++++
 .../resource/XenServerStorageProcessor.java     |  2 +-
 .../resource/Xenserver625StorageProcessor.java  |  2 +-
 .../com/cloud/storage/VolumeApiServiceImpl.java |  7 -----
 .../vm/snapshot/VMSnapshotManagerImpl.java      |  5 ----
 5 files changed, 32 insertions(+), 14 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/ca84fd4f/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
----------------------------------------------------------------------
diff --git a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
index 2865e56..da46563 100644
--- a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
+++ b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
@@ -29,6 +29,8 @@ import java.net.URISyntaxException;
 import java.net.URL;
 import java.net.URLConnection;
 import java.nio.charset.Charset;
+
+import org.apache.commons.collections.MapUtils;
 import org.joda.time.Duration;
 import java.util.ArrayList;
 import java.util.Date;
@@ -1415,6 +1417,10 @@ public abstract class CitrixResourceBase implements ServerResource, HypervisorRe
             vbdr.userdevice = "autodetect";
             vbdr.mode = Types.VbdMode.RW;
             vbdr.type = Types.VbdType.DISK;
+            Long deviceId = volumeTO.getDeviceId();
+            if (deviceId != null && (!isDeviceUsed(conn, vm, deviceId) || deviceId > 3)) {
+                vbdr.userdevice = deviceId.toString();
+            }
             VBD.create(conn, vbdr);
         }
         return vm;
@@ -4350,6 +4356,30 @@ public abstract class CitrixResourceBase implements ServerResource, HypervisorRe
         }
     }
 
+    protected void skipOrRemoveSR(Connection conn, SR sr) {
+        if (sr == null) {
+            return;
+        }
+        if (s_logger.isDebugEnabled()) {
+            s_logger.debug(logX(sr, "Removing SR"));
+        }
+        try {
+            Set<VDI> vdis = sr.getVDIs(conn);
+            for (VDI vdi : vdis) {
+                if (MapUtils.isEmpty(vdi.getCurrentOperations(conn))) {
+                    continue;
+                }
+                return;
+            }
+            removeSR(conn, sr);
+            return;
+        } catch (XenAPIException | XmlRpcException e) {
+            s_logger.warn(logX(sr, "Unable to get current opertions " + e.toString()), e);
+        }
+        String msg = "Remove SR failed";
+        s_logger.warn(msg);
+    }
+
     public void removeSR(final Connection conn, final SR sr) {
         if (sr == null) {
             return;

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/ca84fd4f/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/XenServerStorageProcessor.java
----------------------------------------------------------------------
diff --git a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/XenServerStorageProcessor.java b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/XenServerStorageProcessor.java
index bcf997f..1144276 100644
--- a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/XenServerStorageProcessor.java
+++ b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/XenServerStorageProcessor.java
@@ -1199,7 +1199,7 @@ public class XenServerStorageProcessor implements StorageProcessor {
             final Set<VDI> snapshots = volume.getSnapshots(conn);
             for (final VDI snapshot : snapshots) {
                 try {
-                    if (!snapshot.getUuid(conn).equals(avoidSnapshotUuid) && snapshot.getSnapshotTime(conn).before(avoidSnapshot.getSnapshotTime(conn))) {
+                    if (!snapshot.getUuid(conn).equals(avoidSnapshotUuid) && snapshot.getSnapshotTime(conn).before(avoidSnapshot.getSnapshotTime(conn)) && snapshot.getVBDs(conn).isEmpty()) {
                         snapshot.destroy(conn);
                     }
                 } catch (final Exception e) {

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/ca84fd4f/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/Xenserver625StorageProcessor.java
----------------------------------------------------------------------
diff --git a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/Xenserver625StorageProcessor.java b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/Xenserver625StorageProcessor.java
index e3c3beb..b70057d 100644
--- a/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/Xenserver625StorageProcessor.java
+++ b/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/Xenserver625StorageProcessor.java
@@ -738,7 +738,7 @@ public class Xenserver625StorageProcessor extends XenServerStorageProcessor {
             s_logger.warn(details, e);
         } finally {
             if (srcSr != null) {
-                hypervisorResource.removeSR(conn, srcSr);
+                hypervisorResource.skipOrRemoveSR(conn, srcSr);
             }
             if (!result && destVdi != null) {
                 try {

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/ca84fd4f/server/src/com/cloud/storage/VolumeApiServiceImpl.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/storage/VolumeApiServiceImpl.java b/server/src/com/cloud/storage/VolumeApiServiceImpl.java
index 77ecc2a..2a9f02d 100644
--- a/server/src/com/cloud/storage/VolumeApiServiceImpl.java
+++ b/server/src/com/cloud/storage/VolumeApiServiceImpl.java
@@ -2146,13 +2146,6 @@ public class VolumeApiServiceImpl extends ManagerBase implements VolumeApiServic
             throw new InvalidParameterValueException("Can't find zone by id " + volume.getDataCenterId());
         }
 
-        if (volume.getInstanceId() != null) {
-            // Check that Vm to which this volume is attached does not have VM Snapshots
-            if (_vmSnapshotDao.findByVm(volume.getInstanceId()).size() > 0) {
-                throw new InvalidParameterValueException("Volume snapshot is not allowed, please detach it from VM with VM Snapshots");
-            }
-        }
-
         if (Grouping.AllocationState.Disabled == zone.getAllocationState() && !_accountMgr.isRootAdmin(caller.getId())) {
             throw new PermissionDeniedException("Cannot perform this operation, Zone is currently disabled: " + zone.getName());
         }

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/ca84fd4f/server/src/com/cloud/vm/snapshot/VMSnapshotManagerImpl.java
----------------------------------------------------------------------
diff --git a/server/src/com/cloud/vm/snapshot/VMSnapshotManagerImpl.java b/server/src/com/cloud/vm/snapshot/VMSnapshotManagerImpl.java
index bb1536d..5e6ec1c 100644
--- a/server/src/com/cloud/vm/snapshot/VMSnapshotManagerImpl.java
+++ b/server/src/com/cloud/vm/snapshot/VMSnapshotManagerImpl.java
@@ -263,11 +263,6 @@ public class VMSnapshotManagerImpl extends MutualExclusiveIdsManagerBase impleme
             throw new InvalidParameterValueException("Creating VM snapshot failed due to VM:" + vmId + " is a system VM or does not exist");
         }
 
-        if (_snapshotDao.listByInstanceId(vmId, Snapshot.State.BackedUp).size() > 0) {
-            throw new InvalidParameterValueException(
-                    "VM snapshot for this VM is not allowed. This VM has volumes attached which has snapshots, please remove all snapshots before taking VM snapshot");
-        }
-
         // VM snapshot with memory is not supported for VGPU Vms
         if (snapshotMemory && _serviceOfferingDetailsDao.findDetail(userVmVo.getServiceOfferingId(), GPU.Keys.vgpuType.toString()) != null) {
             throw new InvalidParameterValueException("VM snapshot with MEMORY is not supported for vGPU enabled VMs.");


[6/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
Merge pull request #1941 from anshul1886/CLOUDSTACK-8663

CLOUDSTACK-8663: Fixed various issues to allow VM snapshots and volumesnapshots to exist together

Reverting VM to disk only snapshot in Xenserver corrupts VM

Stale NFS secondary storage on XS leads to volume creation failure from snapshot

Fixed various concerns raised in #672

* pr/1941:
  CLOUDSTACK-8663: Fixed various issues to allow VM snapshots and volume snapshots to exist together

Signed-off-by: Rajani Karuturi <ra...@accelerite.com>


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

Branch: refs/heads/4.9
Commit: ea7c48cf6127aeb73c1d25d7bcee52120ab85204
Parents: c4d63af ca84fd4
Author: Rajani Karuturi <ra...@accelerite.com>
Authored: Tue Feb 28 05:39:34 2017 +0530
Committer: Rajani Karuturi <ra...@accelerite.com>
Committed: Tue Feb 28 05:39:34 2017 +0530

----------------------------------------------------------------------
 .../xenserver/resource/CitrixResourceBase.java  | 30 ++++++++++++++++++++
 .../resource/XenServerStorageProcessor.java     |  2 +-
 .../resource/Xenserver625StorageProcessor.java  |  2 +-
 .../com/cloud/storage/VolumeApiServiceImpl.java |  7 -----
 .../vm/snapshot/VMSnapshotManagerImpl.java      |  5 ----
 5 files changed, 32 insertions(+), 14 deletions(-)
----------------------------------------------------------------------



[7/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
Merge pull request #1829 from syed/hvm-volume-attach-restart-fix

CLOUDSTACK-9363: Fix HVM VM restart bug in XenServerHere is the longer description of the problem:

By default XenServer limits HVM guests to only 4 disks. Two of those are reserved for the ROOT disk (deviceId=0) and CD ROM (device ID=3) which means that we can only attach 2 data disks. This limit however is removed when Xentools is installed on the guest. The information that a guest has Xentools installed and can handle more than 4 disks is stored in the VM metadata on XenServer. When a VM is shut down, Cloudstack removes the VM and all the metadata associated with the VM from XenServer. Now, when you start the VM again, even if it has Xentools installed, it will default to only 4 attachable disks.

Now this problem manifests itself when you have a HVM VM and you stop and start it with more than 2 data disks attached. The VM fails to start and the only way to start the VM is to detach the extra disks and then reattach them after the VM start.

In this fix, I am removing the check which is done before creating a `VBD` which enforces this limit. This will not affect current workflow and will fix the HVM issue.

@koushik-das this is related to the "autodetect" feature that you introduced a while back (https://issues.apache.org/jira/browse/CLOUDSTACK-8826). I would love your review on this fix.

* pr/1829:
  Fix HVM VM restart bug in XenServer

Signed-off-by: Rajani Karuturi <ra...@accelerite.com>


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

Branch: refs/heads/4.9
Commit: d9bd01266ffb23f591283c058beff6e65d1cc4aa
Parents: ea7c48c 966814b
Author: Rajani Karuturi <ra...@accelerite.com>
Authored: Tue Feb 28 05:42:58 2017 +0530
Committer: Rajani Karuturi <ra...@accelerite.com>
Committed: Tue Feb 28 05:42:59 2017 +0530

----------------------------------------------------------------------
 .../cloud/hypervisor/xenserver/resource/CitrixResourceBase.java  | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/d9bd0126/plugins/hypervisors/xenserver/src/com/cloud/hypervisor/xenserver/resource/CitrixResourceBase.java
----------------------------------------------------------------------


[4/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
CLOUDSTACK-9746 system-vm: logrotate config causes critical failures

* rotate both daily and by size by using maxsize in stead of size
* decrease the max size to 10M for rsyslog files
* remove delaycompress for rsyslog files
* increase rotate to 10 for cloud.log


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

Branch: refs/heads/4.9
Commit: 5604b4c59e73472d3aa14d08c27a9e1bf1a7948b
Parents: a13ee85
Author: Joakim Sernbrant <jo...@trioptima.com>
Authored: Tue Feb 21 16:39:42 2017 +0100
Committer: Joakim Sernbrant <jo...@trioptima.com>
Committed: Wed Feb 22 11:04:52 2017 +0100

----------------------------------------------------------------------
 systemvm/patches/debian/config/etc/logrotate.d/apache2    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/cloud      | 4 ++--
 systemvm/patches/debian/config/etc/logrotate.d/conntrackd | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/dnsmasq    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/haproxy    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/ppp        | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/rsyslog    | 6 ++----
 7 files changed, 9 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/apache2
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/apache2 b/systemvm/patches/debian/config/etc/logrotate.d/apache2
index 3932c27..58ddb4d 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/apache2
+++ b/systemvm/patches/debian/config/etc/logrotate.d/apache2
@@ -4,6 +4,6 @@
        rotate 3
        compress
        dateext
-       size 10M
+       maxsize 10M
        notifempty
 }

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/cloud
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/cloud b/systemvm/patches/debian/config/etc/logrotate.d/cloud
index 420fce2..bf0ec74 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/cloud
+++ b/systemvm/patches/debian/config/etc/logrotate.d/cloud
@@ -15,9 +15,9 @@
 # specific language governing permissions and limitations
 # under the License.
 /var/log/cloud.log {
-        rotate 4
+        rotate 10
         daily
-        size 10M
+        maxsize 10M
         missingok
         notifempty
         compress

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/conntrackd b/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
index 0229cd7..89f560d 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
+++ b/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
@@ -1,6 +1,6 @@
 /var/log/conntrackd-stats.log {
     daily
-    size 10M
+    maxsize 10M
     rotate 2
     missingok
     compress

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq b/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
index 2f91785..9fb70f0 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
+++ b/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
@@ -1,6 +1,6 @@
 /var/log/dnsmasq.log {
     daily
-    size 10M
+    maxsize 10M
     missingok
     rotate 5
     notifempty

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/haproxy
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/haproxy b/systemvm/patches/debian/config/etc/logrotate.d/haproxy
index 858fe2a..1c8110b 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/haproxy
+++ b/systemvm/patches/debian/config/etc/logrotate.d/haproxy
@@ -3,7 +3,7 @@
     rotate 5
     missingok
     notifempty
-    size 10M
+    maxsize 10M
     postrotate  
       /bin/kill -HUP `cat /var/run/rsyslog.pid 2> /dev/null` 2> /dev/null || true
     endscript

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/ppp
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/ppp b/systemvm/patches/debian/config/etc/logrotate.d/ppp
index 2004e77..2d70f6a 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/ppp
+++ b/systemvm/patches/debian/config/etc/logrotate.d/ppp
@@ -1,6 +1,6 @@
 /var/log/ppp-connect-errors {
 	daily
-	size 10M
+	maxsize 10M
 	rotate 5
 	missingok
 	notifempty

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/5604b4c5/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
----------------------------------------------------------------------
diff --git a/systemvm/patches/debian/config/etc/logrotate.d/rsyslog b/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
index 5803c43..9397f41 100644
--- a/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
+++ b/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
@@ -2,10 +2,9 @@
 {
 	rotate 7
 	daily
-	size 50M
+	maxsize 10M
 	missingok
 	notifempty
-	delaycompress
 	compress
 	postrotate
 		/usr/sbin/invoke-rc.d rsyslog rotate > /dev/null
@@ -27,11 +26,10 @@
 {
 	rotate 10
 	daily
-	size 50M
+	maxsize 10M
 	missingok
 	notifempty
 	compress
-	delaycompress
 	sharedscripts
 	postrotate
 		/usr/sbin/invoke-rc.d rsyslog rotate > /dev/null


[9/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
Merge release branch 4.8 to 4.9

* 4.8:
  CLOUDSTACK-9746 system-vm: logrotate config causes critical failures


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

Branch: refs/heads/4.9
Commit: b95bf8fcd8a2e6b0966e62a35ed6bc9a0a86ab1f
Parents: d9bd012 113ce13
Author: Rajani Karuturi <ra...@accelerite.com>
Authored: Tue Feb 28 05:45:31 2017 +0530
Committer: Rajani Karuturi <ra...@accelerite.com>
Committed: Tue Feb 28 05:45:31 2017 +0530

----------------------------------------------------------------------
 systemvm/patches/debian/config/etc/logrotate.d/apache2    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/cloud      | 4 ++--
 systemvm/patches/debian/config/etc/logrotate.d/conntrackd | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/dnsmasq    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/haproxy    | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/ppp        | 2 +-
 systemvm/patches/debian/config/etc/logrotate.d/rsyslog    | 6 ++----
 7 files changed, 9 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/cloud
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/cloud
index 3fedd5e,bf0ec74..8bda52c
--- a/systemvm/patches/debian/config/etc/logrotate.d/cloud
+++ b/systemvm/patches/debian/config/etc/logrotate.d/cloud
@@@ -15,8 -15,9 +15,8 @@@
  # specific language governing permissions and limitations
  # under the License.
  /var/log/cloud.log {
-         rotate 4
-         size 10M
+         rotate 10
 -        daily
+         maxsize 10M
          missingok
          notifempty
          compress

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/conntrackd
index 1c37c4c,89f560d..8b5ff66
--- a/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
+++ b/systemvm/patches/debian/config/etc/logrotate.d/conntrackd
@@@ -1,5 -1,6 +1,5 @@@
  /var/log/conntrackd-stats.log {
-     size 10M
 -    daily
+     maxsize 10M
      rotate 2
      missingok
      compress

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
index 99815d8,9fb70f0..8a797e9
--- a/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
+++ b/systemvm/patches/debian/config/etc/logrotate.d/dnsmasq
@@@ -1,5 -1,6 +1,5 @@@
  /var/log/dnsmasq.log {
-     size 10M
 -    daily
+     maxsize 10M
      missingok
      rotate 5
      notifempty

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/haproxy
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/haproxy
index 28da41c,1c8110b..4642097
--- a/systemvm/patches/debian/config/etc/logrotate.d/haproxy
+++ b/systemvm/patches/debian/config/etc/logrotate.d/haproxy
@@@ -2,8 -2,9 +2,8 @@@
      rotate 5
      missingok
      notifempty
-     size 10M
+     maxsize 10M
 -    postrotate  
 +    postrotate
        /bin/kill -HUP `cat /var/run/rsyslog.pid 2> /dev/null` 2> /dev/null || true
      endscript
  }

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/ppp
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/ppp
index 624b4ae,2d70f6a..ce02c17
--- a/systemvm/patches/debian/config/etc/logrotate.d/ppp
+++ b/systemvm/patches/debian/config/etc/logrotate.d/ppp
@@@ -1,5 -1,6 +1,5 @@@
  /var/log/ppp-connect-errors {
- 	size 10M
 -	daily
+ 	maxsize 10M
  	rotate 5
  	missingok
  	notifempty

http://git-wip-us.apache.org/repos/asf/cloudstack/blob/b95bf8fc/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
----------------------------------------------------------------------
diff --cc systemvm/patches/debian/config/etc/logrotate.d/rsyslog
index 5a104b3,9397f41..9291494
--- a/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
+++ b/systemvm/patches/debian/config/etc/logrotate.d/rsyslog
@@@ -1,10 -1,10 +1,9 @@@
  /var/log/syslog
  {
  	rotate 7
- 	size 50M
 -	daily
+ 	maxsize 10M
  	missingok
  	notifempty
- 	delaycompress
  	compress
  	postrotate
  		/usr/sbin/invoke-rc.d rsyslog rotate > /dev/null
@@@ -25,7 -25,8 +24,7 @@@
  /var/log/messages
  {
  	rotate 10
- 	size 50M
 -	daily
+ 	maxsize 10M
  	missingok
  	notifempty
  	compress


[5/9] git commit: updated refs/heads/4.9 to b95bf8f

Posted by ra...@apache.org.
Merge pull request #1946 from ustcweizhou/pagesizeIs0

CLOUDSTACK-9788: Fix exception listNetworks with pagesize=0

* pr/1946:
  CLOUDSTACK-9788: Fix exception listNetworks with pagesize=0

Signed-off-by: Rajani Karuturi <ra...@accelerite.com>


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

Branch: refs/heads/4.9
Commit: c4d63af149d22fce0534ce623ef95cb2368c6c7e
Parents: c6f0ba7 c883e29
Author: Rajani Karuturi <ra...@accelerite.com>
Authored: Tue Feb 28 05:35:51 2017 +0530
Committer: Rajani Karuturi <ra...@accelerite.com>
Committed: Tue Feb 28 05:35:52 2017 +0530

----------------------------------------------------------------------
 utils/src/main/java/com/cloud/utils/StringUtils.java | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------