366 lines
12 KiB
C++
366 lines
12 KiB
C++
//
|
|
// Copyright Aliaksei Levin (levlam@telegram.org), Arseny Smirnov (arseny30@gmail.com) 2014-2021
|
|
//
|
|
// Distributed under the Boost Software License, Version 1.0. (See accompanying
|
|
// file LICENSE_1_0.txt or copy at http://www.boost.org/LICENSE_1_0.txt)
|
|
//
|
|
#pragma once
|
|
|
|
#include "td/actor/impl/ActorInfo-decl.h"
|
|
#include "td/actor/impl/Scheduler-decl.h"
|
|
|
|
#include "td/utils/common.h"
|
|
#include "td/utils/Heap.h"
|
|
#include "td/utils/logging.h"
|
|
#include "td/utils/ObjectPool.h"
|
|
#include "td/utils/port/detail/PollableFd.h"
|
|
#include "td/utils/port/PollFlags.h"
|
|
#include "td/utils/Slice.h"
|
|
#include "td/utils/Time.h"
|
|
|
|
#include <atomic>
|
|
#include <tuple>
|
|
#include <utility>
|
|
|
|
namespace td {
|
|
|
|
/*** EventGuard ***/
|
|
class EventGuard {
|
|
public:
|
|
EventGuard(Scheduler *scheduler, ActorInfo *actor_info);
|
|
|
|
bool can_run() const {
|
|
return event_context_.flags == 0;
|
|
}
|
|
|
|
EventGuard(const EventGuard &other) = delete;
|
|
EventGuard &operator=(const EventGuard &other) = delete;
|
|
EventGuard(EventGuard &&other) = delete;
|
|
EventGuard &operator=(EventGuard &&other) = delete;
|
|
~EventGuard();
|
|
|
|
private:
|
|
Scheduler::EventContext event_context_;
|
|
Scheduler::EventContext *event_context_ptr_;
|
|
Scheduler *scheduler_;
|
|
ActorContext *save_context_;
|
|
const char *save_log_tag2_;
|
|
|
|
void swap_context(ActorInfo *info);
|
|
};
|
|
|
|
/*** Scheduler ***/
|
|
inline SchedulerGuard Scheduler::get_guard() {
|
|
return SchedulerGuard(this);
|
|
}
|
|
inline SchedulerGuard Scheduler::get_const_guard() {
|
|
return SchedulerGuard(this, false);
|
|
}
|
|
|
|
inline void Scheduler::init() {
|
|
init(0, {}, nullptr);
|
|
}
|
|
|
|
inline int32 Scheduler::sched_id() const {
|
|
return sched_id_;
|
|
}
|
|
inline int32 Scheduler::sched_count() const {
|
|
return sched_n_;
|
|
}
|
|
|
|
template <class ActorT, class... Args>
|
|
ActorOwn<ActorT> Scheduler::create_actor(Slice name, Args &&... args) {
|
|
return register_actor_impl(name, new ActorT(std::forward<Args>(args)...), Actor::Deleter::Destroy, sched_id_);
|
|
}
|
|
|
|
template <class ActorT, class... Args>
|
|
ActorOwn<ActorT> Scheduler::create_actor_on_scheduler(Slice name, int32 sched_id, Args &&... args) {
|
|
return register_actor_impl(name, new ActorT(std::forward<Args>(args)...), Actor::Deleter::Destroy, sched_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> Scheduler::register_actor(Slice name, ActorT *actor_ptr, int32 sched_id) {
|
|
return register_actor_impl(name, actor_ptr, Actor::Deleter::None, sched_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> Scheduler::register_actor(Slice name, unique_ptr<ActorT> actor_ptr, int32 sched_id) {
|
|
return register_actor_impl(name, actor_ptr.release(), Actor::Deleter::Destroy, sched_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> Scheduler::register_actor_impl(Slice name, ActorT *actor_ptr, Actor::Deleter deleter, int32 sched_id) {
|
|
CHECK(has_guard_);
|
|
if (sched_id == -1) {
|
|
sched_id = sched_id_;
|
|
}
|
|
#if TD_THREAD_UNSUPPORTED || TD_EVENTFD_UNSUPPORTED
|
|
sched_id = 0;
|
|
#endif
|
|
LOG_CHECK(sched_id == sched_id_ || (0 <= sched_id && sched_id < static_cast<int32>(outbound_queues_.size())))
|
|
<< sched_id;
|
|
auto info = actor_info_pool_->create_empty();
|
|
actor_count_++;
|
|
auto weak_info = info.get_weak();
|
|
auto actor_info = info.get();
|
|
actor_info->init(sched_id_, name, std::move(info), static_cast<Actor *>(actor_ptr), deleter,
|
|
ActorTraits<ActorT>::need_context, ActorTraits<ActorT>::need_start_up);
|
|
VLOG(actor) << "Create actor " << *actor_info << " (actor_count = " << actor_count_ << ')';
|
|
|
|
ActorId<ActorT> actor_id = weak_info->actor_id(actor_ptr);
|
|
if (sched_id != sched_id_) {
|
|
send<ActorSendType::LaterWeak>(actor_id, Event::start());
|
|
do_migrate_actor(actor_info, sched_id);
|
|
} else {
|
|
pending_actors_list_.put(weak_info->get_list_node());
|
|
if (ActorTraits<ActorT>::need_start_up) {
|
|
send<ActorSendType::LaterWeak>(actor_id, Event::start());
|
|
}
|
|
}
|
|
|
|
return ActorOwn<ActorT>(actor_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> Scheduler::register_existing_actor(unique_ptr<ActorT> actor_ptr) {
|
|
CHECK(!actor_ptr->empty());
|
|
auto actor_info = actor_ptr->get_info();
|
|
CHECK(actor_info->migrate_dest_flag_atomic().first == sched_id_);
|
|
return actor_info->transfer_ownership_to_scheduler(std::move(actor_ptr));
|
|
}
|
|
|
|
inline void Scheduler::destroy_actor(ActorInfo *actor_info) {
|
|
VLOG(actor) << "Destroy actor " << *actor_info << " (actor_count = " << actor_count_ << ')';
|
|
|
|
LOG_CHECK(actor_info->migrate_dest() == sched_id_) << actor_info->migrate_dest() << " " << sched_id_;
|
|
cancel_actor_timeout(actor_info);
|
|
actor_info->get_list_node()->remove();
|
|
// called by ObjectPool
|
|
// actor_info->clear();
|
|
actor_count_--;
|
|
CHECK(actor_count_ >= 0);
|
|
}
|
|
|
|
template <class RunFuncT, class EventFuncT>
|
|
void Scheduler::flush_mailbox(ActorInfo *actor_info, const RunFuncT &run_func, const EventFuncT &event_func) {
|
|
auto &mailbox = actor_info->mailbox_;
|
|
size_t mailbox_size = mailbox.size();
|
|
CHECK(mailbox_size != 0);
|
|
EventGuard guard(this, actor_info);
|
|
size_t i = 0;
|
|
for (; i < mailbox_size && guard.can_run(); i++) {
|
|
do_event(actor_info, std::move(mailbox[i]));
|
|
}
|
|
if (run_func) {
|
|
if (guard.can_run()) {
|
|
(*run_func)(actor_info);
|
|
} else {
|
|
mailbox.insert(mailbox.begin() + i, (*event_func)());
|
|
}
|
|
}
|
|
mailbox.erase(mailbox.begin(), mailbox.begin() + i);
|
|
}
|
|
|
|
inline void Scheduler::send_to_scheduler(int32 sched_id, const ActorId<> &actor_id, Event &&event) {
|
|
if (sched_id == sched_id_) {
|
|
ActorInfo *actor_info = actor_id.get_actor_info();
|
|
pending_events_[actor_info].push_back(std::move(event));
|
|
} else {
|
|
send_to_other_scheduler(sched_id, actor_id, std::move(event));
|
|
}
|
|
}
|
|
|
|
inline void Scheduler::before_tail_send(const ActorId<> &actor_id) {
|
|
// TODO
|
|
}
|
|
|
|
inline void Scheduler::inc_wait_generation() {
|
|
wait_generation_ += 2;
|
|
}
|
|
|
|
template <ActorSendType send_type, class RunFuncT, class EventFuncT>
|
|
void Scheduler::send_impl(const ActorId<> &actor_id, const RunFuncT &run_func, const EventFuncT &event_func) {
|
|
ActorInfo *actor_info = actor_id.get_actor_info();
|
|
if (unlikely(actor_info == nullptr || close_flag_)) {
|
|
return;
|
|
}
|
|
|
|
CHECK(actor_info != nullptr);
|
|
int32 actor_sched_id;
|
|
bool is_migrating;
|
|
std::tie(actor_sched_id, is_migrating) = actor_info->migrate_dest_flag_atomic();
|
|
bool on_current_sched = !is_migrating && sched_id_ == actor_sched_id;
|
|
CHECK(has_guard_ || !on_current_sched);
|
|
|
|
if (likely(send_type == ActorSendType::Immediate && on_current_sched && !actor_info->is_running() &&
|
|
!actor_info->must_wait(wait_generation_))) { // run immediately
|
|
if (likely(actor_info->mailbox_.empty())) {
|
|
EventGuard guard(this, actor_info);
|
|
run_func(actor_info);
|
|
} else {
|
|
flush_mailbox(actor_info, &run_func, &event_func);
|
|
}
|
|
} else {
|
|
if (on_current_sched) {
|
|
add_to_mailbox(actor_info, event_func());
|
|
if (send_type == ActorSendType::Later) {
|
|
actor_info->set_wait_generation(wait_generation_);
|
|
}
|
|
} else {
|
|
send_to_scheduler(actor_sched_id, actor_id, event_func());
|
|
}
|
|
}
|
|
}
|
|
|
|
template <ActorSendType send_type, class EventT>
|
|
void Scheduler::send_lambda(ActorRef actor_ref, EventT &&lambda) {
|
|
return send_impl<send_type>(
|
|
actor_ref.get(),
|
|
[&](ActorInfo *actor_info) {
|
|
event_context_ptr_->link_token = actor_ref.token();
|
|
lambda();
|
|
},
|
|
[&] {
|
|
auto event = Event::lambda(std::forward<EventT>(lambda));
|
|
event.set_link_token(actor_ref.token());
|
|
return event;
|
|
});
|
|
}
|
|
|
|
template <ActorSendType send_type, class EventT>
|
|
void Scheduler::send_closure(ActorRef actor_ref, EventT &&closure) {
|
|
return send_impl<send_type>(
|
|
actor_ref.get(),
|
|
[&](ActorInfo *actor_info) {
|
|
event_context_ptr_->link_token = actor_ref.token();
|
|
closure.run(static_cast<typename EventT::ActorType *>(actor_info->get_actor_unsafe()));
|
|
},
|
|
[&] {
|
|
auto event = Event::immediate_closure(std::forward<EventT>(closure));
|
|
event.set_link_token(actor_ref.token());
|
|
return event;
|
|
});
|
|
}
|
|
|
|
template <ActorSendType send_type>
|
|
void Scheduler::send(ActorRef actor_ref, Event &&event) {
|
|
event.set_link_token(actor_ref.token());
|
|
return send_impl<send_type>(
|
|
actor_ref.get(), [&](ActorInfo *actor_info) { do_event(actor_info, std::move(event)); },
|
|
[&] { return std::move(event); });
|
|
}
|
|
|
|
inline void Scheduler::subscribe(PollableFd fd, PollFlags flags) {
|
|
instance()->poll_.subscribe(std::move(fd), flags);
|
|
}
|
|
|
|
inline void Scheduler::unsubscribe(PollableFdRef fd) {
|
|
instance()->poll_.unsubscribe(std::move(fd));
|
|
}
|
|
|
|
inline void Scheduler::unsubscribe_before_close(PollableFdRef fd) {
|
|
instance()->poll_.unsubscribe_before_close(std::move(fd));
|
|
}
|
|
|
|
inline void Scheduler::yield_actor(Actor *actor) {
|
|
yield_actor(actor->get_info());
|
|
}
|
|
inline void Scheduler::yield_actor(ActorInfo *actor_info) {
|
|
send<ActorSendType::LaterWeak>(actor_info->actor_id(), Event::yield());
|
|
}
|
|
|
|
inline void Scheduler::stop_actor(Actor *actor) {
|
|
stop_actor(actor->get_info());
|
|
}
|
|
inline void Scheduler::stop_actor(ActorInfo *actor_info) {
|
|
CHECK(event_context_ptr_->actor_info == actor_info);
|
|
event_context_ptr_->flags |= EventContext::Stop;
|
|
}
|
|
|
|
inline uint64 Scheduler::get_link_token(Actor *actor) {
|
|
return get_link_token(actor->get_info());
|
|
}
|
|
inline uint64 Scheduler::get_link_token(ActorInfo *actor_info) {
|
|
LOG_CHECK(event_context_ptr_->actor_info == actor_info) << actor_info->get_name();
|
|
return event_context_ptr_->link_token;
|
|
}
|
|
|
|
inline void Scheduler::finish_migrate_actor(Actor *actor) {
|
|
register_migrated_actor(actor->get_info());
|
|
}
|
|
|
|
inline double Scheduler::get_actor_timeout(const Actor *actor) const {
|
|
return get_actor_timeout(actor->get_info());
|
|
}
|
|
inline void Scheduler::set_actor_timeout_in(Actor *actor, double timeout) {
|
|
set_actor_timeout_in(actor->get_info(), timeout);
|
|
}
|
|
inline void Scheduler::set_actor_timeout_at(Actor *actor, double timeout_at) {
|
|
set_actor_timeout_at(actor->get_info(), timeout_at);
|
|
}
|
|
inline void Scheduler::cancel_actor_timeout(Actor *actor) {
|
|
cancel_actor_timeout(actor->get_info());
|
|
}
|
|
|
|
inline void Scheduler::cancel_actor_timeout(ActorInfo *actor_info) {
|
|
HeapNode *heap_node = actor_info->get_heap_node();
|
|
if (heap_node->in_heap()) {
|
|
timeout_queue_.erase(heap_node);
|
|
}
|
|
}
|
|
|
|
inline void Scheduler::finish() {
|
|
if (callback_) {
|
|
callback_->on_finish();
|
|
}
|
|
yield();
|
|
}
|
|
|
|
inline void Scheduler::yield() {
|
|
yield_flag_ = true;
|
|
}
|
|
|
|
inline void Scheduler::wakeup() {
|
|
std::atomic_thread_fence(std::memory_order_release);
|
|
#if !TD_THREAD_UNSUPPORTED && !TD_EVENTFD_UNSUPPORTED
|
|
inbound_queue_->writer_put({});
|
|
#endif
|
|
}
|
|
|
|
inline void Scheduler::run(Timestamp timeout) {
|
|
auto guard = get_guard();
|
|
run_no_guard(timeout);
|
|
}
|
|
|
|
/*** Interface to current scheduler ***/
|
|
template <class ActorT, class... Args>
|
|
ActorOwn<ActorT> create_actor(Slice name, Args &&... args) {
|
|
return Scheduler::instance()->create_actor<ActorT>(name, std::forward<Args>(args)...);
|
|
}
|
|
|
|
template <class ActorT, class... Args>
|
|
ActorOwn<ActorT> create_actor_on_scheduler(Slice name, int32 sched_id, Args &&... args) {
|
|
return Scheduler::instance()->create_actor_on_scheduler<ActorT>(name, sched_id, std::forward<Args>(args)...);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> register_actor(Slice name, ActorT *actor_ptr, int32 sched_id) {
|
|
return Scheduler::instance()->register_actor<ActorT>(name, actor_ptr, sched_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> register_actor(Slice name, unique_ptr<ActorT> actor_ptr, int32 sched_id) {
|
|
return Scheduler::instance()->register_actor<ActorT>(name, std::move(actor_ptr), sched_id);
|
|
}
|
|
|
|
template <class ActorT>
|
|
ActorOwn<ActorT> register_existing_actor(unique_ptr<ActorT> actor_ptr) {
|
|
return Scheduler::instance()->register_existing_actor(std::move(actor_ptr));
|
|
}
|
|
|
|
inline void yield_scheduler() {
|
|
Scheduler::instance()->yield();
|
|
}
|
|
|
|
} // namespace td
|