#ifndef SRC_NODE_PLATFORM_H_ #define SRC_NODE_PLATFORM_H_ #if defined(NODE_WANT_INTERNALS) && NODE_WANT_INTERNALS #include #include #include #include #include "libplatform/libplatform.h" #include "node.h" #include "node_mutex.h" #include "tracing/agent.h" #include "uv.h" namespace node { class NodePlatform; class IsolateData; class PerIsolatePlatformData; template class TaskQueue { public: TaskQueue(); ~TaskQueue() = default; void Push(std::unique_ptr task); std::unique_ptr Pop(); std::unique_ptr BlockingPop(); std::queue> PopAll(); void NotifyOfCompletion(); void BlockingDrain(); void Stop(); private: Mutex lock_; ConditionVariable tasks_available_; ConditionVariable tasks_drained_; int outstanding_tasks_; bool stopped_; std::queue> task_queue_; }; struct DelayedTask { std::unique_ptr task; uv_timer_t timer; double timeout; std::shared_ptr platform_data; }; // This acts as the foreground task runner for a given Isolate. class PerIsolatePlatformData : public IsolatePlatformDelegate, public v8::TaskRunner, public std::enable_shared_from_this { public: PerIsolatePlatformData(v8::Isolate* isolate, uv_loop_t* loop); ~PerIsolatePlatformData() override; std::shared_ptr GetForegroundTaskRunner() override; void PostTask(std::unique_ptr task) override; void PostIdleTask(std::unique_ptr task) override; void PostDelayedTask(std::unique_ptr task, double delay_in_seconds) override; bool IdleTasksEnabled() override { return false; } // Non-nestable tasks are treated like regular tasks. bool NonNestableTasksEnabled() const override { return true; } bool NonNestableDelayedTasksEnabled() const override { return true; } void PostNonNestableTask(std::unique_ptr task) override; void PostNonNestableDelayedTask(std::unique_ptr task, double delay_in_seconds) override; void AddShutdownCallback(void (*callback)(void*), void* data); void Shutdown(); // Returns true if work was dispatched or executed. New tasks that are // posted during flushing of the queue are postponed until the next // flushing. bool FlushForegroundTasksInternal(); const uv_loop_t* event_loop() const { return loop_; } private: void DeleteFromScheduledTasks(DelayedTask* task); void DecreaseHandleCount(); static void FlushTasks(uv_async_t* handle); static void RunForegroundTask(std::unique_ptr task); static void RunForegroundTask(uv_timer_t* timer); struct ShutdownCallback { void (*cb)(void*); void* data; }; typedef std::vector ShutdownCbList; ShutdownCbList shutdown_callbacks_; // shared_ptr to self to keep this object alive during shutdown. std::shared_ptr self_reference_; uint32_t uv_handle_count_ = 1; // 1 = flush_tasks_ uv_loop_t* const loop_; uv_async_t* flush_tasks_ = nullptr; TaskQueue foreground_tasks_; TaskQueue foreground_delayed_tasks_; // Use a custom deleter because libuv needs to close the handle first. typedef std::unique_ptr DelayedTaskPointer; std::vector scheduled_delayed_tasks_; }; // This acts as the single worker thread task runner for all Isolates. class WorkerThreadsTaskRunner { public: explicit WorkerThreadsTaskRunner(int thread_pool_size); void PostTask(std::unique_ptr task); void PostDelayedTask(std::unique_ptr task, double delay_in_seconds); void BlockingDrain(); void Shutdown(); int NumberOfWorkerThreads() const; private: TaskQueue pending_worker_tasks_; class DelayedTaskScheduler; std::unique_ptr delayed_task_scheduler_; std::vector> threads_; }; class NodePlatform : public MultiIsolatePlatform { public: NodePlatform(int thread_pool_size, node::tracing::TracingController* tracing_controller); ~NodePlatform() override = default; void DrainTasks(v8::Isolate* isolate) override; void Shutdown(); // v8::Platform implementation. int NumberOfWorkerThreads() override; void CallOnWorkerThread(std::unique_ptr task) override; void CallDelayedOnWorkerThread(std::unique_ptr task, double delay_in_seconds) override; void CallOnForegroundThread(v8::Isolate* isolate, v8::Task* task) override { UNREACHABLE(); } void CallDelayedOnForegroundThread(v8::Isolate* isolate, v8::Task* task, double delay_in_seconds) override { UNREACHABLE(); } bool IdleTasksEnabled(v8::Isolate* isolate) override; double MonotonicallyIncreasingTime() override; double CurrentClockTimeMillis() override; node::tracing::TracingController* GetTracingController() override; bool FlushForegroundTasks(v8::Isolate* isolate) override; void RegisterIsolate(v8::Isolate* isolate, uv_loop_t* loop) override; void RegisterIsolate(v8::Isolate* isolate, IsolatePlatformDelegate* delegate) override; void UnregisterIsolate(v8::Isolate* isolate) override; void AddIsolateFinishedCallback(v8::Isolate* isolate, void (*callback)(void*), void* data) override; std::shared_ptr GetForegroundTaskRunner( v8::Isolate* isolate) override; private: IsolatePlatformDelegate* ForIsolate(v8::Isolate* isolate); std::shared_ptr ForNodeIsolate(v8::Isolate* isolate); Mutex per_isolate_mutex_; using DelegatePair = std::pair< IsolatePlatformDelegate*, std::shared_ptr>; std::unordered_map per_isolate_; node::tracing::TracingController* tracing_controller_; std::shared_ptr worker_thread_task_runner_; }; } // namespace node #endif // defined(NODE_WANT_INTERNALS) && NODE_WANT_INTERNALS #endif // SRC_NODE_PLATFORM_H_