|
V8_INLINE IsolateAllocationMode | isolate_allocation_mode () |
|
v8::PageAllocator * | page_allocator () |
|
void | InitializeLoggingAndCounters () |
|
bool | InitializeCounters () |
|
bool | Init (StartupDeserializer *des) |
|
bool | IsInUse () |
|
void | ReleaseSharedPtrs () |
|
void | ClearSerializerData () |
|
bool | LogObjectRelocation () |
|
void | Enter () |
|
void | Exit () |
|
PerIsolateThreadData * | FindOrAllocatePerThreadDataForThisThread () |
|
PerIsolateThreadData * | FindPerThreadDataForThisThread () |
|
PerIsolateThreadData * | FindPerThreadDataForThread (ThreadId thread_id) |
|
void | DiscardPerThreadDataForThisThread () |
|
base::RecursiveMutex * | break_access () |
|
Address | get_address_from_id (IsolateAddressId id) |
|
Context | context () |
|
void | set_context (Context context) |
|
Context * | context_address () |
|
Object * | pending_exception () |
|
void | set_pending_exception (Object *exception_obj) |
|
void | clear_pending_exception () |
|
bool | AreWasmThreadsEnabled (Handle< Context > context) |
|
bool | has_pending_exception () |
|
v8::TryCatch * | try_catch_handler () |
|
bool * | external_caught_exception_address () |
|
void | clear_pending_message () |
|
Address | pending_message_obj_address () |
|
Object * | scheduled_exception () |
|
bool | has_scheduled_exception () |
|
void | clear_scheduled_exception () |
|
bool | IsJavaScriptHandlerOnTop (Object *exception) |
|
bool | IsExternalHandlerOnTop (Object *exception) |
|
bool | is_catchable_by_javascript (Object *exception) |
|
Address | c_function () |
|
Address * | c_entry_fp_address () |
|
Address * | handler_address () |
|
Address * | c_function_address () |
|
Address | js_entry_sp () |
|
Address * | js_entry_sp_address () |
|
Handle< JSGlobalObject > | global_object () |
|
Handle< JSObject > | global_proxy () |
|
void | FreeThreadResources () |
|
V8_EXPORT_PRIVATE bool | OptionalRescheduleException (bool is_bottom_call) |
|
void | PushPromise (Handle< JSObject > promise) |
|
void | PopPromise () |
|
Handle< Object > | GetPromiseOnStackOnThrow () |
|
bool | PromiseHasUserDefinedRejectHandler (Handle< Object > promise) |
|
void | SetCaptureStackTraceForUncaughtExceptions (bool capture, int frame_limit, StackTrace::StackTraceOptions options) |
|
void | SetAbortOnUncaughtExceptionCallback (v8::Isolate::AbortOnUncaughtExceptionCallback callback) |
|
void | PrintCurrentStackTrace (FILE *out) |
|
void | PrintStack (StringStream *accumulator, PrintStackMode mode=kPrintStackVerbose) |
|
V8_EXPORT_PRIVATE void | PrintStack (FILE *out, PrintStackMode mode=kPrintStackVerbose) |
|
Handle< String > | StackTraceString () |
|
V8_NOINLINE void | PushStackTraceAndDie (void *ptr1=nullptr, void *ptr2=nullptr, void *ptr3=nullptr, void *ptr4=nullptr) |
|
Handle< FixedArray > | CaptureCurrentStackTrace (int frame_limit, StackTrace::StackTraceOptions options) |
|
Handle< Object > | CaptureSimpleStackTrace (Handle< JSReceiver > error_object, FrameSkipMode mode, Handle< Object > caller) |
|
MaybeHandle< JSReceiver > | CaptureAndSetDetailedStackTrace (Handle< JSReceiver > error_object) |
|
MaybeHandle< JSReceiver > | CaptureAndSetSimpleStackTrace (Handle< JSReceiver > error_object, FrameSkipMode mode, Handle< Object > caller) |
|
Handle< FixedArray > | GetDetailedStackTrace (Handle< JSObject > error_object) |
|
Address | GetAbstractPC (int *line, int *column) |
|
bool | MayAccess (Handle< Context > accessing_context, Handle< JSObject > receiver) |
|
void | SetFailedAccessCheckCallback (v8::FailedAccessCheckCallback callback) |
|
void | ReportFailedAccessCheck (Handle< JSObject > receiver) |
|
Object * | Throw (Object *exception, MessageLocation *location=nullptr) |
|
Object * | ThrowIllegalOperation () |
|
template<typename T > |
V8_WARN_UNUSED_RESULT MaybeHandle< T > | Throw (Handle< Object > exception, MessageLocation *location=nullptr) |
|
void | set_console_delegate (debug::ConsoleDelegate *delegate) |
|
debug::ConsoleDelegate * | console_delegate () |
|
void | set_async_event_delegate (debug::AsyncEventDelegate *delegate) |
|
void | OnAsyncFunctionStateChanged (Handle< JSPromise > promise, debug::DebugAsyncActionType) |
|
Object * | ReThrow (Object *exception) |
|
Object * | UnwindAndFindHandler () |
|
CatchType | PredictExceptionCatcher () |
|
V8_EXPORT_PRIVATE void | ScheduleThrow (Object *exception) |
|
void | RestorePendingMessageFromTryCatch (v8::TryCatch *handler) |
|
void | CancelScheduledExceptionFromTryCatch (v8::TryCatch *handler) |
|
void | ReportPendingMessages () |
|
void | ReportPendingMessagesFromJavaScript () |
|
void | ReportPendingMessagesImpl (bool report_externally) |
|
MessageLocation | GetMessageLocation () |
|
Object * | PromoteScheduledException () |
|
bool | ComputeLocation (MessageLocation *target) |
|
bool | ComputeLocationFromException (MessageLocation *target, Handle< Object > exception) |
|
bool | ComputeLocationFromStackTrace (MessageLocation *target, Handle< Object > exception) |
|
Handle< JSMessageObject > | CreateMessage (Handle< Object > exception, MessageLocation *location) |
|
Object * | StackOverflow () |
|
Object * | TerminateExecution () |
|
void | CancelTerminateExecution () |
|
void | RequestInterrupt (InterruptCallback callback, void *data) |
|
void | InvokeApiInterruptCallbacks () |
|
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 () |
|
NativeContext | raw_native_context () |
|
Handle< Context > | GetIncumbentContext () |
|
void | RegisterTryCatchHandler (v8::TryCatch *that) |
|
void | UnregisterTryCatchHandler (v8::TryCatch *that) |
|
char * | ArchiveThread (char *to) |
|
char * | RestoreThread (char *from) |
|
Bootstrapper * | bootstrapper () |
|
Counters * | counters () |
|
const std::shared_ptr< Counters > & | async_counters () |
|
RuntimeProfiler * | runtime_profiler () |
|
CompilationCache * | compilation_cache () |
|
Logger * | logger () |
|
StackGuard * | stack_guard () |
|
Heap * | heap () |
|
const IsolateData * | isolate_data () const |
|
IsolateData * | isolate_data () |
|
Address | isolate_root () const |
|
RootsTable & | roots_table () |
|
base::AddressRegion | root_register_addressable_region () const |
|
Object * | root (RootIndex index) |
|
Handle< Object > | root_handle (RootIndex index) |
|
ExternalReferenceTable * | external_reference_table () |
|
V8_INLINE Address * | builtins_table () |
|
StubCache * | load_stub_cache () |
|
StubCache * | store_stub_cache () |
|
DeoptimizerData * | deoptimizer_data () |
|
bool | deoptimizer_lazy_throw () const |
|
void | set_deoptimizer_lazy_throw (bool value) |
|
ThreadLocalTop * | thread_local_top () |
|
MaterializedObjectStore * | materialized_object_store () |
|
DescriptorLookupCache * | descriptor_lookup_cache () |
|
HandleScopeData * | handle_scope_data () |
|
HandleScopeImplementer * | handle_scope_implementer () |
|
UnicodeCache * | unicode_cache () |
|
InnerPointerToCodeCache * | inner_pointer_to_code_cache () |
|
GlobalHandles * | global_handles () |
|
EternalHandles * | eternal_handles () |
|
ThreadManager * | thread_manager () |
|
unibrow::Mapping< unibrow::Ecma262UnCanonicalize > * | jsregexp_uncanonicalize () |
|
unibrow::Mapping< unibrow::CanonicalizationRange > * | jsregexp_canonrange () |
|
RuntimeState * | runtime_state () |
|
Builtins * | builtins () |
|
unibrow::Mapping< unibrow::Ecma262Canonicalize > * | regexp_macro_assembler_canonicalize () |
|
RegExpStack * | regexp_stack () |
|
size_t | total_regexp_code_generated () |
|
void | IncreaseTotalRegexpCodeGenerated (int size) |
|
std::vector< int > * | regexp_indices () |
|
unibrow::Mapping< unibrow::Ecma262Canonicalize > * | interp_canonicalize_mapping () |
|
Debug * | debug () |
|
bool * | is_profiling_address () |
|
CodeEventDispatcher * | code_event_dispatcher () const |
|
HeapProfiler * | heap_profiler () const |
|
v8::internal::Factory * | factory () |
|
void | SetData (uint32_t slot, void *data) |
|
void * | GetData (uint32_t slot) |
|
bool | serializer_enabled () const |
|
void | enable_serializer () |
|
bool | snapshot_available () const |
|
bool | IsDead () |
|
void | SignalFatalError () |
|
bool | use_optimizer () |
|
bool | initialized_from_snapshot () |
|
bool | NeedsSourcePositionsForProfiling () 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_collecting_type_profile () const |
|
void | SetFeedbackVectorsForProfilingTools (Object *value) |
|
void | MaybeInitializeVectorListFromHeap () |
|
double | time_millis_since_init () |
|
DateCache * | date_cache () |
|
void | set_date_cache (DateCache *date_cache) |
|
bool | IsArrayConstructorIntact () |
|
bool | IsNoElementsProtectorIntact (Context context) |
|
bool | IsNoElementsProtectorIntact () |
|
bool | IsArrayOrObjectOrStringPrototype (Object *object) |
|
bool | IsArraySpeciesLookupChainIntact () |
|
bool | IsTypedArraySpeciesLookupChainIntact () |
|
bool | IsRegExpSpeciesLookupChainIntact () |
|
bool | IsPromiseSpeciesLookupChainIntact () |
|
bool | IsIsConcatSpreadableLookupChainIntact () |
|
bool | IsIsConcatSpreadableLookupChainIntact (JSReceiver *receiver) |
|
bool | IsStringLengthOverflowIntact () |
|
bool | IsArrayIteratorLookupChainIntact () |
|
bool | IsMapIteratorLookupChainIntact () |
|
bool | IsSetIteratorLookupChainIntact () |
|
bool | IsStringIteratorLookupChainIntact () |
|
bool | IsArrayBufferNeuteringIntact () |
|
bool | IsPromiseHookProtectorIntact () |
|
bool | IsPromiseResolveLookupChainIntact () |
|
bool | IsPromiseThenLookupChainIntact () |
|
bool | IsPromiseThenLookupChainIntact (Handle< JSReceiver > receiver) |
|
void | UpdateNoElementsProtectorOnSetElement (Handle< JSObject > object) |
|
void | UpdateNoElementsProtectorOnSetLength (Handle< JSObject > object) |
|
void | UpdateNoElementsProtectorOnSetPrototype (Handle< JSObject > object) |
|
void | UpdateNoElementsProtectorOnNormalizeElements (Handle< JSObject > object) |
|
void | InvalidateArrayConstructorProtector () |
|
void | InvalidateArraySpeciesProtector () |
|
void | InvalidateTypedArraySpeciesProtector () |
|
void | InvalidateRegExpSpeciesProtector () |
|
void | InvalidatePromiseSpeciesProtector () |
|
void | InvalidateIsConcatSpreadableProtector () |
|
void | InvalidateStringLengthOverflowProtector () |
|
void | InvalidateArrayIteratorProtector () |
|
void | InvalidateMapIteratorProtector () |
|
void | InvalidateSetIteratorProtector () |
|
void | InvalidateStringIteratorProtector () |
|
void | InvalidateArrayBufferNeuteringProtector () |
|
V8_EXPORT_PRIVATE void | InvalidatePromiseHookProtector () |
|
void | InvalidatePromiseResolveProtector () |
|
void | InvalidatePromiseThenProtector () |
|
bool | IsAnyInitialArrayPrototype (Handle< JSArray > array) |
|
void | IterateDeferredHandles (RootVisitor *visitor) |
|
void | LinkDeferredHandles (DeferredHandles *deferred_handles) |
|
void | UnlinkDeferredHandles (DeferredHandles *deferred_handles) |
|
bool | concurrent_recompilation_enabled () |
|
OptimizingCompileDispatcher * | optimizing_compile_dispatcher () |
|
void | AbortConcurrentOptimization (BlockingBehavior blocking_behavior) |
|
int | id () const |
|
CompilationStatistics * | GetTurboStatistics () |
|
CodeTracer * | GetCodeTracer () |
|
void | DumpAndResetStats () |
|
void * | stress_deopt_count_address () |
|
void | set_force_slow_path (bool v) |
|
bool | force_slow_path () const |
|
bool * | force_slow_path_address () |
|
DebugInfo::ExecutionMode * | debug_execution_mode_address () |
|
V8_EXPORT_PRIVATE base::RandomNumberGenerator * | random_number_generator () |
|
V8_EXPORT_PRIVATE base::RandomNumberGenerator * | fuzzer_rng () |
|
int | GenerateIdentityHash (uint32_t mask) |
|
Code | FindCodeObject (Address a) |
|
int | NextOptimizationId () |
|
void | AddNearHeapLimitCallback (v8::NearHeapLimitCallback, void *data) |
|
void | RemoveNearHeapLimitCallback (v8::NearHeapLimitCallback callback, size_t heap_limit) |
|
void | AddCallCompletedCallback (CallCompletedCallback callback) |
|
void | RemoveCallCompletedCallback (CallCompletedCallback callback) |
|
void | FireCallCompletedCallback () |
|
void | AddBeforeCallEnteredCallback (BeforeCallEnteredCallback callback) |
|
void | RemoveBeforeCallEnteredCallback (BeforeCallEnteredCallback callback) |
|
void | FireBeforeCallEnteredCallback () |
|
void | AddMicrotasksCompletedCallback (MicrotasksCompletedCallback callback) |
|
void | RemoveMicrotasksCompletedCallback (MicrotasksCompletedCallback callback) |
|
void | FireMicrotasksCompletedCallback () |
|
void | SetPromiseRejectCallback (PromiseRejectCallback callback) |
|
void | ReportPromiseReject (Handle< JSPromise > promise, Handle< Object > value, v8::PromiseRejectEvent event) |
|
void | EnqueueMicrotask (Handle< Microtask > microtask) |
|
void | RunMicrotasks () |
|
bool | IsRunningMicrotasks () const |
|
Handle< Symbol > | SymbolFor (RootIndex dictionary_index, Handle< String > name, bool private_symbol) |
|
void | SetUseCounterCallback (v8::Isolate::UseCounterCallback callback) |
|
void | CountUsage (v8::Isolate::UseCounterFeature feature) |
|
Address | promise_hook_address () |
|
Address | async_event_delegate_address () |
|
Address | promise_hook_or_async_event_delegate_address () |
|
Address | default_microtask_queue_address () |
|
Address | promise_hook_or_debug_is_active_or_async_event_delegate_address () |
|
Address | handle_scope_implementer_address () |
|
void | SetAtomicsWaitCallback (v8::Isolate::AtomicsWaitCallback callback, void *data) |
|
void | RunAtomicsWaitCallback (v8::Isolate::AtomicsWaitEvent event, Handle< JSArrayBuffer > array_buffer, size_t offset_in_bytes, int32_t value, double timeout_in_ms, AtomicsWaitWakeHandle *stop_handle) |
|
void | SetPromiseHook (PromiseHook hook) |
|
void | RunPromiseHook (PromiseHookType type, Handle< JSPromise > promise, Handle< Object > parent) |
|
void | PromiseHookStateUpdated () |
|
void | AddDetachedContext (Handle< Context > context) |
|
void | CheckDetachedContextsAfterGC () |
|
std::vector< Object * > * | read_only_object_cache () |
|
std::vector< Object * > * | partial_snapshot_cache () |
|
bool | ShouldLoadConstantsFromRootList () const |
|
BuiltinsConstantsTableBuilder * | builtins_constants_table_builder () const |
|
const uint8_t * | embedded_blob () const |
|
uint32_t | embedded_blob_size () const |
|
void | set_array_buffer_allocator (v8::ArrayBuffer::Allocator *allocator) |
|
v8::ArrayBuffer::Allocator * | array_buffer_allocator () const |
|
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 () |
|
CompilerDispatcher * | compiler_dispatcher () const |
|
bool | IsInAnyContext (Object *object, uint32_t index) |
|
void | SetHostImportModuleDynamicallyCallback (HostImportModuleDynamicallyCallback callback) |
|
MaybeHandle< JSPromise > | RunHostImportModuleDynamicallyCallback (Handle< Script > referrer, Handle< Object > specifier) |
|
void | SetHostInitializeImportMetaObjectCallback (HostInitializeImportMetaObjectCallback callback) |
|
Handle< JSObject > | RunHostInitializeImportMetaObjectCallback (Handle< Module > module) |
|
void | SetPrepareStackTraceCallback (PrepareStackTraceCallback callback) |
|
MaybeHandle< Object > | RunPrepareStackTraceCallback (Handle< Context >, Handle< JSObject > Error, Handle< JSArray > sites) |
|
bool | HasPrepareStackTraceCallback () const |
|
void | SetRAILMode (RAILMode rail_mode) |
|
RAILMode | rail_mode () |
|
double | LoadStartTimeMs () |
|
void | IsolateInForegroundNotification () |
|
void | IsolateInBackgroundNotification () |
|
bool | IsIsolateInBackground () |
|
void | EnableMemorySavingsMode () |
|
void | DisableMemorySavingsMode () |
|
bool | IsMemorySavingsModeActive () |
|
| PRINTF_FORMAT (2, 3) void PrintWithTimestamp(const char *format |
|
void | set_allow_atomics_wait (bool set) |
|
bool | allow_atomics_wait () |
|
void | RegisterManagedPtrDestructor (ManagedPtrDestructor *finalizer) |
|
void | UnregisterManagedPtrDestructor (ManagedPtrDestructor *finalizer) |
|
size_t | elements_deletion_counter () |
|
void | set_elements_deletion_counter (size_t value) |
|
wasm::WasmEngine * | wasm_engine () const |
|
void | SetWasmEngine (std::shared_ptr< wasm::WasmEngine > engine) |
|
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) |
|