diff options
Diffstat (limited to 'components/script')
-rw-r--r-- | components/script/dom/bindings/trace.rs | 7 | ||||
-rw-r--r-- | components/script/dom/dedicatedworkerglobalscope.rs | 9 | ||||
-rw-r--r-- | components/script/dom/document.rs | 54 | ||||
-rw-r--r-- | components/script/dom/performancepainttiming.rs | 12 | ||||
-rw-r--r-- | components/script/dom/vrdisplay.rs | 3 | ||||
-rw-r--r-- | components/script/dom/websocket.rs | 3 | ||||
-rw-r--r-- | components/script/dom/window.rs | 14 | ||||
-rw-r--r-- | components/script/dom/workerglobalscope.rs | 2 | ||||
-rw-r--r-- | components/script/dom/worklet.rs | 2 | ||||
-rw-r--r-- | components/script/script_runtime.rs | 5 | ||||
-rw-r--r-- | components/script/script_thread.rs | 119 | ||||
-rw-r--r-- | components/script/task_source/dom_manipulation.rs | 1 | ||||
-rw-r--r-- | components/script/task_source/file_reading.rs | 1 | ||||
-rw-r--r-- | components/script/task_source/networking.rs | 2 | ||||
-rw-r--r-- | components/script/task_source/performance_timeline.rs | 3 | ||||
-rw-r--r-- | components/script/task_source/user_interaction.rs | 1 |
16 files changed, 202 insertions, 36 deletions
diff --git a/components/script/dom/bindings/trace.rs b/components/script/dom/bindings/trace.rs index 5c7723f17de..6f5dce2ab14 100644 --- a/components/script/dom/bindings/trace.rs +++ b/components/script/dom/bindings/trace.rs @@ -61,6 +61,7 @@ use js::glue::{CallObjectTracer, CallValueTracer}; use js::jsapi::{GCTraceKindToAscii, Heap, JSObject, JSTracer, TraceKind}; use js::jsval::JSVal; use js::rust::Runtime; +use metrics::{InteractiveMetrics, InteractiveWindow}; use msg::constellation_msg::{BrowsingContextId, FrameType, PipelineId, TopLevelBrowsingContextId}; use net_traits::{Metadata, NetworkError, ReferrerPolicy, ResourceThreads}; use net_traits::filemanager_thread::RelativePos; @@ -283,7 +284,7 @@ unsafe impl<T: JSTraceable, U: JSTraceable> JSTraceable for Result<T, U> { unsafe impl<K, V, S> JSTraceable for HashMap<K, V, S> where K: Hash + Eq + JSTraceable, V: JSTraceable, - S: BuildHasher + S: BuildHasher, { #[inline] unsafe fn trace(&self, trc: *mut JSTracer) { @@ -296,7 +297,7 @@ unsafe impl<K, V, S> JSTraceable for HashMap<K, V, S> unsafe impl<T, S> JSTraceable for HashSet<T, S> where T: Hash + Eq + JSTraceable, - S: BuildHasher + S: BuildHasher, { #[inline] unsafe fn trace(&self, trc: *mut JSTracer) { @@ -413,6 +414,8 @@ unsafe_no_jsmanaged_fields!(WebGLVertexArrayId); unsafe_no_jsmanaged_fields!(MediaList); unsafe_no_jsmanaged_fields!(WebVRGamepadHand); unsafe_no_jsmanaged_fields!(ScriptToConstellationChan); +unsafe_no_jsmanaged_fields!(InteractiveMetrics); +unsafe_no_jsmanaged_fields!(InteractiveWindow); unsafe impl<'a> JSTraceable for &'a str { #[inline] diff --git a/components/script/dom/dedicatedworkerglobalscope.rs b/components/script/dom/dedicatedworkerglobalscope.rs index 51c52e3f766..bf2077b743f 100644 --- a/components/script/dom/dedicatedworkerglobalscope.rs +++ b/components/script/dom/dedicatedworkerglobalscope.rs @@ -196,7 +196,8 @@ impl DedicatedWorkerGlobalScope { println!("error loading script {}", serialized_worker_url); parent_sender.send(CommonScriptMsg::Task( WorkerEvent, - Box::new(SimpleWorkerErrorHandler::new(worker)) + Box::new(SimpleWorkerErrorHandler::new(worker)), + pipeline_id )).unwrap(); return; } @@ -358,6 +359,7 @@ impl DedicatedWorkerGlobalScope { #[allow(unsafe_code)] pub fn forward_error_to_worker_object(&self, error_info: ErrorInfo) { let worker = self.worker.borrow().as_ref().unwrap().clone(); + let pipeline_id = worker.clone().root().global().pipeline_id(); let task = Box::new(task!(forward_error_to_worker_object: move || { let worker = worker.root(); let global = worker.global(); @@ -383,7 +385,7 @@ impl DedicatedWorkerGlobalScope { } })); // TODO: Should use the DOM manipulation task source. - self.parent_sender.send(CommonScriptMsg::Task(WorkerEvent, task)).unwrap(); + self.parent_sender.send(CommonScriptMsg::Task(WorkerEvent, task, Some(pipeline_id))).unwrap(); } } @@ -404,10 +406,11 @@ impl DedicatedWorkerGlobalScopeMethods for DedicatedWorkerGlobalScope { unsafe fn PostMessage(&self, cx: *mut JSContext, message: HandleValue) -> ErrorResult { let data = StructuredCloneData::write(cx, message)?; let worker = self.worker.borrow().as_ref().unwrap().clone(); + let pipeline_id = worker.clone().root().global().pipeline_id(); let task = Box::new(task!(post_worker_message: move || { Worker::handle_message(worker, data); })); - self.parent_sender.send(CommonScriptMsg::Task(WorkerEvent, task)).unwrap(); + self.parent_sender.send(CommonScriptMsg::Task(WorkerEvent, task, Some(pipeline_id))).unwrap(); Ok(()) } diff --git a/components/script/dom/document.rs b/components/script/dom/document.rs index 95408843f07..b9b4542697b 100644 --- a/components/script/dom/document.rs +++ b/components/script/dom/document.rs @@ -99,6 +99,7 @@ use hyper_serde::Serde; use ipc_channel::ipc::{self, IpcSender}; use js::jsapi::{JSContext, JSRuntime}; use js::jsapi::JS_GetRuntime; +use metrics::{InteractiveFlag, InteractiveMetrics, InteractiveWindow, ProfilerMetadataFactory, ProgressiveWebMetric}; use msg::constellation_msg::{ALT, CONTROL, SHIFT, SUPER}; use msg::constellation_msg::{BrowsingContextId, Key, KeyModifiers, KeyState, TopLevelBrowsingContextId}; use net_traits::{FetchResponseMsg, IpcSend, ReferrerPolicy}; @@ -108,6 +109,7 @@ use net_traits::pub_domains::is_pub_domain; use net_traits::request::RequestInit; use net_traits::response::HttpsState; use num_traits::ToPrimitive; +use profile_traits::time::{TimerMetadata, TimerMetadataFrameType, TimerMetadataReflowType}; use script_layout_interface::message::{Msg, NodesFromPointQueryType, ReflowGoal}; use script_runtime::{CommonScriptMsg, ScriptThreadEventCategory}; use script_thread::{MainThreadScriptMsg, ScriptThread}; @@ -360,6 +362,8 @@ pub struct Document { /// is inserted or removed from the document. /// See https://html.spec.whatwg.org/multipage/#form-owner form_id_listener_map: DomRefCell<HashMap<Atom, HashSet<Dom<Element>>>>, + interactive_time: DomRefCell<InteractiveMetrics>, + tti_window: DomRefCell<InteractiveWindow>, } #[derive(JSTraceable, MallocSizeOf)] @@ -1834,6 +1838,9 @@ impl Document { window.reflow(ReflowGoal::Full, ReflowReason::DOMContentLoaded); update_with_current_time_ms(&self.dom_content_loaded_event_end); + // html parsing has finished - set dom content loaded + self.interactive_time.borrow().maybe_set_tti(self, None, InteractiveFlag::DCL); + // Step 4.2. // TODO: client message queue. } @@ -1916,6 +1923,14 @@ impl Document { self.dom_interactive.get() } + pub fn get_interactive_metrics(&self) -> Ref<InteractiveMetrics> { + self.interactive_time.borrow() + } + + pub fn is_interactive(&self) -> bool { + self.get_interactive_metrics().get_tti().is_some() + } + pub fn get_dom_content_loaded_event_start(&self) -> u64 { self.dom_content_loaded_event_start.get() } @@ -1936,6 +1951,23 @@ impl Document { self.load_event_end.get() } + pub fn start_tti(&self) { + self.tti_window.borrow_mut().start_window(); + } + + /// check tti for this document + /// if it's been 10s since this doc encountered a task over 50ms, then we consider the + /// main thread available and try to set tti + pub fn check_tti(&self) { + if self.is_interactive() { return; } + + if self.tti_window.borrow().needs_check() { + self.get_interactive_metrics().maybe_set_tti(self, + Some(self.tti_window.borrow().get_start() as f64), + InteractiveFlag::TTI); + } + } + // https://html.spec.whatwg.org/multipage/#fire-a-focus-event fn fire_focus_event(&self, focus_event_type: FocusEventType, node: &Node, related_target: Option<&EventTarget>) { let (event_name, does_bubble) = match focus_event_type { @@ -2145,6 +2177,9 @@ impl Document { (DocumentReadyState::Complete, true) }; + let mut interactive_time = InteractiveMetrics::new(window.time_profiler_chan().clone()); + interactive_time.set_navigation_start(window.get_navigation_start()); + Document { node: Node::new_document_node(), window: Dom::from_ref(window), @@ -2236,6 +2271,8 @@ impl Document { dom_count: Cell::new(1), fullscreen_element: MutNullableDom::new(None), form_id_listener_map: Default::default(), + interactive_time: DomRefCell::new(interactive_time), + tti_window: DomRefCell::new(InteractiveWindow::new()), } } @@ -2579,11 +2616,13 @@ impl Document { self.send_to_constellation(event); } + let pipeline_id = self.window().pipeline_id(); + // Step 7 let trusted_pending = Trusted::new(pending); let trusted_promise = TrustedPromise::new(promise.clone()); let handler = ElementPerformFullscreenEnter::new(trusted_pending, trusted_promise, error); - let script_msg = CommonScriptMsg::Task(ScriptThreadEventCategory::EnterFullscreen, handler); + let script_msg = CommonScriptMsg::Task(ScriptThreadEventCategory::EnterFullscreen, handler, pipeline_id); let msg = MainThreadScriptMsg::Common(script_msg); window.main_thread_script_chan().send(msg).unwrap(); @@ -2615,7 +2654,8 @@ impl Document { let trusted_element = Trusted::new(element.r()); let trusted_promise = TrustedPromise::new(promise.clone()); let handler = ElementPerformFullscreenExit::new(trusted_element, trusted_promise); - let script_msg = CommonScriptMsg::Task(ScriptThreadEventCategory::ExitFullscreen, handler); + let pipeline_id = Some(global.pipeline_id()); + let script_msg = CommonScriptMsg::Task(ScriptThreadEventCategory::ExitFullscreen, handler, pipeline_id); let msg = MainThreadScriptMsg::Common(script_msg); window.main_thread_script_chan().send(msg).unwrap(); @@ -2673,6 +2713,16 @@ impl Element { } } +impl ProfilerMetadataFactory for Document { + fn new_metadata(&self) -> Option<TimerMetadata> { + Some(TimerMetadata { + url: String::from(self.url().as_str()), + iframe: TimerMetadataFrameType::RootWindow, + incremental: TimerMetadataReflowType::Incremental, + }) + } +} + impl DocumentMethods for Document { // https://drafts.csswg.org/cssom/#dom-document-stylesheets fn StyleSheets(&self) -> DomRoot<StyleSheetList> { diff --git a/components/script/dom/performancepainttiming.rs b/components/script/dom/performancepainttiming.rs index 4c25e785208..fb7b8b30209 100644 --- a/components/script/dom/performancepainttiming.rs +++ b/components/script/dom/performancepainttiming.rs @@ -9,7 +9,7 @@ use dom::bindings::str::DOMString; use dom::globalscope::GlobalScope; use dom::performanceentry::PerformanceEntry; use dom_struct::dom_struct; -use script_traits::PaintMetricType; +use script_traits::PWMType; #[dom_struct] pub struct PerformancePaintTiming { @@ -17,11 +17,11 @@ pub struct PerformancePaintTiming { } impl PerformancePaintTiming { - fn new_inherited(metric_type: PaintMetricType, start_time: f64) - -> PerformancePaintTiming { + fn new_inherited(metric_type: PWMType, start_time: f64) -> PerformancePaintTiming { let name = match metric_type { - PaintMetricType::FirstPaint => DOMString::from("first-paint"), - PaintMetricType::FirstContentfulPaint => DOMString::from("first-contentful-paint"), + PWMType::FirstPaint => DOMString::from("first-paint"), + PWMType::FirstContentfulPaint => DOMString::from("first-contentful-paint"), + _ => DOMString::from(""), }; PerformancePaintTiming { entry: PerformanceEntry::new_inherited(name, @@ -33,7 +33,7 @@ impl PerformancePaintTiming { #[allow(unrooted_must_root)] pub fn new(global: &GlobalScope, - metric_type: PaintMetricType, + metric_type: PWMType, start_time: f64) -> DomRoot<PerformancePaintTiming> { let entry = PerformancePaintTiming::new_inherited(metric_type, start_time); reflect_dom_object(Box::new(entry), global, PerformancePaintTimingBinding::Wrap) diff --git a/components/script/dom/vrdisplay.rs b/components/script/dom/vrdisplay.rs index d63e0f514e0..55d94412095 100644 --- a/components/script/dom/vrdisplay.rs +++ b/components/script/dom/vrdisplay.rs @@ -505,6 +505,7 @@ impl VRDisplay { let (raf_sender, raf_receiver) = mpsc::channel(); let mut near = near_init; let mut far = far_init; + // let pipeline_id = self.global().pipeline_id().clone(); TODO // Initialize compositor api_sender.send_vr(WebVRCommand::Create(display_id)).unwrap(); @@ -515,7 +516,7 @@ impl VRDisplay { let task = Box::new(task!(handle_vrdisplay_raf: move || { this.root().handle_raf(&sender); })); - js_sender.send(CommonScriptMsg::Task(WebVREvent, task)).unwrap(); + js_sender.send(CommonScriptMsg::Task(WebVREvent, task, None)).unwrap(); // Run Sync Poses in parallell on Render thread let msg = WebVRCommand::SyncPoses(display_id, near, far, sync_sender.clone()); diff --git a/components/script/dom/websocket.rs b/components/script/dom/websocket.rs index 47d3a6f3668..a29aed6f246 100644 --- a/components/script/dom/websocket.rs +++ b/components/script/dom/websocket.rs @@ -263,9 +263,10 @@ impl WebSocket { address: address, }); + let pipeline_id = self.global().pipeline_id(); self.global() .script_chan() - .send(CommonScriptMsg::Task(WebSocketEvent, task)) + .send(CommonScriptMsg::Task(WebSocketEvent, task, Some(pipeline_id))) .unwrap(); } diff --git a/components/script/dom/window.rs b/components/script/dom/window.rs index 1df5d6490c8..384c46a04fb 100644 --- a/components/script/dom/window.rs +++ b/components/script/dom/window.rs @@ -304,6 +304,11 @@ impl Window { } } + /// Get a sender to the time profiler thread. + pub fn time_profiler_chan(&self) -> &TimeProfilerChan { + self.globalscope.time_profiler_chan() + } + pub fn origin(&self) -> &MutableOrigin { self.globalscope.origin() } @@ -1040,6 +1045,10 @@ impl Window { } } + pub fn get_navigation_start(&self) -> f64 { + self.navigation_start_precise.get() + } + /// Cancels all the tasks associated with that window. /// /// This sets the current `ignore_further_async_events` sentinel value to @@ -1854,6 +1863,10 @@ impl Window { WindowBinding::Wrap(runtime.cx(), win) } } + + pub fn pipeline_id(&self) -> Option<PipelineId> { + Some(self.upcast::<GlobalScope>().pipeline_id()) + } } fn should_move_clip_rect(clip_rect: Rect<Au>, new_viewport: Rect<f32>) -> bool { @@ -1962,6 +1975,7 @@ impl Window { let _ = self.script_chan.send(CommonScriptMsg::Task( ScriptThreadEventCategory::DomEvent, Box::new(self.task_canceller().wrap_task(task)), + self.pipeline_id() )); } } diff --git a/components/script/dom/workerglobalscope.rs b/components/script/dom/workerglobalscope.rs index 4ebfd67a486..6638f1d1922 100644 --- a/components/script/dom/workerglobalscope.rs +++ b/components/script/dom/workerglobalscope.rs @@ -386,7 +386,7 @@ impl WorkerGlobalScope { pub fn process_event(&self, msg: CommonScriptMsg) { match msg { - CommonScriptMsg::Task(_, task) => { + CommonScriptMsg::Task(_, task, _) => { task.run_box() }, CommonScriptMsg::CollectReports(reports_chan) => { diff --git a/components/script/dom/worklet.rs b/components/script/dom/worklet.rs index ca48ec08fe8..e49163bb799 100644 --- a/components/script/dom/worklet.rs +++ b/components/script/dom/worklet.rs @@ -646,7 +646,7 @@ impl WorkletThread { where T: TaskBox + 'static, { - let msg = CommonScriptMsg::Task(ScriptThreadEventCategory::WorkletEvent, Box::new(task)); + let msg = CommonScriptMsg::Task(ScriptThreadEventCategory::WorkletEvent, Box::new(task), None); let msg = MainThreadScriptMsg::Common(msg); self.global_init.to_script_thread_sender.send(msg).expect("Worklet thread outlived script thread."); } diff --git a/components/script/script_runtime.rs b/components/script/script_runtime.rs index 7d3e5e60e1c..57e1bbd0755 100644 --- a/components/script/script_runtime.rs +++ b/components/script/script_runtime.rs @@ -22,6 +22,7 @@ use js::jsapi::{JSObject, RuntimeOptionsRef, SetPreserveWrapperCallback, SetEnqu use js::panic::wrap_panic; use js::rust::Runtime as RustRuntime; use microtask::{EnqueuedPromiseCallback, Microtask}; +use msg::constellation_msg::PipelineId; use profile_traits::mem::{Report, ReportKind, ReportsChan}; use script_thread::trace_thread; use servo_config::opts; @@ -44,14 +45,14 @@ pub enum CommonScriptMsg { /// supplied channel. CollectReports(ReportsChan), /// Generic message that encapsulates event handling. - Task(ScriptThreadEventCategory, Box<TaskBox>), + Task(ScriptThreadEventCategory, Box<TaskBox>, Option<PipelineId>), } impl fmt::Debug for CommonScriptMsg { fn fmt(&self, f: &mut fmt::Formatter) -> fmt::Result { match *self { CommonScriptMsg::CollectReports(_) => write!(f, "CollectReports(...)"), - CommonScriptMsg::Task(ref category, ref task) => { + CommonScriptMsg::Task(ref category, ref task, _) => { f.debug_tuple("Task").field(category).field(task).finish() }, } diff --git a/components/script/script_thread.rs b/components/script/script_thread.rs index 1a45b08e54b..1fe8c47b7bc 100644 --- a/components/script/script_thread.rs +++ b/components/script/script_thread.rs @@ -16,6 +16,7 @@ //! takes over the response body. Once parsing is complete, the document lifecycle for loading //! a page runs its course and the script thread returns to processing events in the main event //! loop. +#![feature(box_syntax)] use bluetooth_traits::BluetoothRequest; use canvas_traits::webgl::WebGLPipeline; @@ -74,7 +75,7 @@ use js::jsapi::{JSTracer, SetWindowProxyClass}; use js::jsval::UndefinedValue; use malloc_size_of::MallocSizeOfOps; use mem::malloc_size_of_including_self; -use metrics::PaintTimeMetrics; +use metrics::{InteractiveWindow, PaintTimeMetrics}; use microtask::{MicrotaskQueue, Microtask}; use msg::constellation_msg::{BrowsingContextId, FrameType, PipelineId, PipelineNamespace, TopLevelBrowsingContextId}; use net_traits::{FetchMetadata, FetchResponseListener, FetchResponseMsg}; @@ -91,7 +92,7 @@ use script_traits::{CompositorEvent, ConstellationControlMsg}; use script_traits::{DiscardBrowsingContext, DocumentActivity, EventResult}; use script_traits::{InitialScriptState, JsEvalResult, LayoutMsg, LoadData}; use script_traits::{MouseButton, MouseEventType, MozBrowserEvent, NewLayoutInfo}; -use script_traits::{PaintMetricType, Painter, ScriptMsg, ScriptThreadFactory}; +use script_traits::{PWMType, Painter, ScriptMsg, ScriptThreadFactory}; use script_traits::{ScriptToConstellationChan, TimerEvent, TimerSchedulerMsg}; use script_traits::{TimerSource, TouchEventType, TouchId, UntrustedNodeAddress}; use script_traits::{UpdatePipelineIdReason, WindowSizeData, WindowSizeType}; @@ -345,6 +346,10 @@ impl Documents { self.map.get(&pipeline_id).map(|doc| DomRoot::from_ref(&**doc)) } + pub fn len(&self) -> usize { + self.map.len() + } + pub fn find_window(&self, pipeline_id: PipelineId) -> Option<DomRoot<Window>> { self.find_document(pipeline_id).map(|doc| DomRoot::from_ref(doc.window())) } @@ -681,7 +686,8 @@ impl ScriptThread { SCRIPT_THREAD_ROOT.with(|root| { if let Some(script_thread) = root.get() { let script_thread = unsafe { &*script_thread }; - script_thread.profile_event(ScriptThreadEventCategory::AttachLayout, || { + let p_id = Some(new_layout_info.new_pipeline_id); + script_thread.profile_event(ScriptThreadEventCategory::AttachLayout, p_id, || { script_thread.handle_new_layout(new_layout_info, origin); }) } @@ -727,8 +733,8 @@ impl ScriptThread { pipeline_id: PipelineId, name: Atom, properties: Vec<Atom>, - painter: Box<Painter>, - ) { + painter: Box<Painter>) + { let window = self.documents.borrow().find_window(pipeline_id); let window = match window { Some(window) => window, @@ -840,7 +846,7 @@ impl ScriptThread { control_chan: state.control_chan, control_port: control_port, script_sender: state.script_to_constellation_chan.sender.clone(), - time_profiler_chan: state.time_profiler_chan, + time_profiler_chan: state.time_profiler_chan.clone(), mem_profiler_chan: state.mem_profiler_chan, devtools_chan: state.devtools_chan, @@ -964,7 +970,8 @@ impl ScriptThread { // child list yet, causing the find() to fail. FromConstellation(ConstellationControlMsg::AttachLayout( new_layout_info)) => { - self.profile_event(ScriptThreadEventCategory::AttachLayout, || { + //FIXME there should be a pipeline id + self.profile_event(ScriptThreadEventCategory::AttachLayout, None, || { // If this is an about:blank load, it must share the creator's origin. // This must match the logic in the constellation when creating a new pipeline let origin = if new_layout_info.load_data.url.as_str() != "about:blank" { @@ -986,17 +993,17 @@ impl ScriptThread { } FromConstellation(ConstellationControlMsg::Resize(id, size, size_type)) => { // step 7.7 - self.profile_event(ScriptThreadEventCategory::Resize, || { + self.profile_event(ScriptThreadEventCategory::Resize, Some(id), || { self.handle_resize(id, size, size_type); }) } FromConstellation(ConstellationControlMsg::Viewport(id, rect)) => { - self.profile_event(ScriptThreadEventCategory::SetViewport, || { + self.profile_event(ScriptThreadEventCategory::SetViewport, Some(id), || { self.handle_viewport(id, rect); }) } FromConstellation(ConstellationControlMsg::SetScrollState(id, scroll_state)) => { - self.profile_event(ScriptThreadEventCategory::SetScrollState, || { + self.profile_event(ScriptThreadEventCategory::SetScrollState, Some(id), || { self.handle_set_scroll_state(id, &scroll_state); }) } @@ -1051,9 +1058,11 @@ impl ScriptThread { debug!("Processing events."); for msg in sequential { debug!("Processing event {:?}.", msg); + let category = self.categorize_msg(&msg); + let p_id = self.message_to_pipeline(&msg); - let result = self.profile_event(category, move || { + let result = self.profile_event(category, p_id, move || { match msg { FromConstellation(ConstellationControlMsg::ExitScriptThread) => { self.handle_exit_script_thread_msg(); @@ -1122,7 +1131,7 @@ impl ScriptThread { MixedMessage::FromImageCache(_) => ScriptThreadEventCategory::ImageCacheMsg, MixedMessage::FromScript(ref inner_msg) => { match *inner_msg { - MainThreadScriptMsg::Common(CommonScriptMsg::Task(category, _)) => { + MainThreadScriptMsg::Common(CommonScriptMsg::Task(category, ..)) => { category }, MainThreadScriptMsg::RegisterPaintWorklet { .. } => { @@ -1135,7 +1144,67 @@ impl ScriptThread { } } - fn profile_event<F, R>(&self, category: ScriptThreadEventCategory, f: F) -> R + fn message_to_pipeline(&self, msg: &MixedMessage) -> Option<PipelineId> { + use script_traits::ConstellationControlMsg::*; + match *msg { + MixedMessage::FromConstellation(ref inner_msg) => { + match *inner_msg { + NavigationResponse(id, _) => Some(id), + AttachLayout(ref new_layout_info) => Some(new_layout_info.new_pipeline_id), + Resize(id, ..) => Some(id), + ResizeInactive(id, ..) => Some(id), + ExitPipeline(id, ..) => Some(id), + ExitScriptThread => None, + SendEvent(id, ..) => Some(id), + Viewport(id, ..) => Some(id), + SetScrollState(id, ..) => Some(id), + GetTitle(id) => Some(id), + SetDocumentActivity(id, ..) => Some(id), + ChangeFrameVisibilityStatus(id, ..) => Some(id), + NotifyVisibilityChange(id, ..) => Some(id), + Navigate(id, ..) => Some(id), + PostMessage(id, ..) => Some(id), + MozBrowserEvent(id, ..) => Some(id), + UpdatePipelineId(_, _, id, _) => Some(id), + FocusIFrame(id, ..) => Some(id), + WebDriverScriptCommand(id, ..) => Some(id), + TickAllAnimations(id) => Some(id), + TransitionEnd(..) => None, + WebFontLoaded(id) => Some(id), + DispatchIFrameLoadEvent { .. } => None, + DispatchStorageEvent(id, ..) => Some(id), + ReportCSSError(id, ..) => Some(id), + Reload(id, ..) => Some(id), + WebVREvents(id, ..) => Some(id), + PaintMetric(..) => None, + InteractiveMetric(..) => None, + } + }, + MixedMessage::FromDevtools(_) => None, + MixedMessage::FromScript(ref inner_msg) => { + match *inner_msg { + MainThreadScriptMsg::Common(CommonScriptMsg::Task(_, _, pipeline_id)) => + pipeline_id, + MainThreadScriptMsg::Common(_) => None, //TODO double check + MainThreadScriptMsg::ExitWindow(pipeline_id) => Some(pipeline_id), + MainThreadScriptMsg::Navigate(pipeline_id, ..) => Some(pipeline_id), + MainThreadScriptMsg::WorkletLoaded(pipeline_id) => Some(pipeline_id), + MainThreadScriptMsg::RegisterPaintWorklet { pipeline_id, .. } => Some(pipeline_id), + MainThreadScriptMsg::DispatchJobQueue { .. } => None, + } + }, + MixedMessage::FromImageCache((pipeline_id, _)) => Some(pipeline_id), + MixedMessage::FromScheduler(ref timer_event) => { + let TimerEvent(source, _) = *timer_event; + match source { + TimerSource::FromWindow(pipeline_id) => Some(pipeline_id), + _ => None + } + } + } + } + + fn profile_event<F, R>(&self, category: ScriptThreadEventCategory, p_id: Option<PipelineId>, f: F) -> R where F: FnOnce() -> R { if opts::get().profile_script_events { let profiler_cat = match category { @@ -1169,7 +1238,24 @@ impl ScriptThread { ScriptThreadEventCategory::ExitFullscreen => ProfilerCategory::ScriptExitFullscreen, ScriptThreadEventCategory::PerformanceTimelineTask => ProfilerCategory::ScriptPerformanceEvent, }; - profile(profiler_cat, None, self.time_profiler_chan.clone(), f) + + let start = precise_time_ns(); + let t = profile(profiler_cat, None, self.time_profiler_chan.clone(), f); + let end = precise_time_ns(); + debug!("Task {:?} took {}", category, end - start); // TODO do we want to do anything with this? + + for (doc_id, doc) in self.documents.borrow().iter() { + match p_id { + Some(p_id) => { + if p_id == doc_id && end - start > InteractiveWindow::max_task_time() { + doc.start_tti() + } + }, + _ => () + } + doc.check_tti(); + } + t } else { f() } @@ -1240,6 +1326,7 @@ impl ScriptThread { self.handle_webvr_events(pipeline_id, events), ConstellationControlMsg::PaintMetric(pipeline_id, metric_type, metric_value) => self.handle_paint_metric(pipeline_id, metric_type, metric_value), + ConstellationControlMsg::InteractiveMetric(pipeline_id, metric_value) => (), //TODO msg @ ConstellationControlMsg::AttachLayout(..) | msg @ ConstellationControlMsg::Viewport(..) | msg @ ConstellationControlMsg::SetScrollState(..) | @@ -1257,7 +1344,7 @@ impl ScriptThread { MainThreadScriptMsg::ExitWindow(id) => { self.handle_exit_window_msg(id) }, - MainThreadScriptMsg::Common(CommonScriptMsg::Task(_, task)) => { + MainThreadScriptMsg::Common(CommonScriptMsg::Task(_, task, _)) => { task.run_box() } MainThreadScriptMsg::Common(CommonScriptMsg::CollectReports(chan)) => { @@ -2563,7 +2650,7 @@ impl ScriptThread { fn handle_paint_metric(&self, pipeline_id: PipelineId, - metric_type: PaintMetricType, + metric_type: PWMType, metric_value: f64) { let window = self.documents.borrow().find_window(pipeline_id); if let Some(window) = window { diff --git a/components/script/task_source/dom_manipulation.rs b/components/script/task_source/dom_manipulation.rs index 5eb20d2d274..16db9310693 100644 --- a/components/script/task_source/dom_manipulation.rs +++ b/components/script/task_source/dom_manipulation.rs @@ -37,6 +37,7 @@ impl TaskSource for DOMManipulationTaskSource { let msg = MainThreadScriptMsg::Common(CommonScriptMsg::Task( ScriptThreadEventCategory::ScriptEvent, Box::new(canceller.wrap_task(task)), + None //TODO )); self.0.send(msg).map_err(|_| ()) } diff --git a/components/script/task_source/file_reading.rs b/components/script/task_source/file_reading.rs index fe2ae2e4d17..8f4cdd80ac3 100644 --- a/components/script/task_source/file_reading.rs +++ b/components/script/task_source/file_reading.rs @@ -30,6 +30,7 @@ impl TaskSource for FileReadingTaskSource { self.0.send(CommonScriptMsg::Task( ScriptThreadEventCategory::FileRead, Box::new(canceller.wrap_task(task)), + None //TODO )) } } diff --git a/components/script/task_source/networking.rs b/components/script/task_source/networking.rs index 41795227e5d..0c2fd8f6162 100644 --- a/components/script/task_source/networking.rs +++ b/components/script/task_source/networking.rs @@ -27,6 +27,7 @@ impl TaskSource for NetworkingTaskSource { self.0.send(CommonScriptMsg::Task( ScriptThreadEventCategory::NetworkEvent, Box::new(canceller.wrap_task(task)), + None )) } } @@ -41,6 +42,7 @@ impl NetworkingTaskSource { self.0.send(CommonScriptMsg::Task( ScriptThreadEventCategory::NetworkEvent, Box::new(task), + None //TODO )) } } diff --git a/components/script/task_source/performance_timeline.rs b/components/script/task_source/performance_timeline.rs index 0de171c4949..a91865cf02f 100644 --- a/components/script/task_source/performance_timeline.rs +++ b/components/script/task_source/performance_timeline.rs @@ -40,7 +40,8 @@ impl TaskSource for PerformanceTimelineTaskSource { { let msg = CommonScriptMsg::Task( ScriptThreadEventCategory::PerformanceTimelineTask, - Box::new(canceller.wrap_task(task)) + Box::new(canceller.wrap_task(task)), + None ); self.0.send(msg).map_err(|_| ()) } diff --git a/components/script/task_source/user_interaction.rs b/components/script/task_source/user_interaction.rs index c10e870ac7e..ba90a26a080 100644 --- a/components/script/task_source/user_interaction.rs +++ b/components/script/task_source/user_interaction.rs @@ -37,6 +37,7 @@ impl TaskSource for UserInteractionTaskSource { let msg = MainThreadScriptMsg::Common(CommonScriptMsg::Task( ScriptThreadEventCategory::InputEvent, Box::new(canceller.wrap_task(task)), + None )); self.0.send(msg).map_err(|_| ()) } |