GCC Code Coverage Report
Directory: ./ Exec Total Coverage
File: node_platform.cc Lines: 350 366 95.6 %
Date: 2022-05-21 04:15:56 Branches: 78 102 76.5 %

Line Branch Exec Source
1
#include "node_platform.h"
2
#include "node_internals.h"
3
4
#include "env-inl.h"
5
#include "debug_utils-inl.h"
6
#include <algorithm>  // find_if(), find(), move()
7
#include <cmath>  // llround()
8
#include <memory>  // unique_ptr(), shared_ptr(), make_shared()
9
10
namespace node {
11
12
using v8::Isolate;
13
using v8::Object;
14
using v8::Platform;
15
using v8::Task;
16
17
namespace {
18
19
struct PlatformWorkerData {
20
  TaskQueue<Task>* task_queue;
21
  Mutex* platform_workers_mutex;
22
  ConditionVariable* platform_workers_ready;
23
  int* pending_platform_workers;
24
  int id;
25
};
26
27
20782
static void PlatformWorkerThread(void* data) {
28
  std::unique_ptr<PlatformWorkerData>
29
41536
      worker_data(static_cast<PlatformWorkerData*>(data));
30
31
20782
  TaskQueue<Task>* pending_worker_tasks = worker_data->task_queue;
32

26220
  TRACE_EVENT_METADATA1("__metadata", "thread_name", "name",
33
                        "PlatformWorkerThread");
34
35
  // Notify the main thread that the platform worker is ready.
36
  {
37
41564
    Mutex::ScopedLock lock(*worker_data->platform_workers_mutex);
38
20782
    (*worker_data->pending_platform_workers)--;
39
20782
    worker_data->platform_workers_ready->Signal(lock);
40
  }
41
42
123710
  while (std::unique_ptr<Task> task = pending_worker_tasks->BlockingPop()) {
43
102928
    task->Run();
44
102928
    pending_worker_tasks->NotifyOfCompletion();
45
102928
  }
46
20754
}
47
48
}  // namespace
49
50
class WorkerThreadsTaskRunner::DelayedTaskScheduler {
51
 public:
52
5194
  explicit DelayedTaskScheduler(TaskQueue<Task>* tasks)
53
5194
    : pending_worker_tasks_(tasks) {}
54
55
5194
  std::unique_ptr<uv_thread_t> Start() {
56
5194
    auto start_thread = [](void* data) {
57
5194
      static_cast<DelayedTaskScheduler*>(data)->Run();
58
5187
    };
59
5194
    std::unique_ptr<uv_thread_t> t { new uv_thread_t() };
60
5194
    uv_sem_init(&ready_, 0);
61
5194
    CHECK_EQ(0, uv_thread_create(t.get(), start_thread, this));
62
5194
    uv_sem_wait(&ready_);
63
5194
    uv_sem_destroy(&ready_);
64
5194
    return t;
65
  }
66
67
527
  void PostDelayedTask(std::unique_ptr<Task> task, double delay_in_seconds) {
68
527
    tasks_.Push(std::make_unique<ScheduleTask>(this, std::move(task),
69
                                               delay_in_seconds));
70
527
    uv_async_send(&flush_tasks_);
71
527
  }
72
73
5187
  void Stop() {
74
5187
    tasks_.Push(std::make_unique<StopTask>(this));
75
5187
    uv_async_send(&flush_tasks_);
76
5187
  }
77
78
 private:
79
5194
  void Run() {
80

10440
    TRACE_EVENT_METADATA1("__metadata", "thread_name", "name",
81
                          "WorkerThreadsTaskRunner::DelayedTaskScheduler");
82
5194
    loop_.data = this;
83
5194
    CHECK_EQ(0, uv_loop_init(&loop_));
84
5194
    flush_tasks_.data = this;
85
5194
    CHECK_EQ(0, uv_async_init(&loop_, &flush_tasks_, FlushTasks));
86
5194
    uv_sem_post(&ready_);
87
88
5194
    uv_run(&loop_, UV_RUN_DEFAULT);
89
5187
    CheckedUvLoopClose(&loop_);
90
5187
  }
91
92
5714
  static void FlushTasks(uv_async_t* flush_tasks) {
93
    DelayedTaskScheduler* scheduler =
94
5714
        ContainerOf(&DelayedTaskScheduler::loop_, flush_tasks->loop);
95
11428
    while (std::unique_ptr<Task> task = scheduler->tasks_.Pop())
96
11428
      task->Run();
97
5714
  }
98
99
  class StopTask : public Task {
100
   public:
101
5187
    explicit StopTask(DelayedTaskScheduler* scheduler): scheduler_(scheduler) {}
102
103
5187
    void Run() override {
104
5187
      std::vector<uv_timer_t*> timers;
105
5539
      for (uv_timer_t* timer : scheduler_->timers_)
106
352
        timers.push_back(timer);
107
5539
      for (uv_timer_t* timer : timers)
108
352
        scheduler_->TakeTimerTask(timer);
109
5187
      uv_close(reinterpret_cast<uv_handle_t*>(&scheduler_->flush_tasks_),
110
5187
               [](uv_handle_t* handle) {});
111
5187
    }
112
113
   private:
114
     DelayedTaskScheduler* scheduler_;
115
  };
116
117
  class ScheduleTask : public Task {
118
   public:
119
527
    ScheduleTask(DelayedTaskScheduler* scheduler,
120
                 std::unique_ptr<Task> task,
121
                 double delay_in_seconds)
122
527
      : scheduler_(scheduler),
123
527
        task_(std::move(task)),
124
527
        delay_in_seconds_(delay_in_seconds) {}
125
126
527
    void Run() override {
127
527
      uint64_t delay_millis = llround(delay_in_seconds_ * 1000);
128
527
      std::unique_ptr<uv_timer_t> timer(new uv_timer_t());
129
527
      CHECK_EQ(0, uv_timer_init(&scheduler_->loop_, timer.get()));
130
527
      timer->data = task_.release();
131
527
      CHECK_EQ(0, uv_timer_start(timer.get(), RunTask, delay_millis, 0));
132
527
      scheduler_->timers_.insert(timer.release());
133
527
    }
134
135
   private:
136
    DelayedTaskScheduler* scheduler_;
137
    std::unique_ptr<Task> task_;
138
    double delay_in_seconds_;
139
  };
140
141
175
  static void RunTask(uv_timer_t* timer) {
142
    DelayedTaskScheduler* scheduler =
143
175
        ContainerOf(&DelayedTaskScheduler::loop_, timer->loop);
144
175
    scheduler->pending_worker_tasks_->Push(scheduler->TakeTimerTask(timer));
145
175
  }
146
147
527
  std::unique_ptr<Task> TakeTimerTask(uv_timer_t* timer) {
148
527
    std::unique_ptr<Task> task(static_cast<Task*>(timer->data));
149
527
    uv_timer_stop(timer);
150
527
    uv_close(reinterpret_cast<uv_handle_t*>(timer), [](uv_handle_t* handle) {
151
527
      delete reinterpret_cast<uv_timer_t*>(handle);
152
527
    });
153
527
    timers_.erase(timer);
154
527
    return task;
155
  }
156
157
  uv_sem_t ready_;
158
  TaskQueue<Task>* pending_worker_tasks_;
159
160
  TaskQueue<Task> tasks_;
161
  uv_loop_t loop_;
162
  uv_async_t flush_tasks_;
163
  std::unordered_set<uv_timer_t*> timers_;
164
};
165
166
5194
WorkerThreadsTaskRunner::WorkerThreadsTaskRunner(int thread_pool_size) {
167
10388
  Mutex platform_workers_mutex;
168
10388
  ConditionVariable platform_workers_ready;
169
170
10388
  Mutex::ScopedLock lock(platform_workers_mutex);
171
5194
  int pending_platform_workers = thread_pool_size;
172
173
5194
  delayed_task_scheduler_ = std::make_unique<DelayedTaskScheduler>(
174
5194
      &pending_worker_tasks_);
175
5194
  threads_.push_back(delayed_task_scheduler_->Start());
176
177
25976
  for (int i = 0; i < thread_pool_size; i++) {
178
    PlatformWorkerData* worker_data = new PlatformWorkerData{
179
20782
      &pending_worker_tasks_, &platform_workers_mutex,
180
      &platform_workers_ready, &pending_platform_workers, i
181
20782
    };
182
20782
    std::unique_ptr<uv_thread_t> t { new uv_thread_t() };
183
20782
    if (uv_thread_create(t.get(), PlatformWorkerThread,
184
20782
                         worker_data) != 0) {
185
      break;
186
    }
187
20782
    threads_.push_back(std::move(t));
188
  }
189
190
  // Wait for platform workers to initialize before continuing with the
191
  // bootstrap.
192
23625
  while (pending_platform_workers > 0) {
193
18431
    platform_workers_ready.Wait(lock);
194
  }
195
5194
}
196
197
102753
void WorkerThreadsTaskRunner::PostTask(std::unique_ptr<Task> task) {
198
102753
  pending_worker_tasks_.Push(std::move(task));
199
102753
}
200
201
527
void WorkerThreadsTaskRunner::PostDelayedTask(std::unique_ptr<Task> task,
202
                                              double delay_in_seconds) {
203
527
  delayed_task_scheduler_->PostDelayedTask(std::move(task), delay_in_seconds);
204
527
}
205
206
15105
void WorkerThreadsTaskRunner::BlockingDrain() {
207
15105
  pending_worker_tasks_.BlockingDrain();
208
15105
}
209
210
5187
void WorkerThreadsTaskRunner::Shutdown() {
211
5187
  pending_worker_tasks_.Stop();
212
5187
  delayed_task_scheduler_->Stop();
213
31128
  for (size_t i = 0; i < threads_.size(); i++) {
214
25941
    CHECK_EQ(0, uv_thread_join(threads_[i].get()));
215
  }
216
5187
}
217
218
62677
int WorkerThreadsTaskRunner::NumberOfWorkerThreads() const {
219
62677
  return threads_.size();
220
}
221
222
6060
PerIsolatePlatformData::PerIsolatePlatformData(
223
6060
    Isolate* isolate, uv_loop_t* loop)
224
6060
  : isolate_(isolate), loop_(loop) {
225
6060
  flush_tasks_ = new uv_async_t();
226
6060
  CHECK_EQ(0, uv_async_init(loop, flush_tasks_, FlushTasks));
227
6060
  flush_tasks_->data = static_cast<void*>(this);
228
6060
  uv_unref(reinterpret_cast<uv_handle_t*>(flush_tasks_));
229
6060
}
230
231
std::shared_ptr<v8::TaskRunner>
232
28768
PerIsolatePlatformData::GetForegroundTaskRunner() {
233
28768
  return shared_from_this();
234
}
235
236
8736
void PerIsolatePlatformData::FlushTasks(uv_async_t* handle) {
237
8736
  auto platform_data = static_cast<PerIsolatePlatformData*>(handle->data);
238
8736
  platform_data->FlushForegroundTasksInternal();
239
8736
}
240
241
void PerIsolatePlatformData::PostIdleTask(std::unique_ptr<v8::IdleTask> task) {
242
  UNREACHABLE();
243
}
244
245
10500
void PerIsolatePlatformData::PostTask(std::unique_ptr<Task> task) {
246
10500
  if (flush_tasks_ == nullptr) {
247
    // V8 may post tasks during Isolate disposal. In that case, the only
248
    // sensible path forward is to discard the task.
249
    return;
250
  }
251
10500
  foreground_tasks_.Push(std::move(task));
252
10500
  uv_async_send(flush_tasks_);
253
}
254
255
5467
void PerIsolatePlatformData::PostDelayedTask(
256
    std::unique_ptr<Task> task, double delay_in_seconds) {
257
5467
  if (flush_tasks_ == nullptr) {
258
    // V8 may post tasks during Isolate disposal. In that case, the only
259
    // sensible path forward is to discard the task.
260
    return;
261
  }
262
10934
  std::unique_ptr<DelayedTask> delayed(new DelayedTask());
263
5467
  delayed->task = std::move(task);
264
5467
  delayed->platform_data = shared_from_this();
265
5467
  delayed->timeout = delay_in_seconds;
266
5467
  foreground_delayed_tasks_.Push(std::move(delayed));
267
5467
  uv_async_send(flush_tasks_);
268
}
269
270
8658
void PerIsolatePlatformData::PostNonNestableTask(std::unique_ptr<Task> task) {
271
8658
  PostTask(std::move(task));
272
8658
}
273
274
void PerIsolatePlatformData::PostNonNestableDelayedTask(
275
    std::unique_ptr<Task> task,
276
    double delay_in_seconds) {
277
  PostDelayedTask(std::move(task), delay_in_seconds);
278
}
279
280
1744
PerIsolatePlatformData::~PerIsolatePlatformData() {
281
1744
  CHECK(!flush_tasks_);
282
}
283
284
814
void PerIsolatePlatformData::AddShutdownCallback(void (*callback)(void*),
285
                                                 void* data) {
286
814
  shutdown_callbacks_.emplace_back(ShutdownCallback { callback, data });
287
814
}
288
289
5552
void PerIsolatePlatformData::Shutdown() {
290
5552
  if (flush_tasks_ == nullptr)
291
    return;
292
293
  // While there should be no V8 tasks in the queues at this point, it is
294
  // possible that Node.js-internal tasks from e.g. the inspector are still
295
  // lying around. We clear these queues and ignore the return value,
296
  // effectively deleting the tasks instead of running them.
297
5552
  foreground_delayed_tasks_.PopAll();
298
5552
  foreground_tasks_.PopAll();
299
5552
  scheduled_delayed_tasks_.clear();
300
301
  // Both destroying the scheduled_delayed_tasks_ lists and closing
302
  // flush_tasks_ handle add tasks to the event loop. We keep a count of all
303
  // non-closed handles, and when that reaches zero, we inform any shutdown
304
  // callbacks that the platform is done as far as this Isolate is concerned.
305
5552
  self_reference_ = shared_from_this();
306
5552
  uv_close(reinterpret_cast<uv_handle_t*>(flush_tasks_),
307
872
           [](uv_handle_t* handle) {
308
    std::unique_ptr<uv_async_t> flush_tasks {
309
1744
        reinterpret_cast<uv_async_t*>(handle) };
310
    PerIsolatePlatformData* platform_data =
311
872
        static_cast<PerIsolatePlatformData*>(flush_tasks->data);
312
872
    platform_data->DecreaseHandleCount();
313
872
    platform_data->self_reference_.reset();
314
872
  });
315
5552
  flush_tasks_ = nullptr;
316
}
317
318
1732
void PerIsolatePlatformData::DecreaseHandleCount() {
319
1732
  CHECK_GE(uv_handle_count_, 1);
320
1732
  if (--uv_handle_count_ == 0) {
321
1686
    for (const auto& callback : shutdown_callbacks_)
322
814
      callback.cb(callback.data);
323
  }
324
1732
}
325
326
5194
NodePlatform::NodePlatform(int thread_pool_size,
327
                           v8::TracingController* tracing_controller,
328
5194
                           v8::PageAllocator* page_allocator) {
329
5194
  if (tracing_controller != nullptr) {
330
5187
    tracing_controller_ = tracing_controller;
331
  } else {
332
7
    tracing_controller_ = new v8::TracingController();
333
  }
334
335
  // V8 will default to its built in allocator if none is provided.
336
5194
  page_allocator_ = page_allocator;
337
338
  // TODO(addaleax): It's a bit icky that we use global state here, but we can't
339
  // really do anything about it unless V8 starts exposing a way to access the
340
  // current v8::Platform instance.
341
5194
  SetTracingController(tracing_controller_);
342
  DCHECK_EQ(GetTracingController(), tracing_controller_);
343
  worker_thread_task_runner_ =
344
5194
      std::make_shared<WorkerThreadsTaskRunner>(thread_pool_size);
345
5194
}
346
347
20748
NodePlatform::~NodePlatform() {
348
10374
  Shutdown();
349
20748
}
350
351
6059
void NodePlatform::RegisterIsolate(Isolate* isolate, uv_loop_t* loop) {
352
12118
  Mutex::ScopedLock lock(per_isolate_mutex_);
353
12118
  auto delegate = std::make_shared<PerIsolatePlatformData>(isolate, loop);
354
6059
  IsolatePlatformDelegate* ptr = delegate.get();
355
  auto insertion = per_isolate_.emplace(
356
    isolate,
357
6059
    std::make_pair(ptr, std::move(delegate)));
358
6059
  CHECK(insertion.second);
359
6059
}
360
361
1
void NodePlatform::RegisterIsolate(Isolate* isolate,
362
                                   IsolatePlatformDelegate* delegate) {
363
2
  Mutex::ScopedLock lock(per_isolate_mutex_);
364
  auto insertion = per_isolate_.emplace(
365
    isolate,
366
1
    std::make_pair(delegate, std::shared_ptr<PerIsolatePlatformData>{}));
367
1
  CHECK(insertion.second);
368
1
}
369
370
5552
void NodePlatform::UnregisterIsolate(Isolate* isolate) {
371
11104
  Mutex::ScopedLock lock(per_isolate_mutex_);
372
5552
  auto existing_it = per_isolate_.find(isolate);
373
5552
  CHECK_NE(existing_it, per_isolate_.end());
374
5552
  auto& existing = existing_it->second;
375
5552
  if (existing.second) {
376
5551
    existing.second->Shutdown();
377
  }
378
5552
  per_isolate_.erase(existing_it);
379
5552
}
380
381
814
void NodePlatform::AddIsolateFinishedCallback(Isolate* isolate,
382
                                              void (*cb)(void*), void* data) {
383
814
  Mutex::ScopedLock lock(per_isolate_mutex_);
384
814
  auto it = per_isolate_.find(isolate);
385
814
  if (it == per_isolate_.end()) {
386
    cb(data);
387
    return;
388
  }
389
814
  CHECK(it->second.second);
390
814
  it->second.second->AddShutdownCallback(cb, data);
391
}
392
393
10369
void NodePlatform::Shutdown() {
394
10369
  if (has_shut_down_) return;
395
5187
  has_shut_down_ = true;
396
5187
  worker_thread_task_runner_->Shutdown();
397
398
  {
399
10374
    Mutex::ScopedLock lock(per_isolate_mutex_);
400
5187
    per_isolate_.clear();
401
  }
402
}
403
404
62677
int NodePlatform::NumberOfWorkerThreads() {
405
62677
  return worker_thread_task_runner_->NumberOfWorkerThreads();
406
}
407
408
10152
void PerIsolatePlatformData::RunForegroundTask(std::unique_ptr<Task> task) {
409
10152
  DebugSealHandleScope scope(isolate_);
410
10152
  Environment* env = Environment::GetCurrent(isolate_);
411
10152
  if (env != nullptr) {
412
15519
    v8::HandleScope scope(isolate_);
413
7763
    InternalCallbackScope cb_scope(env, Object::New(isolate_), { 0, 0 },
414
15526
                                   InternalCallbackScope::kNoFlags);
415
7763
    task->Run();
416
  } else {
417
    // The task is moved out of InternalCallbackScope if env is not available.
418
    // This is a required else block, and should not be removed.
419
    // See comment: https://github.com/nodejs/node/pull/34688#pullrequestreview-463867489
420
2389
    task->Run();
421
  }
422
10145
}
423
424
16
void PerIsolatePlatformData::DeleteFromScheduledTasks(DelayedTask* task) {
425
  auto it = std::find_if(scheduled_delayed_tasks_.begin(),
426
                         scheduled_delayed_tasks_.end(),
427
32
                         [task](const DelayedTaskPointer& delayed) -> bool {
428
16
          return delayed.get() == task;
429
16
      });
430
16
  CHECK_NE(it, scheduled_delayed_tasks_.end());
431
16
  scheduled_delayed_tasks_.erase(it);
432
16
}
433
434
16
void PerIsolatePlatformData::RunForegroundTask(uv_timer_t* handle) {
435
16
  DelayedTask* delayed = ContainerOf(&DelayedTask::timer, handle);
436
16
  delayed->platform_data->RunForegroundTask(std::move(delayed->task));
437
16
  delayed->platform_data->DeleteFromScheduledTasks(delayed);
438
16
}
439
440
10736
void NodePlatform::DrainTasks(Isolate* isolate) {
441
10736
  std::shared_ptr<PerIsolatePlatformData> per_isolate = ForNodeIsolate(isolate);
442
10736
  if (!per_isolate) return;
443
444
4370
  do {
445
    // Worker tasks aren't associated with an Isolate.
446
15105
    worker_thread_task_runner_->BlockingDrain();
447
15105
  } while (per_isolate->FlushForegroundTasksInternal());
448
}
449
450
23845
bool PerIsolatePlatformData::FlushForegroundTasksInternal() {
451
23845
  bool did_work = false;
452
453
  while (std::unique_ptr<DelayedTask> delayed =
454
29066
      foreground_delayed_tasks_.Pop()) {
455
5221
    did_work = true;
456
5221
    uint64_t delay_millis = llround(delayed->timeout * 1000);
457
458
5221
    delayed->timer.data = static_cast<void*>(delayed.get());
459
5221
    uv_timer_init(loop_, &delayed->timer);
460
    // Timers may not guarantee queue ordering of events with the same delay if
461
    // the delay is non-zero. This should not be a problem in practice.
462
5221
    uv_timer_start(&delayed->timer, RunForegroundTask, delay_millis, 0);
463
5221
    uv_unref(reinterpret_cast<uv_handle_t*>(&delayed->timer));
464
5221
    uv_handle_count_++;
465
466
15663
    scheduled_delayed_tasks_.emplace_back(delayed.release(),
467
5062
                                          [](DelayedTask* delayed) {
468
5062
      uv_close(reinterpret_cast<uv_handle_t*>(&delayed->timer),
469
860
               [](uv_handle_t* handle) {
470
        std::unique_ptr<DelayedTask> task {
471
1720
            static_cast<DelayedTask*>(handle->data) };
472
860
        task->platform_data->DecreaseHandleCount();
473
860
      });
474
5221
    });
475
5221
  }
476
  // Move all foreground tasks into a separate queue and flush that queue.
477
  // This way tasks that are posted while flushing the queue will be run on the
478
  // next call of FlushForegroundTasksInternal.
479
23845
  std::queue<std::unique_ptr<Task>> tasks = foreground_tasks_.PopAll();
480
33974
  while (!tasks.empty()) {
481
10136
    std::unique_ptr<Task> task = std::move(tasks.front());
482
10136
    tasks.pop();
483
10136
    did_work = true;
484
10136
    RunForegroundTask(std::move(task));
485
  }
486
23838
  return did_work;
487
}
488
489
102753
void NodePlatform::CallOnWorkerThread(std::unique_ptr<Task> task) {
490
102753
  worker_thread_task_runner_->PostTask(std::move(task));
491
102753
}
492
493
527
void NodePlatform::CallDelayedOnWorkerThread(std::unique_ptr<Task> task,
494
                                             double delay_in_seconds) {
495
527
  worker_thread_task_runner_->PostDelayedTask(std::move(task),
496
                                              delay_in_seconds);
497
527
}
498
499
500
28768
IsolatePlatformDelegate* NodePlatform::ForIsolate(Isolate* isolate) {
501
57536
  Mutex::ScopedLock lock(per_isolate_mutex_);
502
28768
  auto data = per_isolate_[isolate];
503
28768
  CHECK_NOT_NULL(data.first);
504
28768
  return data.first;
505
}
506
507
std::shared_ptr<PerIsolatePlatformData>
508
10740
NodePlatform::ForNodeIsolate(Isolate* isolate) {
509
21480
  Mutex::ScopedLock lock(per_isolate_mutex_);
510
21480
  auto data = per_isolate_[isolate];
511
10740
  CHECK_NOT_NULL(data.first);
512
10740
  return data.second;
513
}
514
515
4
bool NodePlatform::FlushForegroundTasks(Isolate* isolate) {
516
8
  std::shared_ptr<PerIsolatePlatformData> per_isolate = ForNodeIsolate(isolate);
517
4
  if (!per_isolate) return false;
518
4
  return per_isolate->FlushForegroundTasksInternal();
519
}
520
521
28850
std::unique_ptr<v8::JobHandle> NodePlatform::PostJob(v8::TaskPriority priority,
522
                                       std::unique_ptr<v8::JobTask> job_task) {
523
  return v8::platform::NewDefaultJobHandle(
524
28850
      this, priority, std::move(job_task), NumberOfWorkerThreads());
525
}
526
527
bool NodePlatform::IdleTasksEnabled(Isolate* isolate) {
528
  return ForIsolate(isolate)->IdleTasksEnabled();
529
}
530
531
std::shared_ptr<v8::TaskRunner>
532
28768
NodePlatform::GetForegroundTaskRunner(Isolate* isolate) {
533
28768
  return ForIsolate(isolate)->GetForegroundTaskRunner();
534
}
535
536
221037
double NodePlatform::MonotonicallyIncreasingTime() {
537
  // Convert nanos to seconds.
538
221037
  return uv_hrtime() / 1e9;
539
}
540
541
16584743
double NodePlatform::CurrentClockTimeMillis() {
542
16584743
  return SystemClockTimeMillis();
543
}
544
545
305520
v8::TracingController* NodePlatform::GetTracingController() {
546
305520
  CHECK_NOT_NULL(tracing_controller_);
547
305520
  return tracing_controller_;
548
}
549
550
5194
Platform::StackTracePrinter NodePlatform::GetStackTracePrinter() {
551
  return []() {
552
    fprintf(stderr, "\n");
553
    DumpBacktrace(stderr);
554
    fflush(stderr);
555
5194
  };
556
}
557
558
5195
v8::PageAllocator* NodePlatform::GetPageAllocator() {
559
5195
  return page_allocator_;
560
}
561
562
template <class T>
563
45016
TaskQueue<T>::TaskQueue()
564
    : lock_(), tasks_available_(), tasks_drained_(),
565
45016
      outstanding_tasks_(0), stopped_(false), task_queue_() { }
566
567
template <class T>
568
249218
void TaskQueue<T>::Push(std::unique_ptr<T> task) {
569
498436
  Mutex::ScopedLock scoped_lock(lock_);
570
249218
  outstanding_tasks_++;
571
249218
  task_queue_.push(std::move(task));
572
249218
  tasks_available_.Signal(scoped_lock);
573
249218
}
574
575
template <class T>
576
80988
std::unique_ptr<T> TaskQueue<T>::Pop() {
577
161976
  Mutex::ScopedLock scoped_lock(lock_);
578
80988
  if (task_queue_.empty()) {
579
59118
    return std::unique_ptr<T>(nullptr);
580
  }
581
43740
  std::unique_ptr<T> result = std::move(task_queue_.front());
582
21870
  task_queue_.pop();
583
21870
  return result;
584
}
585
586
template <class T>
587
123710
std::unique_ptr<T> TaskQueue<T>::BlockingPop() {
588
247392
  Mutex::ScopedLock scoped_lock(lock_);
589

238135
  while (task_queue_.empty() && !stopped_) {
590
114453
    tasks_available_.Wait(scoped_lock);
591
  }
592
123682
  if (stopped_) {
593
20754
    return std::unique_ptr<T>(nullptr);
594
  }
595
205856
  std::unique_ptr<T> result = std::move(task_queue_.front());
596
102928
  task_queue_.pop();
597
102928
  return result;
598
}
599
600
template <class T>
601
102928
void TaskQueue<T>::NotifyOfCompletion() {
602
205856
  Mutex::ScopedLock scoped_lock(lock_);
603
102928
  if (--outstanding_tasks_ == 0) {
604
43828
    tasks_drained_.Broadcast(scoped_lock);
605
  }
606
102928
}
607
608
template <class T>
609
15105
void TaskQueue<T>::BlockingDrain() {
610
30210
  Mutex::ScopedLock scoped_lock(lock_);
611
16506
  while (outstanding_tasks_ > 0) {
612
1401
    tasks_drained_.Wait(scoped_lock);
613
  }
614
15105
}
615
616
template <class T>
617
5187
void TaskQueue<T>::Stop() {
618
10374
  Mutex::ScopedLock scoped_lock(lock_);
619
5187
  stopped_ = true;
620
5187
  tasks_available_.Broadcast(scoped_lock);
621
5187
}
622
623
template <class T>
624
34949
std::queue<std::unique_ptr<T>> TaskQueue<T>::PopAll() {
625
69898
  Mutex::ScopedLock scoped_lock(lock_);
626
34949
  std::queue<std::unique_ptr<T>> result;
627
34949
  result.swap(task_queue_);
628
34949
  return result;
629
}
630
631
}  // namespace node