|
| Isolate (const Isolate &)=delete |
|
Isolate & | operator= (const Isolate &)=delete |
|
void * | operator new (size_t)=delete |
|
void | operator delete (void *)=delete |
|
void | SetUpFromReadOnlyArtifacts (ReadOnlyArtifacts *artifacts) |
|
void | set_read_only_heap (ReadOnlyHeap *ro_heap) |
|
v8::PageAllocator * | page_allocator () const |
|
bool | IsCurrent () const |
|
void | InitializeLoggingAndCounters () |
|
bool | InitializeCounters () |
|
bool | InitWithoutSnapshot () |
|
bool | InitWithSnapshot (SnapshotData *startup_snapshot_data, SnapshotData *read_only_snapshot_data, SnapshotData *shared_heap_snapshot_data, bool can_rehash) |
|
bool | IsInUse () |
|
void | ReleaseSharedPtrs () |
|
void | ClearSerializerData () |
|
void | UpdateLogObjectRelocation () |
|
void | Enter () |
|
void | Exit () |
|
PerIsolateThreadData * | FindOrAllocatePerThreadDataForThisThread () |
|
PerIsolateThreadData * | FindPerThreadDataForThisThread () |
|
PerIsolateThreadData * | FindPerThreadDataForThread (ThreadId thread_id) |
|
void | DiscardPerThreadDataForThisThread () |
|
base::RecursiveMutex * | break_access () |
|
base::Mutex * | feedback_vector_access () |
|
base::Mutex * | internalized_string_access () |
|
base::Mutex * | full_transition_array_access () |
|
base::Mutex * | shared_function_info_access () |
|
base::Mutex * | map_updater_access () |
|
base::Mutex * | boilerplate_migration_access () |
|
ReadOnlyArtifacts * | read_only_artifacts () const |
|
StringTable * | string_table () const |
|
StringForwardingTable * | string_forwarding_table () const |
|
SharedStructTypeRegistry * | shared_struct_type_registry () const |
|
Address | get_address_from_id (IsolateAddressId id) |
|
Tagged< Context > | context () const |
|
void | set_context (Tagged< Context > context) |
|
Tagged< Context > * | context_address () |
|
Tagged< Context > | topmost_script_having_context () const |
|
void | set_topmost_script_having_context (Tagged< Context > context) |
|
void | clear_topmost_script_having_context () |
|
Tagged< Context > * | topmost_script_having_context_address () |
|
void | set_thread_id (ThreadId id) |
|
ThreadId | thread_id () const |
|
void | InstallConditionalFeatures (DirectHandle< NativeContext > context) |
|
bool | IsSharedArrayBufferConstructorEnabled (DirectHandle< NativeContext > context) |
|
bool | IsWasmStringRefEnabled (DirectHandle< NativeContext > context) |
|
bool | IsWasmImportedStringsEnabled (DirectHandle< NativeContext > context) |
|
bool | IsWasmJSPIRequested (DirectHandle< NativeContext > context) |
|
bool | IsWasmJSPIEnabled (DirectHandle< NativeContext > context) |
|
bool | IsCompileHintsMagicEnabled (Handle< NativeContext > context) |
|
v8::TryCatch * | try_catch_handler () |
|
Tagged< Object > | exception () |
|
void | set_exception (Tagged< Object > exception_obj) |
|
void | clear_exception () |
|
void | clear_internal_exception () |
|
bool | has_exception () |
|
void | clear_pending_message () |
|
Tagged< Object > | pending_message () |
|
bool | has_pending_message () |
|
void | set_pending_message (Tagged< Object > message_obj) |
|
ExceptionHandlerType | TopExceptionHandlerType (Tagged< Object > exception) |
|
bool | is_catchable_by_javascript (Tagged< Object > exception) |
|
bool | is_catchable_by_wasm (Tagged< Object > exception) |
|
bool | is_execution_terminating () |
|
Address | c_function () |
|
Address * | c_entry_fp_address () |
|
Address * | handler_address () |
|
Address * | c_function_address () |
|
void | RegisterDeserializerStarted () |
|
void | RegisterDeserializerFinished () |
|
bool | has_active_deserializer () const |
|
Address | js_entry_sp () |
|
Address * | js_entry_sp_address () |
|
std::vector< MemoryRange > * | GetCodePages () const |
|
void | SetCodePages (std::vector< MemoryRange > *new_code_pages) |
|
Handle< JSGlobalObject > | global_object () |
|
Handle< JSGlobalProxy > | global_proxy () |
|
void | FreeThreadResources () |
|
bool | WalkCallStackAndPromiseTree (MaybeDirectHandle< JSPromise > rejected_promise, const std::function< void(PromiseHandler)> &callback) |
|
void | SetCaptureStackTraceForUncaughtExceptions (bool capture, int frame_limit, StackTrace::StackTraceOptions options) |
|
bool | get_capture_stack_trace_for_uncaught_exceptions () const |
|
void | SetAbortOnUncaughtExceptionCallback (v8::Isolate::AbortOnUncaughtExceptionCallback callback) |
|
void | PrintCurrentStackTrace (std::ostream &out, PrintCurrentStackTraceFilterCallback should_include_frame_callback=nullptr) |
|
void | PrintStack (StringStream *accumulator, PrintStackMode mode=kPrintStackVerbose) |
|
void | PrintStack (FILE *out, PrintStackMode mode=kPrintStackVerbose) |
|
DirectHandle< String > | StackTraceString () |
|
V8_NOINLINE void | PushStackTraceAndDie (void *ptr1=nullptr, void *ptr2=nullptr, void *ptr3=nullptr, void *ptr4=nullptr, void *ptr5=nullptr, void *ptr6=nullptr) |
|
V8_NOINLINE void | PushParamsAndDie (void *ptr1=nullptr, void *ptr2=nullptr, void *ptr3=nullptr, void *ptr4=nullptr, void *ptr5=nullptr, void *ptr6=nullptr) |
|
V8_NOINLINE void | PushStackTraceAndContinue (void *ptr1=nullptr, void *ptr2=nullptr, void *ptr3=nullptr, void *ptr4=nullptr, void *ptr5=nullptr, void *ptr6=nullptr) |
|
V8_NOINLINE void | PushParamsAndContinue (void *ptr1=nullptr, void *ptr2=nullptr, void *ptr3=nullptr, void *ptr4=nullptr, void *ptr5=nullptr, void *ptr6=nullptr) |
|
DirectHandle< StackTraceInfo > | CaptureDetailedStackTrace (int limit, StackTrace::StackTraceOptions options) |
|
MaybeDirectHandle< JSObject > | CaptureAndSetErrorStack (DirectHandle< JSObject > error_object, FrameSkipMode mode, Handle< Object > caller) |
|
Handle< StackTraceInfo > | GetDetailedStackTrace (DirectHandle< JSReceiver > error_object) |
|
Handle< FixedArray > | GetSimpleStackTrace (DirectHandle< JSReceiver > error_object) |
|
DirectHandle< String > | CurrentScriptNameOrSourceURL () |
|
MaybeDirectHandle< Script > | CurrentReferrerScript () |
|
bool | GetStackTraceLimit (Isolate *isolate, int *result) |
|
Address | GetAbstractPC (int *line, int *column) |
|
bool | MayAccess (DirectHandle< NativeContext > accessing_context, DirectHandle< JSObject > receiver) |
|
void | SetFailedAccessCheckCallback (v8::FailedAccessCheckCallback callback) |
|
V8_WARN_UNUSED_RESULT MaybeDirectHandle< Object > | ReportFailedAccessCheck (DirectHandle< JSObject > receiver) |
|
Tagged< Object > | Throw (Tagged< Object > exception, MessageLocation *location=nullptr) |
|
Tagged< Object > | ThrowAt (DirectHandle< JSObject > exception, MessageLocation *location) |
|
Tagged< Object > | ThrowIllegalOperation () |
|
void | FatalProcessOutOfHeapMemory (const char *location) |
|
void | set_console_delegate (debug::ConsoleDelegate *delegate) |
|
debug::ConsoleDelegate * | console_delegate () |
|
void | set_async_event_delegate (debug::AsyncEventDelegate *delegate) |
|
void | OnAsyncFunctionSuspended (DirectHandle< JSPromise > promise, DirectHandle< JSPromise > parent) |
|
void | OnPromiseThen (DirectHandle< JSPromise > promise) |
|
void | OnPromiseBefore (DirectHandle< JSPromise > promise) |
|
void | OnPromiseAfter (DirectHandle< JSPromise > promise) |
|
void | OnStackTraceCaptured (DirectHandle< StackTraceInfo > stack_trace) |
|
void | OnTerminationDuringRunMicrotasks () |
|
Tagged< Object > | ReThrow (Tagged< Object > exception) |
|
Tagged< Object > | ReThrow (Tagged< Object > exception, Tagged< Object > message) |
|
Tagged< Object > | UnwindAndFindHandler () |
|
CatchType | PredictExceptionCatcher () |
|
void | ReportPendingMessages (bool report=true) |
|
bool | ComputeLocation (MessageLocation *target) |
|
bool | ComputeLocationFromException (MessageLocation *target, DirectHandle< Object > exception) |
|
bool | ComputeLocationFromSimpleStackTrace (MessageLocation *target, DirectHandle< Object > exception) |
|
bool | ComputeLocationFromDetailedStackTrace (MessageLocation *target, DirectHandle< Object > exception) |
|
Handle< JSMessageObject > | CreateMessage (DirectHandle< Object > exception, MessageLocation *location) |
|
DirectHandle< JSMessageObject > | CreateMessageOrAbort (DirectHandle< Object > exception, MessageLocation *location) |
|
Handle< JSMessageObject > | CreateMessageFromException (DirectHandle< Object > exception) |
|
Tagged< Object > | StackOverflow () |
|
Tagged< Object > | TerminateExecution () |
|
void | CancelTerminateExecution () |
|
void | RequestInterrupt (InterruptCallback callback, void *data) |
|
void | InvokeApiInterruptCallbacks () |
|
void | RequestInvalidateNoProfilingProtector () |
|
void | Iterate (RootVisitor *v) |
|
void | Iterate (RootVisitor *v, ThreadLocalTop *t) |
|
char * | Iterate (RootVisitor *v, char *t) |
|
void | IterateThread (ThreadVisitor *v, char *t) |
|
Handle< NativeContext > | native_context () |
|
Tagged< NativeContext > | raw_native_context () |
|
DirectHandle< NativeContext > | GetIncumbentContext () |
|
DirectHandle< NativeContext > | GetIncumbentContextSlow () |
|
void | RegisterTryCatchHandler (v8::TryCatch *that) |
|
void | UnregisterTryCatchHandler (v8::TryCatch *that) |
|
char * | ArchiveThread (char *to) |
|
char * | RestoreThread (char *from) |
|
void | SetDetailedSourcePositionsForProfiling (bool value) |
|
bool | detailed_source_positions_for_profiling () const |
|
Bootstrapper * | bootstrapper () |
|
Counters * | counters () |
|
const std::shared_ptr< Counters > & | async_counters () |
|
const std::shared_ptr< metrics::Recorder > & | metrics_recorder () |
|
TieringManager * | tiering_manager () |
|
CompilationCache * | compilation_cache () |
|
V8FileLogger * | v8_file_logger () const |
|
StackGuard * | stack_guard () |
|
Heap * | heap () |
|
const Heap * | heap () const |
|
ReadOnlyHeap * | read_only_heap () const |
|
const IsolateData * | isolate_data () const |
|
IsolateData * | isolate_data () |
|
Address | cage_base () const |
|
Address | code_cage_base () const |
|
IsolateGroup * | isolate_group () const |
|
Address | isolate_root () const |
|
RootsTable & | roots_table () |
|
const RootsTable & | roots_table () const |
|
base::AddressRegion | root_register_addressable_region () const |
|
Tagged< Object > | root (RootIndex index) const |
|
Handle< Object > | root_handle (RootIndex index) |
|
ExternalReferenceTable * | external_reference_table () |
|
ExternalReferenceTable * | external_reference_table_unsafe () |
|
Address * | builtin_entry_table () |
|
V8_INLINE Address * | builtin_table () |
|
V8_INLINE Address * | builtin_tier0_table () |
|
bool | IsBuiltinTableHandleLocation (Address *handle_location) |
|
StubCache * | load_stub_cache () const |
|
StubCache * | store_stub_cache () const |
|
StubCache * | define_own_stub_cache () const |
|
Deoptimizer * | GetAndClearCurrentDeoptimizer () |
|
void | set_current_deoptimizer (Deoptimizer *deoptimizer) |
|
bool | deoptimizer_lazy_throw () const |
|
void | set_deoptimizer_lazy_throw (bool value) |
|
void | InitializeThreadLocal () |
|
ThreadLocalTop * | thread_local_top () |
|
ThreadLocalTop const * | thread_local_top () const |
|
uint8_t | error_message_param () |
|
MaterializedObjectStore * | materialized_object_store () const |
|
DescriptorLookupCache * | descriptor_lookup_cache () const |
|
V8_INLINE HandleScopeData * | handle_scope_data () |
|
HandleScopeImplementer * | handle_scope_implementer () const |
|
UnicodeCache * | unicode_cache () const |
|
InnerPointerToCodeCache * | inner_pointer_to_code_cache () |
|
GlobalHandles * | global_handles () const |
|
TracedHandles * | traced_handles () |
|
EternalHandles * | eternal_handles () const |
|
ThreadManager * | thread_manager () const |
|
bigint::Processor * | bigint_processor () |
|
unibrow::Mapping< unibrow::Ecma262UnCanonicalize > * | jsregexp_uncanonicalize () |
|
unibrow::Mapping< unibrow::CanonicalizationRange > * | jsregexp_canonrange () |
|
unibrow::Mapping< unibrow::Ecma262Canonicalize > * | regexp_macro_assembler_canonicalize () |
|
RuntimeState * | runtime_state () |
|
Builtins * | builtins () |
|
RegExpStack * | regexp_stack () const |
|
int32_t * | regexp_static_result_offsets_vector () const |
|
void | set_regexp_static_result_offsets_vector (int32_t *value) |
|
Address | address_of_regexp_static_result_offsets_vector () const |
|
std::unordered_set< int32_t * > & | active_dynamic_regexp_result_vectors () |
|
std::vector< int > * | regexp_indices () |
|
size_t | total_regexp_code_generated () const |
|
void | IncreaseTotalRegexpCodeGenerated (DirectHandle< HeapObject > code) |
|
Debug * | debug () const |
|
bool | is_profiling () const |
|
void | SetIsProfiling (bool enabled) |
|
bool | should_check_side_effects () const |
|
DebugInfo::ExecutionMode | debug_execution_mode () const |
|
void | set_debug_execution_mode (DebugInfo::ExecutionMode debug_execution_mode) |
|
Logger * | logger () const |
|
v8::internal::Factory * | factory () |
|
void | SetData (uint32_t slot, void *data) |
|
void * | GetData (uint32_t slot) const |
|
bool | serializer_enabled () const |
|
void | enable_serializer () |
|
bool | snapshot_available () const |
|
bool | IsDead () const |
|
void | SignalFatalError () |
|
bool | use_optimizer () |
|
bool | initialized_from_snapshot () |
|
bool | NeedsSourcePositions () const |
|
bool | IsLoggingCodeCreation () const |
|
bool | InFastCCall () const |
|
bool | AllowsCodeCompaction () const |
|
bool | NeedsDetailedOptimizedCodeLineInfo () const |
|
bool | is_best_effort_code_coverage () const |
|
bool | is_precise_count_code_coverage () const |
|
bool | is_precise_binary_code_coverage () const |
|
bool | is_block_count_code_coverage () const |
|
bool | is_block_binary_code_coverage () const |
|
bool | is_block_code_coverage () const |
|
bool | is_binary_code_coverage () const |
|
bool | is_count_code_coverage () const |
|
void | SetFeedbackVectorsForProfilingTools (Tagged< Object > value) |
|
void | MaybeInitializeVectorListFromHeap () |
|
double | time_millis_since_init () const |
|
DateCache * | date_cache () const |
|
void | set_date_cache (DateCache *date_cache) |
|
KnownPrototype | IsArrayOrObjectOrStringPrototype (Tagged< JSObject > object) |
|
void | UpdateNoElementsProtectorOnSetElement (DirectHandle< JSObject > object) |
|
void | UpdateNoElementsProtectorOnSetLength (DirectHandle< JSObject > object) |
|
void | UpdateProtectorsOnSetPrototype (DirectHandle< JSObject > object, DirectHandle< Object > new_prototype) |
|
void | UpdateNoElementsProtectorOnSetPrototype (DirectHandle< JSObject > object) |
|
void | UpdateTypedArrayLengthLookupChainProtectorOnSetPrototype (DirectHandle< JSObject > object) |
|
void | UpdateTypedArraySpeciesLookupChainProtectorOnSetPrototype (DirectHandle< JSObject > object) |
|
void | UpdateNumberStringNotRegexpLikeProtectorOnSetPrototype (DirectHandle< JSObject > object) |
|
void | UpdateNoElementsProtectorOnNormalizeElements (DirectHandle< JSObject > object) |
|
void | UpdateStringWrapperToPrimitiveProtectorOnSetPrototype (DirectHandle< JSObject > object, DirectHandle< Object > new_prototype) |
|
bool | IsInitialArrayPrototype (Tagged< JSArray > array) |
|
std::unique_ptr< PersistentHandles > | NewPersistentHandles () |
|
PersistentHandlesList * | persistent_handles_list () const |
|
bool | concurrent_recompilation_enabled () |
|
void | IncreaseConcurrentOptimizationPriority (CodeKind kind, Tagged< SharedFunctionInfo > function) |
|
OptimizingCompileDispatcher * | optimizing_compile_dispatcher () |
|
OptimizingCompileDispatcher * | SetOptimizingCompileDispatcherForTesting (OptimizingCompileDispatcher *dispatcher) |
|
void | AbortConcurrentOptimization (BlockingBehavior blocking_behavior) |
|
int | id () const |
|
bool | was_locker_ever_used () const |
|
void | set_was_locker_ever_used () |
|
std::shared_ptr< CompilationStatistics > | GetTurboStatistics () |
|
CodeTracer * | GetCodeTracer () |
|
void | DumpAndResetStats () |
|
void | DumpAndResetBuiltinsProfileData () |
|
uint64_t * | stress_deopt_count_address () |
|
void | set_force_slow_path (bool v) |
|
bool | force_slow_path () const |
|
bool * | force_slow_path_address () |
|
bool | jitless () const |
|
void | set_stack_size (size_t v) |
|
size_t | stack_size () |
|
base::RandomNumberGenerator * | random_number_generator () |
|
base::RandomNumberGenerator * | fuzzer_rng () |
|
int | GenerateIdentityHash (uint32_t mask) |
|
int | NextOptimizationId () |
|
unsigned | NextModuleAsyncEvaluationOrdinal () |
|
void | AddCallCompletedCallback (CallCompletedCallback callback) |
|
void | RemoveCallCompletedCallback (CallCompletedCallback callback) |
|
void | FireCallCompletedCallback (MicrotaskQueue *microtask_queue) |
|
void | AddBeforeCallEnteredCallback (BeforeCallEnteredCallback callback) |
|
void | RemoveBeforeCallEnteredCallback (BeforeCallEnteredCallback callback) |
|
void | FireBeforeCallEnteredCallback () |
|
void | SetPromiseRejectCallback (PromiseRejectCallback callback) |
|
void | ReportPromiseReject (DirectHandle< JSPromise > promise, DirectHandle< Object > value, v8::PromiseRejectEvent event) |
|
void | SetTerminationOnExternalTryCatch () |
|
DirectHandle< Symbol > | SymbolFor (RootIndex dictionary_index, Handle< String > name, bool private_symbol) |
|
void | SetUseCounterCallback (v8::Isolate::UseCounterCallback callback) |
|
void | CountUsage (v8::Isolate::UseCounterFeature feature) |
|
void | CountUsage (base::Vector< const v8::Isolate::UseCounterFeature > features) |
|
int | GetNextScriptId () |
|
uint32_t | next_unique_sfi_id () const |
|
uint32_t | GetAndIncNextUniqueSfiId () |
|
bool | HasContextPromiseHooks () const |
|
Address | promise_hook_flags_address () |
|
Address | promise_hook_address () |
|
Address | async_event_delegate_address () |
|
Address | javascript_execution_assert_address () |
|
void | IncrementJavascriptExecutionCounter () |
|
Address | handle_scope_implementer_address () |
|
void | SetReleaseCppHeapCallback (v8::Isolate::ReleaseCppHeapCallback callback) |
|
void | RunReleaseCppHeapCallback (std::unique_ptr< v8::CppHeap > cpp_heap) |
|
void | SetPromiseHook (PromiseHook hook) |
|
void | RunPromiseHook (PromiseHookType type, DirectHandle< JSPromise > promise, DirectHandle< Object > parent) |
|
void | RunAllPromiseHooks (PromiseHookType type, DirectHandle< JSPromise > promise, DirectHandle< Object > parent) |
|
void | UpdatePromiseHookProtector () |
|
void | PromiseHookStateUpdated () |
|
void | AddDetachedContext (DirectHandle< Context > context) |
|
void | CheckDetachedContextsAfterGC () |
|
void | DetachGlobal (DirectHandle< Context > env) |
|
std::vector< Tagged< Object > > * | startup_object_cache () |
|
std::vector< Tagged< Object > > * | shared_heap_object_cache () |
|
bool | IsGeneratingEmbeddedBuiltins () const |
|
BuiltinsConstantsTableBuilder * | builtins_constants_table_builder () const |
|
size_t | HashIsolateForEmbeddedBlob () |
|
const uint8_t * | embedded_blob_code () const |
|
uint32_t | embedded_blob_code_size () const |
|
const uint8_t * | embedded_blob_data () const |
|
uint32_t | embedded_blob_data_size () const |
|
bool | is_short_builtin_calls_enabled () const |
|
void | set_array_buffer_allocator (v8::ArrayBuffer::Allocator *allocator) |
|
v8::ArrayBuffer::Allocator * | array_buffer_allocator () const |
|
void | set_array_buffer_allocator_shared (std::shared_ptr< v8::ArrayBuffer::Allocator > allocator) |
|
std::shared_ptr< v8::ArrayBuffer::Allocator > | array_buffer_allocator_shared () const |
|
size_t * | array_buffer_max_size_address () |
|
FutexWaitListNode * | futex_wait_list_node () |
|
CancelableTaskManager * | cancelable_task_manager () |
|
const AstStringConstants * | ast_string_constants () const |
|
interpreter::Interpreter * | interpreter () const |
|
compiler::PerIsolateCompilerCache * | compiler_cache () const |
|
void | set_compiler_utils (compiler::PerIsolateCompilerCache *cache, Zone *zone) |
|
AccountingAllocator * | allocator () |
|
LazyCompileDispatcher * | lazy_compile_dispatcher () const |
|
bool | IsInCreationContext (Tagged< JSObject > object, uint32_t index) |
|
void | ClearKeptObjects () |
|
void | SetHostImportModuleDynamicallyCallback (HostImportModuleDynamicallyCallback callback) |
|
void | SetHostImportModuleWithPhaseDynamicallyCallback (HostImportModuleWithPhaseDynamicallyCallback callback) |
|
MaybeDirectHandle< JSPromise > | RunHostImportModuleDynamicallyCallback (MaybeDirectHandle< Script > maybe_referrer, Handle< Object > specifier, ModuleImportPhase phase, MaybeDirectHandle< Object > maybe_import_options_argument) |
|
void | SetHostInitializeImportMetaObjectCallback (HostInitializeImportMetaObjectCallback callback) |
|
MaybeHandle< JSObject > | RunHostInitializeImportMetaObjectCallback (DirectHandle< SourceTextModule > module) |
|
void | SetHostCreateShadowRealmContextCallback (HostCreateShadowRealmContextCallback callback) |
|
MaybeDirectHandle< NativeContext > | RunHostCreateShadowRealmContextCallback () |
|
bool | IsJSApiWrapperNativeError (DirectHandle< JSReceiver > obj) |
|
void | RegisterEmbeddedFileWriter (EmbeddedFileWriterInterface *writer) |
|
int | LookupOrAddExternallyCompiledFilename (const char *filename) |
|
const char * | GetExternallyCompiledFilename (int index) const |
|
int | GetExternallyCompiledFilenameCount () const |
|
void | PrepareBuiltinSourcePositionMap () |
|
void | SetPrepareStackTraceCallback (PrepareStackTraceCallback callback) |
|
MaybeDirectHandle< Object > | RunPrepareStackTraceCallback (DirectHandle< NativeContext >, DirectHandle< JSObject > Error, DirectHandle< JSArray > sites) |
|
bool | HasPrepareStackTraceCallback () const |
|
void | SetAddCrashKeyCallback (AddCrashKeyCallback callback) |
|
void | AddCrashKey (CrashKeyId id, const std::string &value) |
|
bool | interpreted_frames_native_stack () const |
|
void | SetIsLoading (bool is_loading) |
|
void | set_code_coverage_mode (debug::CoverageMode coverage_mode) |
|
debug::CoverageMode | code_coverage_mode () const |
|
void | SetPriority (v8::Isolate::Priority priority) |
|
v8::Isolate::Priority | priority () |
|
bool | is_backgrounded () |
|
bool | EfficiencyModeEnabled () |
|
bool | EfficiencyModeEnabledForTiering () |
|
bool | BatterySaverModeEnabled () |
|
bool | MemorySaverModeEnabled () |
|
| PRINTF_FORMAT (2, 3) void PrintWithTimestamp(const char *format |
|
void | set_allow_atomics_wait (bool set) |
|
bool | allow_atomics_wait () |
|
bool | flush_denormals () const |
|
void | RegisterManagedPtrDestructor (ManagedPtrDestructor *finalizer) |
|
void | UnregisterManagedPtrDestructor (ManagedPtrDestructor *finalizer) |
|
size_t | elements_deletion_counter () |
|
void | set_elements_deletion_counter (size_t value) |
|
const v8::Context::BackupIncumbentScope * | top_backup_incumbent_scope () const |
|
void | set_top_backup_incumbent_scope (const v8::Context::BackupIncumbentScope *top_backup_incumbent_scope) |
|
void | SetIdle (bool is_idle) |
|
void | CollectSourcePositionsForAllBytecodeArrays () |
|
void | AddCodeMemoryChunk (MutablePageMetadata *chunk) |
|
void | RemoveCodeMemoryChunk (MutablePageMetadata *chunk) |
|
void | AddCodeRange (Address begin, size_t length_in_bytes) |
|
bool | RequiresCodeRange () const |
|
v8::metrics::Recorder::ContextId | GetOrRegisterRecorderContextId (DirectHandle< NativeContext > context) |
|
MaybeLocal< v8::Context > | GetContextFromRecorderContextId (v8::metrics::Recorder::ContextId id) |
|
void | UpdateLongTaskStats () |
|
v8::metrics::LongTaskStats * | GetCurrentLongTaskStats () |
|
LocalIsolate * | main_thread_local_isolate () |
|
Isolate * | AsIsolate () |
|
LocalIsolate * | AsLocalIsolate () |
|
Isolate * | GetMainThreadIsolateUnsafe () |
|
LocalHeap * | main_thread_local_heap () |
|
LocalHeap * | CurrentLocalHeap () |
|
Address | continuation_preserved_embedder_data_address () |
|
bool | is_shared_space_isolate () const |
|
Isolate * | shared_space_isolate () const |
|
bool | has_shared_space () const |
|
GlobalSafepoint * | global_safepoint () const |
|
bool | owns_shareable_data () |
|
bool | log_object_relocation () const |
|
bool | OwnsStringTables () const |
|
bool | IsOnCentralStack () |
|
void | LocalsBlockListCacheRehash () |
|
void | LocalsBlockListCacheSet (DirectHandle< ScopeInfo > scope_info, DirectHandle< ScopeInfo > outer_scope_info, DirectHandle< StringSet > locals_blocklist) |
|
Tagged< Object > | LocalsBlockListCacheGet (DirectHandle< ScopeInfo > scope_info) |
|
void | VerifyStaticRoots () |
|
bool | enable_ro_allocation_for_snapshot () const |
|
void | set_battery_saver_mode_enabled (bool battery_saver_mode_enabled) |
|
void | set_memory_saver_mode_enabled (bool memory_saver_mode_enabled) |
|
std::list< std::unique_ptr< detail::WaiterQueueNode > > & | async_waiter_queue_nodes () |
|
void | ReportExceptionFunctionCallback (DirectHandle< JSReceiver > receiver, DirectHandle< FunctionTemplateInfo > function, v8::ExceptionContext callback_kind) |
|
void | ReportExceptionPropertyCallback (DirectHandle< JSReceiver > holder, DirectHandle< Name > name, v8::ExceptionContext callback_kind) |
|
void | SetExceptionPropagationCallback (ExceptionPropagationCallback callback) |
|
bool | IsFrozen () const |
|
void | Freeze (bool is_frozen) |
|
std::shared_ptr< v8::TaskRunner > | task_runner () const |
|