blob: 909698611e988fbeed8084f5b9a9da78d75dbec6 [file] [log] [blame]
tommic06b1332016-05-14 11:31:40 -07001/*
2 * Copyright 2016 The WebRTC Project Authors. All rights reserved.
3 *
4 * Use of this source code is governed by a BSD-style license
5 * that can be found in the LICENSE file in the root of the source
6 * tree. An additional intellectual property rights grant can be found
7 * in the file PATENTS. All contributing project authors may
8 * be found in the AUTHORS file in the root of the source tree.
9 */
10
Danil Chapovaloveb175242019-02-12 10:44:38 +010011#include "rtc_base/task_queue_libevent.h"
tommic06b1332016-05-14 11:31:40 -070012
Yves Gerey988cc082018-10-23 12:03:01 +020013#include <errno.h>
tommic06b1332016-05-14 11:31:40 -070014#include <fcntl.h>
Yves Gerey988cc082018-10-23 12:03:01 +020015#include <pthread.h>
tommi8c80c6e2017-02-23 00:34:52 -080016#include <signal.h>
Yves Gerey988cc082018-10-23 12:03:01 +020017#include <stdint.h>
18#include <time.h>
tommic06b1332016-05-14 11:31:40 -070019#include <unistd.h>
Jonas Olssona4d87372019-07-05 19:08:33 +020020
Danil Chapovalov02fddf62018-02-12 12:41:16 +010021#include <list>
Yves Gerey988cc082018-10-23 12:03:01 +020022#include <memory>
23#include <type_traits>
24#include <utility>
tommic06b1332016-05-14 11:31:40 -070025
Steve Anton9a83dd72020-01-09 11:03:25 -080026#include "absl/container/inlined_vector.h"
Danil Chapovaloveb175242019-02-12 10:44:38 +010027#include "absl/strings/string_view.h"
28#include "api/task_queue/queued_task.h"
29#include "api/task_queue/task_queue_base.h"
tommic06b1332016-05-14 11:31:40 -070030#include "base/third_party/libevent/event.h"
Mirko Bonadei92ea95e2017-09-15 06:47:31 +020031#include "rtc_base/checks.h"
32#include "rtc_base/logging.h"
Karl Wiberge40468b2017-11-22 10:42:26 +010033#include "rtc_base/numerics/safe_conversions.h"
Mirko Bonadei92ea95e2017-09-15 06:47:31 +020034#include "rtc_base/platform_thread.h"
Yves Gerey988cc082018-10-23 12:03:01 +020035#include "rtc_base/platform_thread_types.h"
Markus Handell18523c32020-07-08 17:55:58 +020036#include "rtc_base/synchronization/mutex.h"
Yves Gerey988cc082018-10-23 12:03:01 +020037#include "rtc_base/thread_annotations.h"
Steve Anton10542f22019-01-11 09:11:00 -080038#include "rtc_base/time_utils.h"
tommic06b1332016-05-14 11:31:40 -070039
Danil Chapovaloveb175242019-02-12 10:44:38 +010040namespace webrtc {
tommic06b1332016-05-14 11:31:40 -070041namespace {
Danil Chapovaloveb175242019-02-12 10:44:38 +010042constexpr char kQuit = 1;
Steve Anton9a83dd72020-01-09 11:03:25 -080043constexpr char kRunTasks = 2;
tommi8c80c6e2017-02-23 00:34:52 -080044
Danil Chapovaloveb175242019-02-12 10:44:38 +010045using Priority = TaskQueueFactory::Priority;
tommic9bb7912017-02-24 10:42:14 -080046
tommi8c80c6e2017-02-23 00:34:52 -080047// This ignores the SIGPIPE signal on the calling thread.
48// This signal can be fired when trying to write() to a pipe that's being
49// closed or while closing a pipe that's being written to.
Danil Chapovalov43f39822018-12-05 15:46:58 +010050// We can run into that situation so we ignore this signal and continue as
51// normal.
tommi8c80c6e2017-02-23 00:34:52 -080052// As a side note for this implementation, it would be great if we could safely
53// restore the sigmask, but unfortunately the operation of restoring it, can
54// itself actually cause SIGPIPE to be signaled :-| (e.g. on MacOS)
55// The SIGPIPE signal by default causes the process to be terminated, so we
56// don't want to risk that.
57// An alternative to this approach is to ignore the signal for the whole
58// process:
59// signal(SIGPIPE, SIG_IGN);
60void IgnoreSigPipeSignalOnCurrentThread() {
61 sigset_t sigpipe_mask;
62 sigemptyset(&sigpipe_mask);
63 sigaddset(&sigpipe_mask, SIGPIPE);
64 pthread_sigmask(SIG_BLOCK, &sigpipe_mask, nullptr);
65}
tommic06b1332016-05-14 11:31:40 -070066
tommic06b1332016-05-14 11:31:40 -070067bool SetNonBlocking(int fd) {
68 const int flags = fcntl(fd, F_GETFL);
69 RTC_CHECK(flags != -1);
70 return (flags & O_NONBLOCK) || fcntl(fd, F_SETFL, flags | O_NONBLOCK) != -1;
71}
tommi1666b612016-07-13 10:58:12 -070072
73// TODO(tommi): This is a hack to support two versions of libevent that we're
74// compatible with. The method we really want to call is event_assign(),
75// since event_set() has been marked as deprecated (and doesn't accept
76// passing event_base__ as a parameter). However, the version of libevent
77// that we have in Chromium, doesn't have event_assign(), so we need to call
78// event_set() there.
79void EventAssign(struct event* ev,
80 struct event_base* base,
81 int fd,
82 short events,
83 void (*callback)(int, short, void*),
84 void* arg) {
85#if defined(_EVENT2_EVENT_H_)
86 RTC_CHECK_EQ(0, event_assign(ev, base, fd, events, callback, arg));
87#else
88 event_set(ev, fd, events, callback, arg);
89 RTC_CHECK_EQ(0, event_base_set(base, ev));
90#endif
91}
tommic9bb7912017-02-24 10:42:14 -080092
Danil Chapovaloveb175242019-02-12 10:44:38 +010093rtc::ThreadPriority TaskQueuePriorityToThreadPriority(Priority priority) {
tommic9bb7912017-02-24 10:42:14 -080094 switch (priority) {
95 case Priority::HIGH:
Markus Handellad5037b2021-05-07 15:02:36 +020096 return rtc::ThreadPriority::kRealtime;
tommic9bb7912017-02-24 10:42:14 -080097 case Priority::LOW:
Markus Handellad5037b2021-05-07 15:02:36 +020098 return rtc::ThreadPriority::kLow;
tommic9bb7912017-02-24 10:42:14 -080099 case Priority::NORMAL:
Markus Handellad5037b2021-05-07 15:02:36 +0200100 return rtc::ThreadPriority::kNormal;
tommic9bb7912017-02-24 10:42:14 -0800101 }
tommic9bb7912017-02-24 10:42:14 -0800102}
tommic06b1332016-05-14 11:31:40 -0700103
Danil Chapovaloveb175242019-02-12 10:44:38 +0100104class TaskQueueLibevent final : public TaskQueueBase {
perkj650fdae2017-08-25 05:00:11 -0700105 public:
Danil Chapovaloveb175242019-02-12 10:44:38 +0100106 TaskQueueLibevent(absl::string_view queue_name, rtc::ThreadPriority priority);
perkj650fdae2017-08-25 05:00:11 -0700107
Danil Chapovaloveb175242019-02-12 10:44:38 +0100108 void Delete() override;
109 void PostTask(std::unique_ptr<QueuedTask> task) override;
110 void PostDelayedTask(std::unique_ptr<QueuedTask> task,
111 uint32_t milliseconds) override;
perkj650fdae2017-08-25 05:00:11 -0700112
113 private:
Danil Chapovaloveb175242019-02-12 10:44:38 +0100114 class SetTimerTask;
115 struct TimerEvent;
116
117 ~TaskQueueLibevent() override = default;
118
perkj650fdae2017-08-25 05:00:11 -0700119 static void OnWakeup(int socket, short flags, void* context); // NOLINT
perkj650fdae2017-08-25 05:00:11 -0700120 static void RunTimer(int fd, short flags, void* context); // NOLINT
121
Danil Chapovaloveb175242019-02-12 10:44:38 +0100122 bool is_active_ = true;
perkj650fdae2017-08-25 05:00:11 -0700123 int wakeup_pipe_in_ = -1;
124 int wakeup_pipe_out_ = -1;
125 event_base* event_base_;
Danil Chapovaloveb175242019-02-12 10:44:38 +0100126 event wakeup_event_;
127 rtc::PlatformThread thread_;
Markus Handell18523c32020-07-08 17:55:58 +0200128 Mutex pending_lock_;
Steve Anton9a83dd72020-01-09 11:03:25 -0800129 absl::InlinedVector<std::unique_ptr<QueuedTask>, 4> pending_
130 RTC_GUARDED_BY(pending_lock_);
tommic06b1332016-05-14 11:31:40 -0700131 // Holds a list of events pending timers for cleanup when the loop exits.
132 std::list<TimerEvent*> pending_timers_;
133};
134
Danil Chapovaloveb175242019-02-12 10:44:38 +0100135struct TaskQueueLibevent::TimerEvent {
136 TimerEvent(TaskQueueLibevent* task_queue, std::unique_ptr<QueuedTask> task)
137 : task_queue(task_queue), task(std::move(task)) {}
138 ~TimerEvent() { event_del(&ev); }
139
140 event ev;
141 TaskQueueLibevent* task_queue;
142 std::unique_ptr<QueuedTask> task;
143};
144
145class TaskQueueLibevent::SetTimerTask : public QueuedTask {
tommic06b1332016-05-14 11:31:40 -0700146 public:
147 SetTimerTask(std::unique_ptr<QueuedTask> task, uint32_t milliseconds)
148 : task_(std::move(task)),
149 milliseconds_(milliseconds),
Danil Chapovaloveb175242019-02-12 10:44:38 +0100150 posted_(rtc::Time32()) {}
tommic06b1332016-05-14 11:31:40 -0700151
152 private:
153 bool Run() override {
154 // Compensate for the time that has passed since construction
155 // and until we got here.
Danil Chapovaloveb175242019-02-12 10:44:38 +0100156 uint32_t post_time = rtc::Time32() - posted_;
157 TaskQueueLibevent::Current()->PostDelayedTask(
tommic06b1332016-05-14 11:31:40 -0700158 std::move(task_),
159 post_time > milliseconds_ ? 0 : milliseconds_ - post_time);
160 return true;
161 }
162
163 std::unique_ptr<QueuedTask> task_;
164 const uint32_t milliseconds_;
165 const uint32_t posted_;
166};
167
Danil Chapovaloveb175242019-02-12 10:44:38 +0100168TaskQueueLibevent::TaskQueueLibevent(absl::string_view queue_name,
169 rtc::ThreadPriority priority)
Markus Handellad5037b2021-05-07 15:02:36 +0200170 : event_base_(event_base_new()) {
tommic06b1332016-05-14 11:31:40 -0700171 int fds[2];
172 RTC_CHECK(pipe(fds) == 0);
173 SetNonBlocking(fds[0]);
174 SetNonBlocking(fds[1]);
175 wakeup_pipe_out_ = fds[0];
176 wakeup_pipe_in_ = fds[1];
tommi8c80c6e2017-02-23 00:34:52 -0800177
Danil Chapovaloveb175242019-02-12 10:44:38 +0100178 EventAssign(&wakeup_event_, event_base_, wakeup_pipe_out_,
tommi1666b612016-07-13 10:58:12 -0700179 EV_READ | EV_PERSIST, OnWakeup, this);
Danil Chapovaloveb175242019-02-12 10:44:38 +0100180 event_add(&wakeup_event_, 0);
Markus Handellad5037b2021-05-07 15:02:36 +0200181 thread_ = rtc::PlatformThread::SpawnJoinable(
182 [this] {
183 {
184 CurrentTaskQueueSetter set_current(this);
185 while (is_active_)
186 event_base_loop(event_base_, 0);
187 }
188
189 for (TimerEvent* timer : pending_timers_)
190 delete timer;
191 },
192 queue_name, rtc::ThreadAttributes().SetPriority(priority));
tommic06b1332016-05-14 11:31:40 -0700193}
194
Danil Chapovaloveb175242019-02-12 10:44:38 +0100195void TaskQueueLibevent::Delete() {
tommic06b1332016-05-14 11:31:40 -0700196 RTC_DCHECK(!IsCurrent());
197 struct timespec ts;
198 char message = kQuit;
199 while (write(wakeup_pipe_in_, &message, sizeof(message)) != sizeof(message)) {
200 // The queue is full, so we have no choice but to wait and retry.
201 RTC_CHECK_EQ(EAGAIN, errno);
202 ts.tv_sec = 0;
203 ts.tv_nsec = 1000000;
204 nanosleep(&ts, nullptr);
205 }
206
Markus Handellad5037b2021-05-07 15:02:36 +0200207 thread_.Finalize();
tommic06b1332016-05-14 11:31:40 -0700208
Danil Chapovaloveb175242019-02-12 10:44:38 +0100209 event_del(&wakeup_event_);
tommi8c80c6e2017-02-23 00:34:52 -0800210
211 IgnoreSigPipeSignalOnCurrentThread();
212
tommic06b1332016-05-14 11:31:40 -0700213 close(wakeup_pipe_in_);
214 close(wakeup_pipe_out_);
215 wakeup_pipe_in_ = -1;
216 wakeup_pipe_out_ = -1;
217
tommic06b1332016-05-14 11:31:40 -0700218 event_base_free(event_base_);
Danil Chapovaloveb175242019-02-12 10:44:38 +0100219 delete this;
tommic06b1332016-05-14 11:31:40 -0700220}
221
Danil Chapovaloveb175242019-02-12 10:44:38 +0100222void TaskQueueLibevent::PostTask(std::unique_ptr<QueuedTask> task) {
Danil Chapovalov00e71ef2019-06-11 18:01:56 +0200223 {
Markus Handell18523c32020-07-08 17:55:58 +0200224 MutexLock lock(&pending_lock_);
Steve Anton9a83dd72020-01-09 11:03:25 -0800225 bool had_pending_tasks = !pending_.empty();
Danil Chapovalov00e71ef2019-06-11 18:01:56 +0200226 pending_.push_back(std::move(task));
Steve Anton9a83dd72020-01-09 11:03:25 -0800227
228 // Only write to the pipe if there were no pending tasks before this one
229 // since the thread could be sleeping. If there were already pending tasks
230 // then we know there's either a pending write in the pipe or the thread has
231 // not yet processed the pending tasks. In either case, the thread will
232 // eventually wake up and process all pending tasks including this one.
233 if (had_pending_tasks) {
234 return;
235 }
Danil Chapovalov00e71ef2019-06-11 18:01:56 +0200236 }
Steve Anton9a83dd72020-01-09 11:03:25 -0800237
238 // Note: This behvior outlined above ensures we never fill up the pipe write
239 // buffer since there will only ever be 1 byte pending.
240 char message = kRunTasks;
241 RTC_CHECK_EQ(write(wakeup_pipe_in_, &message, sizeof(message)),
242 sizeof(message));
tommic06b1332016-05-14 11:31:40 -0700243}
244
Danil Chapovaloveb175242019-02-12 10:44:38 +0100245void TaskQueueLibevent::PostDelayedTask(std::unique_ptr<QueuedTask> task,
246 uint32_t milliseconds) {
tommic06b1332016-05-14 11:31:40 -0700247 if (IsCurrent()) {
Danil Chapovaloveb175242019-02-12 10:44:38 +0100248 TimerEvent* timer = new TimerEvent(this, std::move(task));
249 EventAssign(&timer->ev, event_base_, -1, 0, &TaskQueueLibevent::RunTimer,
perkj650fdae2017-08-25 05:00:11 -0700250 timer);
Danil Chapovaloveb175242019-02-12 10:44:38 +0100251 pending_timers_.push_back(timer);
kwiberg5b9746e2017-08-16 04:52:35 -0700252 timeval tv = {rtc::dchecked_cast<int>(milliseconds / 1000),
253 rtc::dchecked_cast<int>(milliseconds % 1000) * 1000};
tommic06b1332016-05-14 11:31:40 -0700254 event_add(&timer->ev, &tv);
255 } else {
Mirko Bonadei317a1f02019-09-17 17:06:18 +0200256 PostTask(std::make_unique<SetTimerTask>(std::move(task), milliseconds));
tommic06b1332016-05-14 11:31:40 -0700257 }
258}
259
tommic06b1332016-05-14 11:31:40 -0700260// static
Danil Chapovaloveb175242019-02-12 10:44:38 +0100261void TaskQueueLibevent::OnWakeup(int socket,
262 short flags, // NOLINT
263 void* context) {
264 TaskQueueLibevent* me = static_cast<TaskQueueLibevent*>(context);
265 RTC_DCHECK(me->wakeup_pipe_out_ == socket);
tommic06b1332016-05-14 11:31:40 -0700266 char buf;
267 RTC_CHECK(sizeof(buf) == read(socket, &buf, sizeof(buf)));
268 switch (buf) {
269 case kQuit:
Danil Chapovaloveb175242019-02-12 10:44:38 +0100270 me->is_active_ = false;
271 event_base_loopbreak(me->event_base_);
tommic06b1332016-05-14 11:31:40 -0700272 break;
Steve Anton9a83dd72020-01-09 11:03:25 -0800273 case kRunTasks: {
274 absl::InlinedVector<std::unique_ptr<QueuedTask>, 4> tasks;
tommic06b1332016-05-14 11:31:40 -0700275 {
Markus Handell18523c32020-07-08 17:55:58 +0200276 MutexLock lock(&me->pending_lock_);
Steve Anton9a83dd72020-01-09 11:03:25 -0800277 tasks.swap(me->pending_);
tommic06b1332016-05-14 11:31:40 -0700278 }
Steve Anton9a83dd72020-01-09 11:03:25 -0800279 RTC_DCHECK(!tasks.empty());
280 for (auto& task : tasks) {
281 if (task->Run()) {
282 task.reset();
283 } else {
284 // |false| means the task should *not* be deleted.
285 task.release();
286 }
287 }
tommic06b1332016-05-14 11:31:40 -0700288 break;
289 }
290 default:
291 RTC_NOTREACHED();
292 break;
293 }
294}
295
296// static
Danil Chapovaloveb175242019-02-12 10:44:38 +0100297void TaskQueueLibevent::RunTimer(int fd,
298 short flags, // NOLINT
299 void* context) {
tommic06b1332016-05-14 11:31:40 -0700300 TimerEvent* timer = static_cast<TimerEvent*>(context);
301 if (!timer->task->Run())
302 timer->task.release();
Danil Chapovaloveb175242019-02-12 10:44:38 +0100303 timer->task_queue->pending_timers_.remove(timer);
tommic06b1332016-05-14 11:31:40 -0700304 delete timer;
305}
306
Danil Chapovaloveb175242019-02-12 10:44:38 +0100307class TaskQueueLibeventFactory final : public TaskQueueFactory {
308 public:
309 std::unique_ptr<TaskQueueBase, TaskQueueDeleter> CreateTaskQueue(
310 absl::string_view name,
311 Priority priority) const override {
312 return std::unique_ptr<TaskQueueBase, TaskQueueDeleter>(
313 new TaskQueueLibevent(name,
314 TaskQueuePriorityToThreadPriority(priority)));
315 }
316};
317
318} // namespace
319
320std::unique_ptr<TaskQueueFactory> CreateTaskQueueLibeventFactory() {
Mirko Bonadei317a1f02019-09-17 17:06:18 +0200321 return std::make_unique<TaskQueueLibeventFactory>();
perkj650fdae2017-08-25 05:00:11 -0700322}
323
Danil Chapovaloveb175242019-02-12 10:44:38 +0100324} // namespace webrtc