#include #include "node.h" #include "node_builtins.h" #include "node_context_data.h" #include "node_errors.h" #include "node_exit_code.h" #include "node_internals.h" #include "node_options-inl.h" #include "node_platform.h" #include "node_realm-inl.h" #include "node_shadow_realm.h" #include "node_snapshot_builder.h" #include "node_v8_platform-inl.h" #include "node_wasm_web_api.h" #include "uv.h" #ifdef NODE_ENABLE_VTUNE_PROFILING #include "../deps/v8/src/third_party/vtune/v8-vtune.h" #endif #if HAVE_INSPECTOR #include "inspector/worker_inspector.h" // ParentInspectorHandle #endif namespace node { using errors::TryCatchScope; using v8::Array; using v8::Context; using v8::EscapableHandleScope; using v8::Function; using v8::FunctionCallbackInfo; using v8::HandleScope; using v8::Isolate; using v8::Just; using v8::Local; using v8::Maybe; using v8::MaybeLocal; using v8::Nothing; using v8::Null; using v8::Object; using v8::ObjectTemplate; using v8::Private; using v8::PropertyDescriptor; using v8::SealHandleScope; using v8::String; using v8::Value; bool AllowWasmCodeGenerationCallback(Local context, Local) { Local wasm_code_gen = context->GetEmbedderData(ContextEmbedderIndex::kAllowWasmCodeGeneration); return wasm_code_gen->IsUndefined() || wasm_code_gen->IsTrue(); } bool ShouldAbortOnUncaughtException(Isolate* isolate) { DebugSealHandleScope scope(isolate); Environment* env = Environment::GetCurrent(isolate); return env != nullptr && (env->is_main_thread() || !env->is_stopping()) && env->abort_on_uncaught_exception() && env->should_abort_on_uncaught_toggle()[0] && !env->inside_should_not_abort_on_uncaught_scope(); } MaybeLocal PrepareStackTraceCallback(Local context, Local exception, Local trace) { Environment* env = Environment::GetCurrent(context); if (env == nullptr) { return exception->ToString(context).FromMaybe(Local()); } // TODO(legendecas): Per-realm prepareStackTrace callback. // If we are in a Realm that is not the principal Realm (e.g. ShadowRealm), // skip the prepareStackTrace callback to avoid passing the JS objects ( // the exception and trace) across the realm boundary with the // `Error.prepareStackTrace` override. Realm* current_realm = Realm::GetCurrent(context); if (current_realm != nullptr && current_realm->kind() != Realm::Kind::kPrincipal) { return exception->ToString(context).FromMaybe(Local()); } Local prepare = env->prepare_stack_trace_callback(); if (prepare.IsEmpty()) { return exception->ToString(context).FromMaybe(Local()); } Local args[] = { context->Global(), exception, trace, }; // This TryCatch + Rethrow is required by V8 due to details around exception // handling there. For C++ callbacks, V8 expects a scheduled exception (which // is what ReThrow gives us). Just returning the empty MaybeLocal would leave // us with a pending exception. TryCatchScope try_catch(env); MaybeLocal result = prepare->Call(context, Undefined(env->isolate()), arraysize(args), args); if (try_catch.HasCaught() && !try_catch.HasTerminated()) { try_catch.ReThrow(); } return result; } void* NodeArrayBufferAllocator::Allocate(size_t size) { void* ret; if (zero_fill_field_ || per_process::cli_options->zero_fill_all_buffers) ret = allocator_->Allocate(size); else ret = allocator_->AllocateUninitialized(size); if (LIKELY(ret != nullptr)) total_mem_usage_.fetch_add(size, std::memory_order_relaxed); return ret; } void* NodeArrayBufferAllocator::AllocateUninitialized(size_t size) { void* ret = allocator_->AllocateUninitialized(size); if (LIKELY(ret != nullptr)) total_mem_usage_.fetch_add(size, std::memory_order_relaxed); return ret; } void* NodeArrayBufferAllocator::Reallocate( void* data, size_t old_size, size_t size) { void* ret = allocator_->Reallocate(data, old_size, size); if (LIKELY(ret != nullptr) || UNLIKELY(size == 0)) total_mem_usage_.fetch_add(size - old_size, std::memory_order_relaxed); return ret; } void NodeArrayBufferAllocator::Free(void* data, size_t size) { total_mem_usage_.fetch_sub(size, std::memory_order_relaxed); allocator_->Free(data, size); } DebuggingArrayBufferAllocator::~DebuggingArrayBufferAllocator() { CHECK(allocations_.empty()); } void* DebuggingArrayBufferAllocator::Allocate(size_t size) { Mutex::ScopedLock lock(mutex_); void* data = NodeArrayBufferAllocator::Allocate(size); RegisterPointerInternal(data, size); return data; } void* DebuggingArrayBufferAllocator::AllocateUninitialized(size_t size) { Mutex::ScopedLock lock(mutex_); void* data = NodeArrayBufferAllocator::AllocateUninitialized(size); RegisterPointerInternal(data, size); return data; } void DebuggingArrayBufferAllocator::Free(void* data, size_t size) { Mutex::ScopedLock lock(mutex_); UnregisterPointerInternal(data, size); NodeArrayBufferAllocator::Free(data, size); } void* DebuggingArrayBufferAllocator::Reallocate(void* data, size_t old_size, size_t size) { Mutex::ScopedLock lock(mutex_); void* ret = NodeArrayBufferAllocator::Reallocate(data, old_size, size); if (ret == nullptr) { if (size == 0) { // i.e. equivalent to free(). // suppress coverity warning as data is used as key versus as pointer // in UnregisterPointerInternal // coverity[pass_freed_arg] UnregisterPointerInternal(data, old_size); } return nullptr; } if (data != nullptr) { auto it = allocations_.find(data); CHECK_NE(it, allocations_.end()); allocations_.erase(it); } RegisterPointerInternal(ret, size); return ret; } void DebuggingArrayBufferAllocator::RegisterPointer(void* data, size_t size) { Mutex::ScopedLock lock(mutex_); NodeArrayBufferAllocator::RegisterPointer(data, size); RegisterPointerInternal(data, size); } void DebuggingArrayBufferAllocator::UnregisterPointer(void* data, size_t size) { Mutex::ScopedLock lock(mutex_); NodeArrayBufferAllocator::UnregisterPointer(data, size); UnregisterPointerInternal(data, size); } void DebuggingArrayBufferAllocator::UnregisterPointerInternal(void* data, size_t size) { if (data == nullptr) return; auto it = allocations_.find(data); CHECK_NE(it, allocations_.end()); if (size > 0) { // We allow allocations with size 1 for 0-length buffers to avoid having // to deal with nullptr values. CHECK_EQ(it->second, size); } allocations_.erase(it); } void DebuggingArrayBufferAllocator::RegisterPointerInternal(void* data, size_t size) { if (data == nullptr) return; CHECK_EQ(allocations_.count(data), 0); allocations_[data] = size; } std::unique_ptr ArrayBufferAllocator::Create(bool debug) { if (debug || per_process::cli_options->debug_arraybuffer_allocations) return std::make_unique(); else return std::make_unique(); } ArrayBufferAllocator* CreateArrayBufferAllocator() { return ArrayBufferAllocator::Create().release(); } void FreeArrayBufferAllocator(ArrayBufferAllocator* allocator) { delete allocator; } void SetIsolateCreateParamsForNode(Isolate::CreateParams* params) { const uint64_t constrained_memory = uv_get_constrained_memory(); const uint64_t total_memory = constrained_memory > 0 ? std::min(uv_get_total_memory(), constrained_memory) : uv_get_total_memory(); if (total_memory > 0 && params->constraints.max_old_generation_size_in_bytes() == 0) { // V8 defaults to 700MB or 1.4GB on 32 and 64 bit platforms respectively. // This default is based on browser use-cases. Tell V8 to configure the // heap based on the actual physical memory. params->constraints.ConfigureDefaults(total_memory, 0); } params->embedder_wrapper_object_index = BaseObject::InternalFields::kSlot; params->embedder_wrapper_type_index = std::numeric_limits::max(); #ifdef NODE_ENABLE_VTUNE_PROFILING params->code_event_handler = vTune::GetVtuneCodeEventHandler(); #endif } void SetIsolateErrorHandlers(v8::Isolate* isolate, const IsolateSettings& s) { if (s.flags & MESSAGE_LISTENER_WITH_ERROR_LEVEL) isolate->AddMessageListenerWithErrorLevel( errors::PerIsolateMessageListener, Isolate::MessageErrorLevel::kMessageError | Isolate::MessageErrorLevel::kMessageWarning); auto* abort_callback = s.should_abort_on_uncaught_exception_callback ? s.should_abort_on_uncaught_exception_callback : ShouldAbortOnUncaughtException; isolate->SetAbortOnUncaughtExceptionCallback(abort_callback); auto* fatal_error_cb = s.fatal_error_callback ? s.fatal_error_callback : OnFatalError; isolate->SetFatalErrorHandler(fatal_error_cb); isolate->SetOOMErrorHandler(OOMErrorHandler); if ((s.flags & SHOULD_NOT_SET_PREPARE_STACK_TRACE_CALLBACK) == 0) { auto* prepare_stack_trace_cb = s.prepare_stack_trace_callback ? s.prepare_stack_trace_callback : PrepareStackTraceCallback; isolate->SetPrepareStackTraceCallback(prepare_stack_trace_cb); } } void SetIsolateMiscHandlers(v8::Isolate* isolate, const IsolateSettings& s) { isolate->SetMicrotasksPolicy(s.policy); auto* allow_wasm_codegen_cb = s.allow_wasm_code_generation_callback ? s.allow_wasm_code_generation_callback : AllowWasmCodeGenerationCallback; isolate->SetAllowWasmCodeGenerationCallback(allow_wasm_codegen_cb); auto* modify_code_generation_from_strings_callback = ModifyCodeGenerationFromStrings; if (s.modify_code_generation_from_strings_callback != nullptr) { modify_code_generation_from_strings_callback = s.modify_code_generation_from_strings_callback; } isolate->SetModifyCodeGenerationFromStringsCallback( modify_code_generation_from_strings_callback); Mutex::ScopedLock lock(node::per_process::cli_options_mutex); if (per_process::cli_options->get_per_isolate_options() ->get_per_env_options() ->experimental_fetch) { isolate->SetWasmStreamingCallback(wasm_web_api::StartStreamingCompilation); } if (per_process::cli_options->get_per_isolate_options() ->experimental_shadow_realm) { isolate->SetHostCreateShadowRealmContextCallback( shadow_realm::HostCreateShadowRealmContextCallback); } if ((s.flags & SHOULD_NOT_SET_PROMISE_REJECTION_CALLBACK) == 0) { auto* promise_reject_cb = s.promise_reject_callback ? s.promise_reject_callback : PromiseRejectCallback; isolate->SetPromiseRejectCallback(promise_reject_cb); } if (s.flags & DETAILED_SOURCE_POSITIONS_FOR_PROFILING) v8::CpuProfiler::UseDetailedSourcePositionsForProfiling(isolate); } void SetIsolateUpForNode(v8::Isolate* isolate, const IsolateSettings& settings) { SetIsolateErrorHandlers(isolate, settings); SetIsolateMiscHandlers(isolate, settings); } void SetIsolateUpForNode(v8::Isolate* isolate) { IsolateSettings settings; SetIsolateUpForNode(isolate, settings); } // TODO(joyeecheung): we may want to expose this, but then we need to be // careful about what we override in the params. Isolate* NewIsolate(Isolate::CreateParams* params, uv_loop_t* event_loop, MultiIsolatePlatform* platform, const SnapshotData* snapshot_data, const IsolateSettings& settings) { Isolate* isolate = Isolate::Allocate(); if (isolate == nullptr) return nullptr; if (snapshot_data != nullptr) { SnapshotBuilder::InitializeIsolateParams(snapshot_data, params); } #ifdef NODE_V8_SHARED_RO_HEAP { // In shared-readonly-heap mode, V8 requires all snapshots used for // creating Isolates to be identical. This isn't really memory-safe // but also otherwise just doesn't work, and the only real alternative // is disabling shared-readonly-heap mode altogether. static Isolate::CreateParams first_params = *params; params->snapshot_blob = first_params.snapshot_blob; params->external_references = first_params.external_references; } #endif // Register the isolate on the platform before the isolate gets initialized, // so that the isolate can access the platform during initialization. platform->RegisterIsolate(isolate, event_loop); SetIsolateCreateParamsForNode(params); Isolate::Initialize(isolate, *params); if (snapshot_data == nullptr) { // If in deserialize mode, delay until after the deserialization is // complete. SetIsolateUpForNode(isolate, settings); } else { SetIsolateMiscHandlers(isolate, settings); } return isolate; } Isolate* NewIsolate(ArrayBufferAllocator* allocator, uv_loop_t* event_loop, MultiIsolatePlatform* platform, const EmbedderSnapshotData* snapshot_data, const IsolateSettings& settings) { Isolate::CreateParams params; if (allocator != nullptr) params.array_buffer_allocator = allocator; return NewIsolate(¶ms, event_loop, platform, SnapshotData::FromEmbedderWrapper(snapshot_data), settings); } Isolate* NewIsolate(std::shared_ptr allocator, uv_loop_t* event_loop, MultiIsolatePlatform* platform, const EmbedderSnapshotData* snapshot_data, const IsolateSettings& settings) { Isolate::CreateParams params; if (allocator) params.array_buffer_allocator_shared = allocator; return NewIsolate(¶ms, event_loop, platform, SnapshotData::FromEmbedderWrapper(snapshot_data), settings); } IsolateData* CreateIsolateData( Isolate* isolate, uv_loop_t* loop, MultiIsolatePlatform* platform, ArrayBufferAllocator* allocator, const EmbedderSnapshotData* embedder_snapshot_data) { const SnapshotData* snapshot_data = SnapshotData::FromEmbedderWrapper(embedder_snapshot_data); return new IsolateData(isolate, loop, platform, allocator, snapshot_data); } void FreeIsolateData(IsolateData* isolate_data) { delete isolate_data; } InspectorParentHandle::~InspectorParentHandle() {} // Hide the internal handle class from the public API. #if HAVE_INSPECTOR struct InspectorParentHandleImpl : public InspectorParentHandle { std::unique_ptr impl; explicit InspectorParentHandleImpl( std::unique_ptr&& impl) : impl(std::move(impl)) {} }; #endif Environment* CreateEnvironment( IsolateData* isolate_data, Local context, const std::vector& args, const std::vector& exec_args, EnvironmentFlags::Flags flags, ThreadId thread_id, std::unique_ptr inspector_parent_handle) { Isolate* isolate = isolate_data->isolate(); HandleScope handle_scope(isolate); const bool use_snapshot = context.IsEmpty(); const EnvSerializeInfo* env_snapshot_info = nullptr; if (use_snapshot) { CHECK_NOT_NULL(isolate_data->snapshot_data()); env_snapshot_info = &isolate_data->snapshot_data()->env_info; } // TODO(addaleax): This is a much better place for parsing per-Environment // options than the global parse call. Environment* env = new Environment(isolate_data, isolate, args, exec_args, env_snapshot_info, flags, thread_id); CHECK_NOT_NULL(env); if (use_snapshot) { context = Context::FromSnapshot(isolate, SnapshotData::kNodeMainContextIndex, {DeserializeNodeInternalFields, env}) .ToLocalChecked(); CHECK(!context.IsEmpty()); Context::Scope context_scope(context); if (InitializeContextRuntime(context).IsNothing()) { FreeEnvironment(env); return nullptr; } SetIsolateErrorHandlers(isolate, {}); } Context::Scope context_scope(context); env->InitializeMainContext(context, env_snapshot_info); #if HAVE_INSPECTOR if (env->should_create_inspector()) { if (inspector_parent_handle) { env->InitializeInspector(std::move( static_cast(inspector_parent_handle.get()) ->impl)); } else { env->InitializeInspector({}); } } #endif if (!use_snapshot && env->principal_realm()->RunBootstrapping().IsEmpty()) { FreeEnvironment(env); return nullptr; } return env; } void FreeEnvironment(Environment* env) { Isolate* isolate = env->isolate(); Isolate::DisallowJavascriptExecutionScope disallow_js(isolate, Isolate::DisallowJavascriptExecutionScope::THROW_ON_FAILURE); { HandleScope handle_scope(isolate); // For env->context(). Context::Scope context_scope(env->context()); SealHandleScope seal_handle_scope(isolate); // Set the flag in accordance with the DisallowJavascriptExecutionScope // above. env->set_can_call_into_js(false); env->set_stopping(true); env->stop_sub_worker_contexts(); env->RunCleanup(); RunAtExit(env); } // This call needs to be made while the `Environment` is still alive // because we assume that it is available for async tracking in the // NodePlatform implementation. MultiIsolatePlatform* platform = env->isolate_data()->platform(); if (platform != nullptr) platform->DrainTasks(isolate); delete env; } NODE_EXTERN std::unique_ptr GetInspectorParentHandle( Environment* env, ThreadId thread_id, const char* url) { return GetInspectorParentHandle(env, thread_id, url, ""); } NODE_EXTERN std::unique_ptr GetInspectorParentHandle( Environment* env, ThreadId thread_id, const char* url, const char* name) { CHECK_NOT_NULL(env); if (name == nullptr) name = ""; CHECK_NE(thread_id.id, static_cast(-1)); #if HAVE_INSPECTOR return std::make_unique( env->inspector_agent()->GetParentHandle(thread_id.id, url, name)); #else return {}; #endif } MaybeLocal LoadEnvironment( Environment* env, StartExecutionCallback cb) { env->InitializeLibuv(); env->InitializeDiagnostics(); return StartExecution(env, cb); } MaybeLocal LoadEnvironment(Environment* env, std::string_view main_script_source_utf8) { CHECK_NOT_NULL(main_script_source_utf8.data()); return LoadEnvironment( env, [&](const StartExecutionCallbackInfo& info) -> MaybeLocal { Local main_script = ToV8Value(env->context(), main_script_source_utf8).ToLocalChecked(); return info.run_cjs->Call( env->context(), Null(env->isolate()), 1, &main_script); }); } Environment* GetCurrentEnvironment(Local context) { return Environment::GetCurrent(context); } IsolateData* GetEnvironmentIsolateData(Environment* env) { return env->isolate_data(); } ArrayBufferAllocator* GetArrayBufferAllocator(IsolateData* isolate_data) { return isolate_data->node_allocator(); } Local GetMainContext(Environment* env) { return env->context(); } MultiIsolatePlatform* GetMultiIsolatePlatform(Environment* env) { return GetMultiIsolatePlatform(env->isolate_data()); } MultiIsolatePlatform* GetMultiIsolatePlatform(IsolateData* env) { return env->platform(); } MultiIsolatePlatform* CreatePlatform( int thread_pool_size, node::tracing::TracingController* tracing_controller) { return CreatePlatform( thread_pool_size, static_cast(tracing_controller)); } MultiIsolatePlatform* CreatePlatform( int thread_pool_size, v8::TracingController* tracing_controller) { return MultiIsolatePlatform::Create(thread_pool_size, tracing_controller) .release(); } void FreePlatform(MultiIsolatePlatform* platform) { delete platform; } std::unique_ptr MultiIsolatePlatform::Create( int thread_pool_size, v8::TracingController* tracing_controller, v8::PageAllocator* page_allocator) { return std::make_unique(thread_pool_size, tracing_controller, page_allocator); } MaybeLocal GetPerContextExports(Local context) { Isolate* isolate = context->GetIsolate(); EscapableHandleScope handle_scope(isolate); Local global = context->Global(); Local key = Private::ForApi(isolate, FIXED_ONE_BYTE_STRING(isolate, "node:per_context_binding_exports")); Local existing_value; if (!global->GetPrivate(context, key).ToLocal(&existing_value)) return MaybeLocal(); if (existing_value->IsObject()) return handle_scope.Escape(existing_value.As()); Local exports = Object::New(isolate); if (context->Global()->SetPrivate(context, key, exports).IsNothing() || InitializePrimordials(context).IsNothing()) return MaybeLocal(); return handle_scope.Escape(exports); } // Any initialization logic should be performed in // InitializeContext, because embedders don't necessarily // call NewContext and so they will experience breakages. Local NewContext(Isolate* isolate, Local object_template) { auto context = Context::New(isolate, nullptr, object_template); if (context.IsEmpty()) return context; if (InitializeContext(context).IsNothing()) { return Local(); } return context; } void ProtoThrower(const FunctionCallbackInfo& info) { THROW_ERR_PROTO_ACCESS(info.GetIsolate()); } // This runs at runtime, regardless of whether the context // is created from a snapshot. Maybe InitializeContextRuntime(Local context) { Isolate* isolate = context->GetIsolate(); HandleScope handle_scope(isolate); // When `IsCodeGenerationFromStringsAllowed` is true, V8 takes the fast path // and ignores the ModifyCodeGenerationFromStrings callback. Set it to false // to delegate the code generation validation to // node::ModifyCodeGenerationFromStrings. // The `IsCodeGenerationFromStringsAllowed` can be refreshed by V8 according // to the runtime flags, propagate the value to the embedder data. bool is_code_generation_from_strings_allowed = context->IsCodeGenerationFromStringsAllowed(); context->AllowCodeGenerationFromStrings(false); context->SetEmbedderData( ContextEmbedderIndex::kAllowCodeGenerationFromStrings, is_code_generation_from_strings_allowed ? True(isolate) : False(isolate)); if (per_process::cli_options->disable_proto == "") { return Just(true); } // Remove __proto__ // https://github.com/nodejs/node/issues/31951 Local prototype; { Local object_string = FIXED_ONE_BYTE_STRING(isolate, "Object"); Local prototype_string = FIXED_ONE_BYTE_STRING(isolate, "prototype"); Local object_v; if (!context->Global() ->Get(context, object_string) .ToLocal(&object_v)) { return Nothing(); } Local prototype_v; if (!object_v.As() ->Get(context, prototype_string) .ToLocal(&prototype_v)) { return Nothing(); } prototype = prototype_v.As(); } Local proto_string = FIXED_ONE_BYTE_STRING(isolate, "__proto__"); if (per_process::cli_options->disable_proto == "delete") { if (prototype ->Delete(context, proto_string) .IsNothing()) { return Nothing(); } } else if (per_process::cli_options->disable_proto == "throw") { Local thrower; if (!Function::New(context, ProtoThrower) .ToLocal(&thrower)) { return Nothing(); } PropertyDescriptor descriptor(thrower, thrower); descriptor.set_enumerable(false); descriptor.set_configurable(true); if (prototype ->DefineProperty(context, proto_string, descriptor) .IsNothing()) { return Nothing(); } } else if (per_process::cli_options->disable_proto != "") { // Validated in ProcessGlobalArgs FatalError("InitializeContextRuntime()", "invalid --disable-proto mode"); } return Just(true); } Maybe InitializeBaseContextForSnapshot(Local context) { Isolate* isolate = context->GetIsolate(); HandleScope handle_scope(isolate); // Delete `Intl.v8BreakIterator` // https://github.com/nodejs/node/issues/14909 { Context::Scope context_scope(context); Local intl_string = FIXED_ONE_BYTE_STRING(isolate, "Intl"); Local break_iter_string = FIXED_ONE_BYTE_STRING(isolate, "v8BreakIterator"); Local intl_v; if (!context->Global()->Get(context, intl_string).ToLocal(&intl_v)) { return Nothing(); } if (intl_v->IsObject() && intl_v.As()->Delete(context, break_iter_string).IsNothing()) { return Nothing(); } } return Just(true); } Maybe InitializeMainContextForSnapshot(Local context) { Isolate* isolate = context->GetIsolate(); HandleScope handle_scope(isolate); // Initialize the default values. context->SetEmbedderData(ContextEmbedderIndex::kAllowWasmCodeGeneration, True(isolate)); context->SetEmbedderData( ContextEmbedderIndex::kAllowCodeGenerationFromStrings, True(isolate)); if (InitializeBaseContextForSnapshot(context).IsNothing()) { return Nothing(); } return InitializePrimordials(context); } Maybe InitializePrimordials(Local context) { // Run per-context JS files. Isolate* isolate = context->GetIsolate(); Context::Scope context_scope(context); Local exports; Local primordials_string = FIXED_ONE_BYTE_STRING(isolate, "primordials"); // Create primordials first and make it available to per-context scripts. Local primordials = Object::New(isolate); if (primordials->SetPrototype(context, Null(isolate)).IsNothing() || !GetPerContextExports(context).ToLocal(&exports) || exports->Set(context, primordials_string, primordials).IsNothing()) { return Nothing(); } static const char* context_files[] = {"internal/per_context/primordials", "internal/per_context/domexception", "internal/per_context/messageport", nullptr}; // We do not have access to a per-Environment BuiltinLoader instance // at this point, because this code runs before an Environment exists // in the first place. However, creating BuiltinLoader instances is // relatively cheap and all the scripts that we may want to run at // startup are always present in it. thread_local builtins::BuiltinLoader builtin_loader; for (const char** module = context_files; *module != nullptr; module++) { Local arguments[] = {exports, primordials}; if (builtin_loader .CompileAndCall( context, *module, arraysize(arguments), arguments, nullptr) .IsEmpty()) { // Execution failed during context creation. return Nothing(); } } return Just(true); } // This initializes the main context (i.e. vm contexts are not included). Maybe InitializeContext(Local context) { if (InitializeMainContextForSnapshot(context).IsNothing()) { return Nothing(); } return InitializeContextRuntime(context); } uv_loop_t* GetCurrentEventLoop(Isolate* isolate) { HandleScope handle_scope(isolate); Local context = isolate->GetCurrentContext(); if (context.IsEmpty()) return nullptr; Environment* env = Environment::GetCurrent(context); if (env == nullptr) return nullptr; return env->event_loop(); } void AddLinkedBinding(Environment* env, const node_module& mod) { CHECK_NOT_NULL(env); Mutex::ScopedLock lock(env->extra_linked_bindings_mutex()); node_module* prev_tail = env->extra_linked_bindings_tail(); env->extra_linked_bindings()->push_back(mod); if (prev_tail != nullptr) prev_tail->nm_link = &env->extra_linked_bindings()->back(); } void AddLinkedBinding(Environment* env, const napi_module& mod) { node_module node_mod = napi_module_to_node_module(&mod); node_mod.nm_flags = NM_F_LINKED; AddLinkedBinding(env, node_mod); } void AddLinkedBinding(Environment* env, const char* name, addon_context_register_func fn, void* priv) { node_module mod = { NODE_MODULE_VERSION, NM_F_LINKED, nullptr, // nm_dso_handle nullptr, // nm_filename nullptr, // nm_register_func fn, name, priv, nullptr // nm_link }; AddLinkedBinding(env, mod); } void AddLinkedBinding(Environment* env, const char* name, napi_addon_register_func fn) { node_module mod = { -1, NM_F_LINKED, nullptr, // nm_dso_handle nullptr, // nm_filename nullptr, // nm_register_func [](v8::Local exports, v8::Local module, v8::Local context, void* priv) { napi_module_register_by_symbol( exports, module, context, reinterpret_cast(priv)); }, name, reinterpret_cast(fn), nullptr // nm_link }; AddLinkedBinding(env, mod); } static std::atomic next_thread_id{0}; ThreadId AllocateEnvironmentThreadId() { return ThreadId { next_thread_id++ }; } [[noreturn]] void Exit(ExitCode exit_code) { exit(static_cast(exit_code)); } void DefaultProcessExitHandlerInternal(Environment* env, ExitCode exit_code) { env->set_stopping(true); env->set_can_call_into_js(false); env->stop_sub_worker_contexts(); env->isolate()->DumpAndResetStats(); // The tracing agent could be in the process of writing data using the // threadpool. Stop it before shutting down libuv. The rest of the tracing // agent disposal will be performed in DisposePlatform(). per_process::v8_platform.StopTracingAgent(); // When the process exits, the tasks in the thread pool may also need to // access the data of V8Platform, such as trace agent, or a field // added in the future. So make sure the thread pool exits first. // And make sure V8Platform don not call into Libuv threadpool, see Dispose // in node_v8_platform-inl.h uv_library_shutdown(); DisposePlatform(); Exit(exit_code); } void DefaultProcessExitHandler(Environment* env, int exit_code) { DefaultProcessExitHandlerInternal(env, static_cast(exit_code)); } void SetProcessExitHandler( Environment* env, std::function&& handler) { env->set_process_exit_handler(std::move(handler)); } void SetProcessExitHandler(Environment* env, std::function&& handler) { auto movedHandler = std::move(handler); env->set_process_exit_handler([=](Environment* env, ExitCode exit_code) { movedHandler(env, static_cast(exit_code)); }); } } // namespace node