blob: 241885669ba5c80271d8a5ada1eae0013949b9eb [file] [log] [blame]
// Copyright 2019 The Fuchsia Authors. All rights reserved.
// Use of this source code is governed by a BSD-style license that can be
// found in the LICENSE file.
#include "src/local_aggregation/event_aggregator_mgr.h"
#include "src/lib/util/datetime_util.h"
namespace cobalt::local_aggregation {
using logger::kOK;
using logger::Status;
using util::ConsistentProtoStore;
using util::TimeToDayIndex;
EventAggregatorManager::EventAggregatorManager(const logger::Encoder* encoder,
const logger::ObservationWriter* observation_writer,
ConsistentProtoStore* local_aggregate_proto_store,
ConsistentProtoStore* obs_history_proto_store,
const size_t backfill_days,
const std::chrono::seconds aggregate_backup_interval,
const std::chrono::seconds generate_obs_interval,
const std::chrono::seconds gc_interval)
: backfill_days_(backfill_days),
aggregate_backup_interval_(aggregate_backup_interval),
generate_obs_interval_(generate_obs_interval),
gc_interval_(gc_interval) {
aggregate_store_ =
std::make_unique<AggregateStore>(encoder, observation_writer, local_aggregate_proto_store,
obs_history_proto_store, backfill_days);
event_aggregator_ = std::make_unique<EventAggregator>(aggregate_store_.get());
}
void EventAggregatorManager::Start(std::unique_ptr<util::SystemClockInterface> clock) {
auto locked = protected_worker_thread_controller_.lock();
locked->shut_down = false;
std::thread t(std::bind(
[this](std::unique_ptr<util::SystemClockInterface>& clock) { this->Run(std::move(clock)); },
std::move(clock)));
worker_thread_ = std::move(t);
}
void EventAggregatorManager::ShutDown() {
if (worker_thread_.joinable()) {
{
auto locked = protected_worker_thread_controller_.lock();
locked->shut_down = true;
locked->shutdown_notifier.notify_all();
}
worker_thread_.join();
} else {
protected_worker_thread_controller_.lock()->shut_down = true;
}
}
void EventAggregatorManager::Run(std::unique_ptr<util::SystemClockInterface> system_clock) {
std::chrono::steady_clock::time_point steady_time = steady_clock_->now();
// Schedule Observation generation to happen in the first cycle.
next_generate_obs_ = steady_time;
// Schedule garbage collection to happen |gc_interval_| seconds from now.
next_gc_ = steady_time + gc_interval_;
// Acquire the mutex protecting the shutdown flag and condition variable.
auto locked = protected_worker_thread_controller_.lock();
while (true) {
// If shutdown has been requested, back up the LocalAggregateStore and
// exit.
if (locked->shut_down) {
aggregate_store_->BackUpLocalAggregateStore();
return;
}
// Sleep until the next scheduled backup of the LocalAggregateStore or
// until notified of shutdown. Back up the LocalAggregateStore after
// waking.
locked->shutdown_notifier.wait_for(locked, aggregate_backup_interval_, [&locked]() {
if (locked->immediate_run_trigger) {
locked->immediate_run_trigger = false;
return true;
}
return locked->shut_down;
});
aggregate_store_->BackUpLocalAggregateStore();
// If the worker thread was woken up by a shutdown request, exit.
// Otherwise, complete any scheduled Observation generation and garbage
// collection.
if (locked->shut_down) {
return;
}
// Check whether it is time to generate Observations or to garbage-collect
// the LocalAggregate store. If so, do that task and schedule the next
// occurrence.
DoScheduledTasks(system_clock->now(), steady_clock_->now());
}
}
void EventAggregatorManager::DoScheduledTasks(std::chrono::system_clock::time_point system_time,
std::chrono::steady_clock::time_point steady_time) {
auto current_time_t = std::chrono::system_clock::to_time_t(system_time);
auto yesterday_utc = TimeToDayIndex(current_time_t, MetricDefinition::UTC) - 1;
auto yesterday_local_time = TimeToDayIndex(current_time_t, MetricDefinition::LOCAL) - 1;
// Skip the tasks (but do schedule a retry) if either day index is too small.
uint32_t min_allowed_day_index = kMaxAllowedAggregationDays + backfill_days_;
bool skip_tasks =
(yesterday_utc < min_allowed_day_index || yesterday_local_time < min_allowed_day_index);
if (steady_time >= next_generate_obs_) {
next_generate_obs_ += generate_obs_interval_;
if (skip_tasks) {
LOG_FIRST_N(ERROR, 10) << "EventAggregator is skipping Observation generation because the "
"current day index is too small.";
} else {
auto obs_status = aggregate_store_->GenerateObservations(yesterday_utc, yesterday_local_time);
if (obs_status == kOK) {
aggregate_store_->BackUpObservationHistory();
} else {
LOG(ERROR) << "GenerateObservations failed with status: " << obs_status;
}
}
}
if (steady_time >= next_gc_) {
next_gc_ += gc_interval_;
if (skip_tasks) {
LOG_FIRST_N(ERROR, 10) << "EventAggregator is skipping garbage collection because the "
"current day index is too small.";
} else {
auto gc_status = aggregate_store_->GarbageCollect(yesterday_utc, yesterday_local_time);
if (gc_status == kOK) {
aggregate_store_->BackUpLocalAggregateStore();
} else {
LOG(ERROR) << "GarbageCollect failed with status: " << gc_status;
}
}
}
}
} // namespace cobalt::local_aggregation