Search in sources :

Example 11 with UsageEventVO

use of com.cloud.event.UsageEventVO in project cloudstack by apache.

the class AccountManagerImplVolumeDeleteEventTest method runningVMRootVolumeUsageEvent.

@Test
public // volume.
void runningVMRootVolumeUsageEvent() throws SecurityException, IllegalArgumentException, ReflectiveOperationException, AgentUnavailableException, ConcurrentOperationException, CloudException {
    List<UsageEventVO> emittedEvents = deleteUserAccountRootVolumeUsageEvents(false);
    Assert.assertEquals(1, emittedEvents.size());
    UsageEventVO event = emittedEvents.get(0);
    Assert.assertEquals(EventTypes.EVENT_VOLUME_DELETE, event.getType());
    Assert.assertEquals(VOLUME_UUID, event.getResourceName());
}
Also used : UsageEventVO(com.cloud.event.UsageEventVO) Test(org.junit.Test)

Example 12 with UsageEventVO

use of com.cloud.event.UsageEventVO in project cloudstack by apache.

the class UsageManagerImpl method parse.

@Override
public void parse(UsageJobVO job, long startDateMillis, long endDateMillis) {
    // TODO: Shouldn't we also allow parsing by the type of usage?
    boolean success = false;
    long timeStart = System.currentTimeMillis();
    try {
        if ((endDateMillis == 0) || (endDateMillis > timeStart)) {
            endDateMillis = timeStart;
        }
        long lastSuccess = _usageJobDao.getLastJobSuccessDateMillis();
        if (lastSuccess != 0) {
            // 1 millisecond after
            startDateMillis = lastSuccess + 1;
        }
        if (startDateMillis >= endDateMillis) {
            if (s_logger.isInfoEnabled()) {
                s_logger.info("not parsing usage records since start time mills (" + startDateMillis + ") is on or after end time millis (" + endDateMillis + ")");
            }
            TransactionLegacy jobUpdateTxn = TransactionLegacy.open(TransactionLegacy.USAGE_DB);
            try {
                jobUpdateTxn.start();
                // everything seemed to work...set endDate as the last success date
                _usageJobDao.updateJobSuccess(job.getId(), startDateMillis, endDateMillis, System.currentTimeMillis() - timeStart, success);
                // create a new job if this is a recurring job
                if (job.getJobType() == UsageJobVO.JOB_TYPE_RECURRING) {
                    _usageJobDao.createNewJob(_hostname, _pid, UsageJobVO.JOB_TYPE_RECURRING);
                }
                jobUpdateTxn.commit();
            } finally {
                jobUpdateTxn.close();
            }
            return;
        }
        Date startDate = new Date(startDateMillis);
        Date endDate = new Date(endDateMillis);
        if (s_logger.isInfoEnabled()) {
            s_logger.info("Parsing usage records between " + startDate + " and " + endDate);
        }
        List<AccountVO> accounts = null;
        List<UserStatisticsVO> userStats = null;
        Map<String, UsageNetworkVO> networkStats = null;
        List<VmDiskStatisticsVO> vmDiskStats = null;
        Map<String, UsageVmDiskVO> vmDiskUsages = null;
        TransactionLegacy userTxn = TransactionLegacy.open(TransactionLegacy.CLOUD_DB);
        try {
            Long limit = Long.valueOf(500);
            Long offset = Long.valueOf(0);
            Long lastAccountId = _usageDao.getLastAccountId();
            if (lastAccountId == null) {
                lastAccountId = Long.valueOf(0);
            }
            do {
                Filter filter = new Filter(AccountVO.class, "id", true, offset, limit);
                accounts = _accountDao.findActiveAccounts(lastAccountId, filter);
                if ((accounts != null) && !accounts.isEmpty()) {
                    // now update the accounts in the cloud_usage db
                    _usageDao.updateAccounts(accounts);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((accounts != null) && !accounts.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            do {
                Filter filter = new Filter(AccountVO.class, "id", true, offset, limit);
                accounts = _accountDao.findRecentlyDeletedAccounts(lastAccountId, startDate, filter);
                if ((accounts != null) && !accounts.isEmpty()) {
                    // now update the accounts in the cloud_usage db
                    _usageDao.updateAccounts(accounts);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((accounts != null) && !accounts.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            do {
                Filter filter = new Filter(AccountVO.class, "id", true, offset, limit);
                accounts = _accountDao.findNewAccounts(lastAccountId, filter);
                if ((accounts != null) && !accounts.isEmpty()) {
                    // now copy the accounts to cloud_usage db
                    _usageDao.saveAccounts(accounts);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((accounts != null) && !accounts.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            // get all the user stats to create usage records for the network usage
            Long lastUserStatsId = _usageDao.getLastUserStatsId();
            if (lastUserStatsId == null) {
                lastUserStatsId = Long.valueOf(0);
            }
            SearchCriteria<UserStatisticsVO> sc2 = _userStatsDao.createSearchCriteria();
            sc2.addAnd("id", SearchCriteria.Op.LTEQ, lastUserStatsId);
            do {
                Filter filter = new Filter(UserStatisticsVO.class, "id", true, offset, limit);
                userStats = _userStatsDao.search(sc2, filter);
                if ((userStats != null) && !userStats.isEmpty()) {
                    // now copy the accounts to cloud_usage db
                    _usageDao.updateUserStats(userStats);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((userStats != null) && !userStats.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            sc2 = _userStatsDao.createSearchCriteria();
            sc2.addAnd("id", SearchCriteria.Op.GT, lastUserStatsId);
            do {
                Filter filter = new Filter(UserStatisticsVO.class, "id", true, offset, limit);
                userStats = _userStatsDao.search(sc2, filter);
                if ((userStats != null) && !userStats.isEmpty()) {
                    // now copy the accounts to cloud_usage db
                    _usageDao.saveUserStats(userStats);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((userStats != null) && !userStats.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            // get all the vm network stats to create usage_VM_network records for the vm network usage
            Long lastVmDiskStatsId = _usageDao.getLastVmDiskStatsId();
            if (lastVmDiskStatsId == null) {
                lastVmDiskStatsId = Long.valueOf(0);
            }
            SearchCriteria<VmDiskStatisticsVO> sc4 = _vmDiskStatsDao.createSearchCriteria();
            sc4.addAnd("id", SearchCriteria.Op.LTEQ, lastVmDiskStatsId);
            do {
                Filter filter = new Filter(VmDiskStatisticsVO.class, "id", true, offset, limit);
                vmDiskStats = _vmDiskStatsDao.search(sc4, filter);
                if ((vmDiskStats != null) && !vmDiskStats.isEmpty()) {
                    // now copy the accounts to cloud_usage db
                    _usageDao.updateVmDiskStats(vmDiskStats);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((vmDiskStats != null) && !vmDiskStats.isEmpty());
            // reset offset
            offset = Long.valueOf(0);
            sc4 = _vmDiskStatsDao.createSearchCriteria();
            sc4.addAnd("id", SearchCriteria.Op.GT, lastVmDiskStatsId);
            do {
                Filter filter = new Filter(VmDiskStatisticsVO.class, "id", true, offset, limit);
                vmDiskStats = _vmDiskStatsDao.search(sc4, filter);
                if ((vmDiskStats != null) && !vmDiskStats.isEmpty()) {
                    // now copy the accounts to cloud_usage db
                    _usageDao.saveVmDiskStats(vmDiskStats);
                }
                offset = new Long(offset.longValue() + limit.longValue());
            } while ((vmDiskStats != null) && !vmDiskStats.isEmpty());
        } finally {
            userTxn.close();
        }
        // TODO:  Fetch a maximum number of events and process them before moving on to the next range of events
        // - get a list of the latest events
        // - insert the latest events into the usage.events table
        List<UsageEventVO> events = _usageEventDao.getRecentEvents(new Date(endDateMillis));
        TransactionLegacy usageTxn = TransactionLegacy.open(TransactionLegacy.USAGE_DB);
        try {
            usageTxn.start();
            // to newest, so just test against the first event)
            if ((events != null) && (events.size() > 0)) {
                Date oldestEventDate = events.get(0).getCreateDate();
                if (oldestEventDate.getTime() < startDateMillis) {
                    startDateMillis = oldestEventDate.getTime();
                    startDate = new Date(startDateMillis);
                }
                // - create the usage records using the parse methods below
                for (UsageEventVO event : events) {
                    event.setProcessed(true);
                    _usageEventDao.update(event.getId(), event);
                    createHelperRecord(event);
                }
            }
            // TODO:  Fetch a maximum number of user stats and process them before moving on to the next range of user stats
            // get user stats in order to compute network usage
            networkStats = _usageNetworkDao.getRecentNetworkStats();
            Calendar recentlyDeletedCal = Calendar.getInstance(_usageTimezone);
            recentlyDeletedCal.setTimeInMillis(startDateMillis);
            recentlyDeletedCal.add(Calendar.MINUTE, -1 * THREE_DAYS_IN_MINUTES);
            Date recentlyDeletedDate = recentlyDeletedCal.getTime();
            // Keep track of user stats for an account, across all of its public IPs
            Map<String, UserStatisticsVO> aggregatedStats = new HashMap<String, UserStatisticsVO>();
            int startIndex = 0;
            do {
                userStats = _userStatsDao.listActiveAndRecentlyDeleted(recentlyDeletedDate, startIndex, 500);
                if (userStats != null) {
                    for (UserStatisticsVO userStat : userStats) {
                        if (userStat.getDeviceId() != null) {
                            String hostKey = userStat.getDataCenterId() + "-" + userStat.getAccountId() + "-Host-" + userStat.getDeviceId();
                            UserStatisticsVO hostAggregatedStat = aggregatedStats.get(hostKey);
                            if (hostAggregatedStat == null) {
                                hostAggregatedStat = new UserStatisticsVO(userStat.getAccountId(), userStat.getDataCenterId(), userStat.getPublicIpAddress(), userStat.getDeviceId(), userStat.getDeviceType(), userStat.getNetworkId());
                            }
                            hostAggregatedStat.setAggBytesSent(hostAggregatedStat.getAggBytesSent() + userStat.getAggBytesSent());
                            hostAggregatedStat.setAggBytesReceived(hostAggregatedStat.getAggBytesReceived() + userStat.getAggBytesReceived());
                            aggregatedStats.put(hostKey, hostAggregatedStat);
                        }
                    }
                }
                startIndex += 500;
            } while ((userStats != null) && !userStats.isEmpty());
            // loop over the user stats, create delta entries in the usage_network helper table
            int numAcctsProcessed = 0;
            usageNetworks.clear();
            for (String key : aggregatedStats.keySet()) {
                UsageNetworkVO currentNetworkStats = null;
                if (networkStats != null) {
                    currentNetworkStats = networkStats.get(key);
                }
                createNetworkHelperEntry(aggregatedStats.get(key), currentNetworkStats, endDateMillis);
                numAcctsProcessed++;
            }
            _usageNetworkDao.saveUsageNetworks(usageNetworks);
            if (s_logger.isDebugEnabled()) {
                s_logger.debug("created network stats helper entries for " + numAcctsProcessed + " accts");
            }
            // get vm disk stats in order to compute vm disk usage
            vmDiskUsages = _usageVmDiskDao.getRecentVmDiskStats();
            // Keep track of user stats for an account, across all of its public IPs
            Map<String, VmDiskStatisticsVO> aggregatedDiskStats = new HashMap<String, VmDiskStatisticsVO>();
            startIndex = 0;
            do {
                vmDiskStats = _vmDiskStatsDao.listActiveAndRecentlyDeleted(recentlyDeletedDate, startIndex, 500);
                if (vmDiskUsages != null) {
                    for (VmDiskStatisticsVO vmDiskStat : vmDiskStats) {
                        if (vmDiskStat.getVmId() != null) {
                            String hostKey = vmDiskStat.getDataCenterId() + "-" + vmDiskStat.getAccountId() + "-Vm-" + vmDiskStat.getVmId() + "-Disk-" + vmDiskStat.getVolumeId();
                            VmDiskStatisticsVO hostAggregatedStat = aggregatedDiskStats.get(hostKey);
                            if (hostAggregatedStat == null) {
                                hostAggregatedStat = new VmDiskStatisticsVO(vmDiskStat.getAccountId(), vmDiskStat.getDataCenterId(), vmDiskStat.getVmId(), vmDiskStat.getVolumeId());
                            }
                            hostAggregatedStat.setAggIORead(hostAggregatedStat.getAggIORead() + vmDiskStat.getAggIORead());
                            hostAggregatedStat.setAggIOWrite(hostAggregatedStat.getAggIOWrite() + vmDiskStat.getAggIOWrite());
                            hostAggregatedStat.setAggBytesRead(hostAggregatedStat.getAggBytesRead() + vmDiskStat.getAggBytesRead());
                            hostAggregatedStat.setAggBytesWrite(hostAggregatedStat.getAggBytesWrite() + vmDiskStat.getAggBytesWrite());
                            aggregatedDiskStats.put(hostKey, hostAggregatedStat);
                        }
                    }
                }
                startIndex += 500;
            } while ((userStats != null) && !userStats.isEmpty());
            // loop over the user stats, create delta entries in the usage_disk helper table
            numAcctsProcessed = 0;
            usageVmDisks.clear();
            for (String key : aggregatedDiskStats.keySet()) {
                UsageVmDiskVO currentVmDiskStats = null;
                if (vmDiskStats != null) {
                    currentVmDiskStats = vmDiskUsages.get(key);
                }
                createVmDiskHelperEntry(aggregatedDiskStats.get(key), currentVmDiskStats, endDateMillis);
                numAcctsProcessed++;
            }
            _usageVmDiskDao.saveUsageVmDisks(usageVmDisks);
            if (s_logger.isDebugEnabled()) {
                s_logger.debug("created vm disk stats helper entries for " + numAcctsProcessed + " accts");
            }
            // commit the helper records, then start a new transaction
            usageTxn.commit();
            usageTxn.start();
            boolean parsed = false;
            numAcctsProcessed = 0;
            Date currentStartDate = startDate;
            Date currentEndDate = endDate;
            Date tempDate = endDate;
            Calendar aggregateCal = Calendar.getInstance(_usageTimezone);
            while ((tempDate.after(startDate)) && ((tempDate.getTime() - startDate.getTime()) > 60000)) {
                currentEndDate = tempDate;
                aggregateCal.setTime(tempDate);
                aggregateCal.add(Calendar.MINUTE, -_aggregationDuration);
                tempDate = aggregateCal.getTime();
            }
            while (!currentEndDate.after(endDate) || (currentEndDate.getTime() - endDate.getTime() < 60000)) {
                Long offset = Long.valueOf(0);
                Long limit = Long.valueOf(500);
                do {
                    Filter filter = new Filter(AccountVO.class, "id", true, offset, limit);
                    accounts = _accountDao.listAll(filter);
                    if ((accounts != null) && !accounts.isEmpty()) {
                        for (AccountVO account : accounts) {
                            parsed = parseHelperTables(account, currentStartDate, currentEndDate);
                            numAcctsProcessed++;
                        }
                    }
                    offset = new Long(offset.longValue() + limit.longValue());
                } while ((accounts != null) && !accounts.isEmpty());
                if (s_logger.isDebugEnabled()) {
                    s_logger.debug("processed VM/Network Usage for " + numAcctsProcessed + " ACTIVE accts");
                }
                numAcctsProcessed = 0;
                // reset offset
                offset = Long.valueOf(0);
                do {
                    Filter filter = new Filter(AccountVO.class, "id", true, offset, limit);
                    accounts = _accountDao.findRecentlyDeletedAccounts(null, recentlyDeletedDate, filter);
                    if ((accounts != null) && !accounts.isEmpty()) {
                        for (AccountVO account : accounts) {
                            parsed = parseHelperTables(account, currentStartDate, currentEndDate);
                            List<Long> publicTemplates = _usageDao.listPublicTemplatesByAccount(account.getId());
                            for (Long templateId : publicTemplates) {
                                //mark public templates owned by deleted accounts as deleted
                                List<UsageStorageVO> storageVOs = _usageStorageDao.listById(account.getId(), templateId, StorageTypes.TEMPLATE);
                                if (storageVOs.size() > 1) {
                                    s_logger.warn("More that one usage entry for storage: " + templateId + " assigned to account: " + account.getId() + "; marking them all as deleted...");
                                }
                                for (UsageStorageVO storageVO : storageVOs) {
                                    if (s_logger.isDebugEnabled()) {
                                        s_logger.debug("deleting template: " + storageVO.getId() + " from account: " + storageVO.getAccountId());
                                    }
                                    storageVO.setDeleted(account.getRemoved());
                                    _usageStorageDao.update(storageVO);
                                }
                            }
                            numAcctsProcessed++;
                        }
                    }
                    offset = new Long(offset.longValue() + limit.longValue());
                } while ((accounts != null) && !accounts.isEmpty());
                currentStartDate = new Date(currentEndDate.getTime() + 1);
                aggregateCal.setTime(currentEndDate);
                aggregateCal.add(Calendar.MINUTE, _aggregationDuration);
                currentEndDate = aggregateCal.getTime();
            }
            if (s_logger.isDebugEnabled()) {
                s_logger.debug("processed Usage for " + numAcctsProcessed + " RECENTLY DELETED accts");
            }
            //        do we want to break out of processing accounts and rollback if there are errors?
            if (!parsed) {
                usageTxn.rollback();
            } else {
                success = true;
            }
        } catch (Exception ex) {
            s_logger.error("Exception in usage manager", ex);
            usageTxn.rollback();
        } finally {
            // everything seemed to work...set endDate as the last success date
            _usageJobDao.updateJobSuccess(job.getId(), startDateMillis, endDateMillis, System.currentTimeMillis() - timeStart, success);
            // create a new job if this is a recurring job
            if (job.getJobType() == UsageJobVO.JOB_TYPE_RECURRING) {
                _usageJobDao.createNewJob(_hostname, _pid, UsageJobVO.JOB_TYPE_RECURRING);
            }
            usageTxn.commit();
            usageTxn.close();
            // switch back to CLOUD_DB
            TransactionLegacy swap = TransactionLegacy.open(TransactionLegacy.CLOUD_DB);
            if (!success) {
                _alertMgr.sendAlert(AlertManager.AlertType.ALERT_TYPE_USAGE_SERVER_RESULT, 0, new Long(0), "Usage job failed. Job id: " + job.getId(), "Usage job failed. Job id: " + job.getId());
            } else {
                _alertMgr.clearAlert(AlertManager.AlertType.ALERT_TYPE_USAGE_SERVER_RESULT, 0, 0);
            }
            swap.close();
        }
    } catch (Exception e) {
        s_logger.error("Usage Manager error", e);
    }
}
Also used : HashMap(java.util.HashMap) UsageEventVO(com.cloud.event.UsageEventVO) AccountVO(com.cloud.user.AccountVO) Calendar(java.util.Calendar) VmDiskStatisticsVO(com.cloud.user.VmDiskStatisticsVO) Date(java.util.Date) ConfigurationException(javax.naming.ConfigurationException) SQLException(java.sql.SQLException) TransactionLegacy(com.cloud.utils.db.TransactionLegacy) Filter(com.cloud.utils.db.Filter) UserStatisticsVO(com.cloud.user.UserStatisticsVO)

Example 13 with UsageEventVO

use of com.cloud.event.UsageEventVO in project cloudstack by apache.

the class BareMetalTemplateAdapter method delete.

@Override
@DB
public boolean delete(TemplateProfile profile) {
    VMTemplateVO template = profile.getTemplate();
    Long templateId = template.getId();
    boolean success = true;
    String zoneName;
    if (!template.isCrossZones() && profile.getZoneId() != null) {
        zoneName = profile.getZoneId().toString();
    } else {
        zoneName = "all zones";
    }
    s_logger.debug("Attempting to mark template host refs for template: " + template.getName() + " as destroyed in zone: " + zoneName);
    Account account = _accountDao.findByIdIncludingRemoved(template.getAccountId());
    String eventType = EventTypes.EVENT_TEMPLATE_DELETE;
    List<TemplateDataStoreVO> templateHostVOs = this._tmpltStoreDao.listByTemplate(templateId);
    for (TemplateDataStoreVO vo : templateHostVOs) {
        TemplateDataStoreVO lock = null;
        try {
            lock = _tmpltStoreDao.acquireInLockTable(vo.getId());
            if (lock == null) {
                s_logger.debug("Failed to acquire lock when deleting templateDataStoreVO with ID: " + vo.getId());
                success = false;
                break;
            }
            vo.setDestroyed(true);
            _tmpltStoreDao.update(vo.getId(), vo);
        } finally {
            if (lock != null) {
                _tmpltStoreDao.releaseFromLockTable(lock.getId());
            }
        }
    }
    if (profile.getZoneId() != null) {
        UsageEventVO usageEvent = new UsageEventVO(eventType, account.getId(), profile.getZoneId(), templateId, null);
        _usageEventDao.persist(usageEvent);
    } else {
        List<DataCenterVO> dcs = _dcDao.listAllIncludingRemoved();
        for (DataCenterVO dc : dcs) {
            UsageEventVO usageEvent = new UsageEventVO(eventType, account.getId(), dc.getId(), templateId, null);
            _usageEventDao.persist(usageEvent);
        }
    }
    VMTemplateZoneVO templateZone = _tmpltZoneDao.findByZoneTemplate(profile.getZoneId(), templateId);
    if (templateZone != null) {
        _tmpltZoneDao.remove(templateZone.getId());
    }
    s_logger.debug("Successfully marked template host refs for template: " + template.getName() + " as destroyed in zone: " + zoneName);
    // If there are no more non-destroyed template host entries for this template, delete it
    if (success && (_tmpltStoreDao.listByTemplate(templateId).size() == 0)) {
        long accountId = template.getAccountId();
        VMTemplateVO lock = _tmpltDao.acquireInLockTable(templateId);
        try {
            if (lock == null) {
                s_logger.debug("Failed to acquire lock when deleting template with ID: " + templateId);
                success = false;
            } else if (_tmpltDao.remove(templateId)) {
                // Decrement the number of templates and total secondary storage space used by the account.
                _resourceLimitMgr.decrementResourceCount(accountId, ResourceType.template);
                _resourceLimitMgr.recalculateResourceCount(accountId, template.getDomainId(), ResourceType.secondary_storage.getOrdinal());
            }
        } finally {
            if (lock != null) {
                _tmpltDao.releaseFromLockTable(lock.getId());
            }
        }
        s_logger.debug("Removed template: " + template.getName() + " because all of its template host refs were marked as destroyed.");
    }
    return success;
}
Also used : DataCenterVO(com.cloud.dc.DataCenterVO) Account(com.cloud.user.Account) VMTemplateZoneVO(com.cloud.storage.VMTemplateZoneVO) VMTemplateVO(com.cloud.storage.VMTemplateVO) UsageEventVO(com.cloud.event.UsageEventVO) TemplateDataStoreVO(org.apache.cloudstack.storage.datastore.db.TemplateDataStoreVO) DB(com.cloud.utils.db.DB)

Example 14 with UsageEventVO

use of com.cloud.event.UsageEventVO in project cloudstack by apache.

the class UsageEventDaoImpl method listDirectIpEvents.

@Override
public List<UsageEventVO> listDirectIpEvents(Date startDate, Date endDate, long zoneId) {
    Filter filter = new Filter(UsageEventVO.class, "createDate", Boolean.TRUE, null, null);
    SearchCriteria<UsageEventVO> sc = IpeventsSearch.create();
    sc.setParameters("startdate", startDate);
    sc.setParameters("enddate", endDate);
    sc.setParameters("assignEvent", EventTypes.EVENT_NET_IP_ASSIGN);
    sc.setParameters("releaseEvent", EventTypes.EVENT_NET_IP_RELEASE);
    sc.setParameters("zoneid", zoneId);
    sc.setParameters("networktype", Vlan.VlanType.DirectAttached.toString());
    return listBy(sc, filter);
}
Also used : Filter(com.cloud.utils.db.Filter) UsageEventVO(com.cloud.event.UsageEventVO)

Example 15 with UsageEventVO

use of com.cloud.event.UsageEventVO in project cloudstack by apache.

the class Upgrade218to22 method convertEvent.

private void convertEvent(EventVO event, Connection conn) throws IOException, SQLException {
    // the event didn't happen, so it couldn't result in usage
    if (!EventVO.LEVEL_INFO.equals(event.getLevel())) {
        return;
    }
    String eventType = event.getType();
    UsageEventVO usageEvent = null;
    if (isVMEvent(eventType)) {
        usageEvent = convertVMEvent(event);
    } else if (isIPEvent(eventType)) {
        usageEvent = convertIPEvent(event, conn);
    } else if (isVolumeEvent(eventType)) {
        usageEvent = convertVolumeEvent(event, conn);
    } else if (isTemplateEvent(eventType)) {
        usageEvent = convertTemplateEvent(event);
    } else if (isISOEvent(eventType)) {
        usageEvent = convertISOEvent(event);
    } else if (isSnapshotEvent(eventType)) {
        usageEvent = convertSnapshotEvent(event, conn);
    }
    /*
           * else if (isSecurityGrpEvent(eventType)) { usageEvent = convertSecurityGrpEvent(event); } else if
           * (isLoadBalancerEvent(eventType)) { usageEvent = convertLoadBalancerEvent(event); }
           */
    if (usageEvent != null) {
        usageEvent.setCreatedDate(event.getCreateDate());
        if (usageEvent.getZoneId() == -1) {
            usageEvent.setZoneId(0);
        }
        // update firewall_rules table
        try (PreparedStatement pstmt = conn.prepareStatement("INSERT INTO usage_event (usage_event.type, usage_event.created, usage_event.account_id, usage_event.zone_id, usage_event.resource_id, usage_event.resource_name," + " usage_event.offering_id, usage_event.template_id, usage_event.size) VALUES (?, ?, ?, ?, ?, ?, ?, ?, ?)")) {
            pstmt.setString(1, usageEvent.getType());
            pstmt.setString(2, DateUtil.getDateDisplayString(TimeZone.getTimeZone("GMT"), usageEvent.getCreateDate()));
            pstmt.setLong(3, usageEvent.getAccountId());
            pstmt.setLong(4, usageEvent.getZoneId());
            pstmt.setLong(5, usageEvent.getResourceId());
            pstmt.setString(6, usageEvent.getResourceName());
            if (usageEvent.getOfferingId() != null) {
                pstmt.setLong(7, usageEvent.getOfferingId());
            } else {
                pstmt.setNull(7, Types.BIGINT);
            }
            if (usageEvent.getTemplateId() != null) {
                pstmt.setLong(8, usageEvent.getTemplateId());
            } else {
                pstmt.setNull(8, Types.BIGINT);
            }
            if (usageEvent.getSize() != null) {
                pstmt.setLong(9, usageEvent.getSize());
            } else {
                pstmt.setNull(9, Types.BIGINT);
            }
            // pstmt.setString(10, usageEvent.getResourceType());
            pstmt.executeUpdate();
        }
    }
}
Also used : UsageEventVO(com.cloud.event.UsageEventVO) PreparedStatement(java.sql.PreparedStatement)

Aggregations

UsageEventVO (com.cloud.event.UsageEventVO)17 StringReader (java.io.StringReader)6 Properties (java.util.Properties)6 Filter (com.cloud.utils.db.Filter)4 PreparedStatement (java.sql.PreparedStatement)4 VMTemplateVO (com.cloud.storage.VMTemplateVO)3 CloudRuntimeException (com.cloud.utils.exception.CloudRuntimeException)3 ResultSet (java.sql.ResultSet)3 Date (java.util.Date)3 HashMap (java.util.HashMap)3 ConfigurationException (javax.naming.ConfigurationException)3 TemplateDataStoreVO (org.apache.cloudstack.storage.datastore.db.TemplateDataStoreVO)3 VMTemplateZoneVO (com.cloud.storage.VMTemplateZoneVO)2 VolumeVO (com.cloud.storage.VolumeVO)2 Account (com.cloud.user.Account)2 AccountVO (com.cloud.user.AccountVO)2 UserStatisticsVO (com.cloud.user.UserStatisticsVO)2 DB (com.cloud.utils.db.DB)2 SQLException (java.sql.SQLException)2 Calendar (java.util.Calendar)2