/* This Source Code Form is subject to the terms of the Mozilla Public * License, v. 2.0. If a copy of the MPL was not distributed with this * file, You can obtain one at http://mozilla.org/MPL/2.0/. */ //! The task that handles all painting. use app_units::Au; use azure::AzFloat; use azure::azure_hl::{BackendType, Color, DrawTarget, SurfaceFormat}; use canvas_traits::CanvasMsg; use display_list::{self, StackingContext}; use euclid::Matrix4; use euclid::point::Point2D; use euclid::rect::Rect; use euclid::size::Size2D; use font_cache_task::FontCacheTask; use font_context::FontContext; use ipc_channel::ipc::IpcSender; use layers::layers::{BufferRequest, LayerBuffer, LayerBufferSet}; use layers::platform::surface::{NativeDisplay, NativeSurface}; use msg::compositor_msg::{Epoch, FrameTreeId, LayerId, LayerKind, LayerProperties, PaintListener}; use msg::compositor_msg::{ScrollPolicy}; use msg::constellation_msg::Msg as ConstellationMsg; use msg::constellation_msg::PipelineExitType; use msg::constellation_msg::{ConstellationChan, Failure, PipelineId}; use paint_context::PaintContext; use profile_traits::mem::{self, ReportsChan}; use profile_traits::time::{self, profile}; use rand::{self, Rng}; use skia::gl_context::GLContext; use std::borrow::ToOwned; use std::collections::HashMap; use std::mem as std_mem; use std::sync::Arc; use std::sync::mpsc::{Receiver, Select, Sender, channel}; use url::Url; use util::geometry::ZERO_POINT; use util::opts; use util::task::spawn_named; use util::task::spawn_named_with_send_on_failure; use util::task_state; /// Information about a hardware graphics layer that layout sends to the painting task. #[derive(Clone, Deserialize, Serialize, HeapSizeOf)] pub struct PaintLayer { /// A per-pipeline ID describing this layer that should be stable across reflows. pub id: LayerId, /// The color of the background in this layer. Used for unpainted content. pub background_color: Color, /// The stacking context that represents the content of this layer. pub stacking_context: Arc, /// The scrolling policy of this layer. pub scroll_policy: ScrollPolicy, } impl PaintLayer { /// Creates a new `PaintLayer`. pub fn new(id: LayerId, background_color: Color, stacking_context: Arc, scroll_policy: ScrollPolicy) -> PaintLayer { PaintLayer { id: id, background_color: background_color, stacking_context: stacking_context, scroll_policy: scroll_policy, } } pub fn find_layer_with_layer_id(this: &Arc, layer_id: LayerId) -> Option> { if this.id == layer_id { return Some(this.clone()); } display_list::find_layer_with_layer_id(&this.stacking_context, layer_id) } } pub struct PaintRequest { pub buffer_requests: Vec, pub scale: f32, pub layer_id: LayerId, pub epoch: Epoch, pub layer_kind: LayerKind, } pub enum Msg { FromLayout(LayoutToPaintMsg), FromChrome(ChromeToPaintMsg), } #[derive(Deserialize, Serialize)] pub enum LayoutToPaintMsg { PaintInit(Epoch, PaintLayer), CanvasLayer(LayerId, IpcSender), Exit(Option>, PipelineExitType), } pub enum ChromeToPaintMsg { Paint(Vec, FrameTreeId), PaintPermissionGranted, PaintPermissionRevoked, CollectReports(ReportsChan), Exit(Option>, PipelineExitType), } pub struct PaintTask { id: PipelineId, _url: Url, layout_to_paint_port: Receiver, chrome_to_paint_port: Receiver, compositor: C, constellation_chan: ConstellationChan, /// A channel to the time profiler. time_profiler_chan: time::ProfilerChan, /// The root paint layer sent to us by the layout thread. root_paint_layer: Option>, /// Permission to send paint messages to the compositor paint_permission: bool, /// The current epoch counter is passed by the layout task current_epoch: Option, /// Communication handles to each of the worker threads. worker_threads: Vec, /// A map to track the canvas specific layers canvas_map: HashMap>, } // If we implement this as a function, we get borrowck errors from borrowing // the whole PaintTask struct. macro_rules! native_display( ($task:expr) => ( $task.native_display.as_ref().expect("Need a graphics context to do painting") ) ); impl PaintTask where C: PaintListener + Send + 'static { pub fn create(id: PipelineId, url: Url, chrome_to_paint_chan: Sender, layout_to_paint_port: Receiver, chrome_to_paint_port: Receiver, compositor: C, constellation_chan: ConstellationChan, font_cache_task: FontCacheTask, failure_msg: Failure, time_profiler_chan: time::ProfilerChan, mem_profiler_chan: mem::ProfilerChan, shutdown_chan: Sender<()>) { let ConstellationChan(c) = constellation_chan.clone(); spawn_named_with_send_on_failure(format!("PaintTask {:?}", id), task_state::PAINT, move || { { // Ensures that the paint task and graphics context are destroyed before the // shutdown message. let mut compositor = compositor; let native_display = compositor.native_display().map( |display| display); let worker_threads = WorkerThreadProxy::spawn(native_display.clone(), font_cache_task, time_profiler_chan.clone()); // FIXME: rust/#5967 let mut paint_task = PaintTask { id: id, _url: url, layout_to_paint_port: layout_to_paint_port, chrome_to_paint_port: chrome_to_paint_port, compositor: compositor, constellation_chan: constellation_chan, time_profiler_chan: time_profiler_chan, root_paint_layer: None, paint_permission: false, current_epoch: None, worker_threads: worker_threads, canvas_map: HashMap::new() }; let reporter_name = format!("paint-reporter-{}", id.0); mem_profiler_chan.run_with_memory_reporting(|| { paint_task.start(); }, reporter_name, chrome_to_paint_chan, ChromeToPaintMsg::CollectReports); // Tell all the worker threads to shut down. for worker_thread in &mut paint_task.worker_threads { worker_thread.exit() } } debug!("paint_task: shutdown_chan send"); shutdown_chan.send(()).unwrap(); }, ConstellationMsg::Failure(failure_msg), c); } fn start(&mut self) { debug!("PaintTask: beginning painting loop"); loop { let message = { let select = Select::new(); let mut layout_to_paint_handle = select.handle(&self.layout_to_paint_port); let mut chrome_to_paint_handle = select.handle(&self.chrome_to_paint_port); unsafe { layout_to_paint_handle.add(); chrome_to_paint_handle.add(); } let result = select.wait(); if result == layout_to_paint_handle.id() { Msg::FromLayout(self.layout_to_paint_port.recv().unwrap()) } else if result == chrome_to_paint_handle.id() { Msg::FromChrome(self.chrome_to_paint_port.recv().unwrap()) } else { panic!("unexpected select result") } }; match message { Msg::FromLayout(LayoutToPaintMsg::PaintInit(epoch, paint_layer)) => { self.current_epoch = Some(epoch); self.root_paint_layer = Some(Arc::new(paint_layer)); if !self.paint_permission { debug!("PaintTask: paint ready msg"); let ConstellationChan(ref mut c) = self.constellation_chan; c.send(ConstellationMsg::PainterReady(self.id)).unwrap(); continue; } self.initialize_layers(); } // Inserts a new canvas renderer to the layer map Msg::FromLayout(LayoutToPaintMsg::CanvasLayer(layer_id, canvas_renderer)) => { debug!("Renderer received for canvas with layer {:?}", layer_id); self.canvas_map.insert(layer_id, canvas_renderer); } Msg::FromChrome(ChromeToPaintMsg::Paint(requests, frame_tree_id)) => { if !self.paint_permission { debug!("PaintTask: paint ready msg"); let ConstellationChan(ref mut c) = self.constellation_chan; c.send(ConstellationMsg::PainterReady(self.id)).unwrap(); continue; } let mut replies = Vec::new(); for PaintRequest { buffer_requests, scale, layer_id, epoch, layer_kind } in requests { if self.current_epoch == Some(epoch) { self.paint(&mut replies, buffer_requests, scale, layer_id, layer_kind); } else { debug!("PaintTask: Ignoring requests with epoch mismatch: {:?} != {:?}", self.current_epoch, epoch); self.compositor.ignore_buffer_requests(buffer_requests); } } debug!("PaintTask: returning surfaces"); self.compositor.assign_painted_buffers(self.id, self.current_epoch.unwrap(), replies, frame_tree_id); } Msg::FromChrome(ChromeToPaintMsg::PaintPermissionGranted) => { self.paint_permission = true; if self.root_paint_layer.is_some() { self.initialize_layers(); } } Msg::FromChrome(ChromeToPaintMsg::PaintPermissionRevoked) => { self.paint_permission = false; } Msg::FromChrome(ChromeToPaintMsg::CollectReports(ref channel)) => { // FIXME(njn): should eventually measure the paint task. channel.send(Vec::new()) } Msg::FromLayout(LayoutToPaintMsg::Exit(ref response_channel, _)) | Msg::FromChrome(ChromeToPaintMsg::Exit(ref response_channel, _)) => { // Ask the compositor to remove any layers it is holding for this paint task. // FIXME(mrobinson): This can probably move back to the constellation now. self.compositor.notify_paint_task_exiting(self.id); debug!("PaintTask: Exiting."); response_channel.as_ref().map(|channel| channel.send(())); break; } } } } /// Paints one layer and places the painted tiles in `replies`. fn paint(&mut self, replies: &mut Vec<(LayerId, Box)>, mut tiles: Vec, scale: f32, layer_id: LayerId, layer_kind: LayerKind) { time::profile(time::ProfilerCategory::Painting, None, self.time_profiler_chan.clone(), || { // Bail out if there is no appropriate layer. let paint_layer = if let Some(ref root_paint_layer) = self.root_paint_layer { match PaintLayer::find_layer_with_layer_id(root_paint_layer, layer_id) { Some(paint_layer) => paint_layer, None => return, } } else { return }; // Divide up the layer into tiles and distribute them to workers via a simple round- // robin strategy. let tiles = std_mem::replace(&mut tiles, Vec::new()); let tile_count = tiles.len(); for (i, tile) in tiles.into_iter().enumerate() { let thread_id = i % self.worker_threads.len(); self.worker_threads[thread_id].paint_tile(thread_id, tile, paint_layer.clone(), scale, layer_kind); } let new_buffers = (0..tile_count).map(|i| { let thread_id = i % self.worker_threads.len(); self.worker_threads[thread_id].painted_tile_buffer() }).collect(); let layer_buffer_set = box LayerBufferSet { buffers: new_buffers, }; replies.push((layer_id, layer_buffer_set)); }) } fn initialize_layers(&mut self) { let root_paint_layer = match self.root_paint_layer { None => return, Some(ref root_paint_layer) => root_paint_layer, }; let mut properties = Vec::new(); build_from_paint_layer(&mut properties, root_paint_layer, &ZERO_POINT, &Matrix4::identity(), &Matrix4::identity(), None); self.compositor.initialize_layers_for_pipeline(self.id, properties, self.current_epoch.unwrap()); fn build_from_paint_layer(properties: &mut Vec, paint_layer: &Arc, page_position: &Point2D, transform: &Matrix4, perspective: &Matrix4, parent_id: Option) { let transform = transform.mul(&paint_layer.stacking_context.transform); let perspective = perspective.mul(&paint_layer.stacking_context.perspective); let overflow_size = Size2D::new( paint_layer.stacking_context.overflow.size.width.to_nearest_px() as f32, paint_layer.stacking_context.overflow.size.height.to_nearest_px() as f32); // Layers start at the top left of their overflow rect, as far as the info // we give to the compositor is concerned. let overflow_relative_page_position = *page_position + paint_layer.stacking_context.bounds.origin + paint_layer.stacking_context.overflow.origin; let layer_position = Rect::new( Point2D::new(overflow_relative_page_position.x.to_nearest_px() as f32, overflow_relative_page_position.y.to_nearest_px() as f32), overflow_size); properties.push(LayerProperties { id: paint_layer.id, parent_id: parent_id, rect: layer_position, background_color: paint_layer.background_color, scroll_policy: paint_layer.stacking_context.scroll_policy, transform: transform, perspective: perspective, establishes_3d_context: paint_layer.stacking_context.establishes_3d_context, scrolls_overflow_area: paint_layer.stacking_context.scrolls_overflow_area, subpage_layer_info: paint_layer.stacking_context.subpage_layer_info, }); // When there is a new layer, the transforms and origin are handled by the compositor, // so the new transform and perspective matrices are just the identity. continue_walking_stacking_context(properties, &paint_layer.stacking_context, &-paint_layer.stacking_context.overflow.origin, &Matrix4::identity(), &Matrix4::identity(), Some(paint_layer.id)); } fn build_from_stacking_context(properties: &mut Vec, stacking_context: &Arc, page_position: &Point2D, transform: &Matrix4, perspective: &Matrix4, parent_id: Option) { continue_walking_stacking_context(properties, stacking_context, &(stacking_context.bounds.origin + *page_position), &transform.mul(&stacking_context.transform), &perspective.mul(&stacking_context.perspective), parent_id); } fn continue_walking_stacking_context(properties: &mut Vec, stacking_context: &Arc, page_position: &Point2D, transform: &Matrix4, perspective: &Matrix4, parent_id: Option) { for kid in stacking_context.display_list.children.iter() { build_from_stacking_context(properties, &kid, &page_position, &transform, &perspective, parent_id) } for kid in stacking_context.display_list.layered_children.iter() { build_from_paint_layer(properties, &kid, &page_position, &transform, &perspective, parent_id) } } } } struct WorkerThreadProxy { sender: Sender, receiver: Receiver, } impl WorkerThreadProxy { fn spawn(native_display: Option, font_cache_task: FontCacheTask, time_profiler_chan: time::ProfilerChan) -> Vec { let thread_count = if opts::get().gpu_painting { 1 } else { opts::get().paint_threads }; (0..thread_count).map(|_| { let (from_worker_sender, from_worker_receiver) = channel(); let (to_worker_sender, to_worker_receiver) = channel(); let font_cache_task = font_cache_task.clone(); let time_profiler_chan = time_profiler_chan.clone(); spawn_named("PaintWorker".to_owned(), move || { let mut worker_thread = WorkerThread::new(from_worker_sender, to_worker_receiver, native_display, font_cache_task, time_profiler_chan); worker_thread.main(); }); WorkerThreadProxy { receiver: from_worker_receiver, sender: to_worker_sender, } }).collect() } fn paint_tile(&mut self, thread_id: usize, tile: BufferRequest, paint_layer: Arc, scale: f32, layer_kind: LayerKind) { let msg = MsgToWorkerThread::PaintTile(thread_id, tile, paint_layer, scale, layer_kind); self.sender.send(msg).unwrap() } fn painted_tile_buffer(&mut self) -> Box { match self.receiver.recv().unwrap() { MsgFromWorkerThread::PaintedTile(layer_buffer) => layer_buffer, } } fn exit(&mut self) { self.sender.send(MsgToWorkerThread::Exit).unwrap() } } struct WorkerThread { sender: Sender, receiver: Receiver, native_display: Option, font_context: Box, time_profiler_sender: time::ProfilerChan, gl_context: Option>, } fn create_gl_context(native_display: Option) -> Option> { if !opts::get().gpu_painting { return None; } match native_display { Some(display) => { let tile_size = opts::get().tile_size as i32; GLContext::new(display.platform_display_data(), Size2D::new(tile_size, tile_size)) } None => { warn!("Could not create GLContext, falling back to CPU rasterization"); None } } } impl WorkerThread { fn new(sender: Sender, receiver: Receiver, native_display: Option, font_cache_task: FontCacheTask, time_profiler_sender: time::ProfilerChan) -> WorkerThread { let gl_context = create_gl_context(native_display); WorkerThread { sender: sender, receiver: receiver, native_display: native_display, font_context: box FontContext::new(font_cache_task.clone()), time_profiler_sender: time_profiler_sender, gl_context: gl_context, } } fn main(&mut self) { loop { match self.receiver.recv().unwrap() { MsgToWorkerThread::Exit => break, MsgToWorkerThread::PaintTile(thread_id, tile, paint_layer, scale, layer_kind) => { let buffer = self.optimize_and_paint_tile(thread_id, tile, paint_layer, scale, layer_kind); self.sender.send(MsgFromWorkerThread::PaintedTile(buffer)).unwrap() } } } } fn create_draw_target_for_layer_buffer(&self, size: Size2D, layer_buffer: &mut Box) -> DrawTarget { match self.gl_context { Some(ref gl_context) => { match layer_buffer.native_surface.gl_rasterization_context(gl_context.clone()) { Some(rasterization_context) => { DrawTarget::new_with_gl_rasterization_context(rasterization_context, SurfaceFormat::B8G8R8A8) } None => panic!("Could not create GLRasterizationContext for LayerBuffer"), } }, None => { // A missing GLContext means we want CPU rasterization. DrawTarget::new(BackendType::Skia, size, SurfaceFormat::B8G8R8A8) } } } fn optimize_and_paint_tile(&mut self, thread_id: usize, mut tile: BufferRequest, paint_layer: Arc, scale: f32, layer_kind: LayerKind) -> Box { let stacking_context = &paint_layer.stacking_context; let size = Size2D::new(tile.screen_rect.size.width as i32, tile.screen_rect.size.height as i32); let mut buffer = self.create_layer_buffer(&mut tile, scale); let draw_target = self.create_draw_target_for_layer_buffer(size, &mut buffer); { // Build the paint context. let mut paint_context = PaintContext { draw_target: draw_target.clone(), font_context: &mut self.font_context, page_rect: tile.page_rect, screen_rect: tile.screen_rect, clip_rect: None, transient_clip: None, layer_kind: layer_kind, }; // Apply a translation to start at the boundaries of the stacking context, since the // layer's origin starts at its overflow rect's origin. let tile_bounds = tile.page_rect.translate( &Point2D::new(stacking_context.overflow.origin.x.to_f32_px(), stacking_context.overflow.origin.y.to_f32_px())); // Apply the translation to paint the tile we want. let matrix = Matrix4::identity(); let matrix = matrix.scale(scale as AzFloat, scale as AzFloat, 1.0); let matrix = matrix.translate(-tile_bounds.origin.x as AzFloat, -tile_bounds.origin.y as AzFloat, 0.0); // Clear the buffer. paint_context.clear(); // Draw the display list. time::profile(time::ProfilerCategory::PaintingPerTile, None, self.time_profiler_sender.clone(), || { stacking_context.optimize_and_draw_into_context(&mut paint_context, &matrix, None); paint_context.draw_target.flush(); }); if opts::get().show_debug_parallel_paint { // Overlay a transparent solid color to identify the thread that // painted this tile. let color = THREAD_TINT_COLORS[thread_id % THREAD_TINT_COLORS.len()]; paint_context.draw_solid_color(&Rect::new(Point2D::new(Au(0), Au(0)), Size2D::new(Au::from_px(size.width), Au::from_px(size.height))), color); } if opts::get().paint_flashing { // Overlay a random transparent color. let color = *rand::thread_rng().choose(&THREAD_TINT_COLORS[..]).unwrap(); paint_context.draw_solid_color(&Rect::new(Point2D::new(Au(0), Au(0)), Size2D::new(Au::from_px(size.width), Au::from_px(size.height))), color); } } // Extract the texture from the draw target and place it into its slot in the buffer. If // using CPU painting, upload it first. if self.gl_context.is_none() { draw_target.snapshot().get_data_surface().with_data(|data| { buffer.native_surface.upload(native_display!(self), data); debug!("painting worker thread uploading to native surface {}", buffer.native_surface.get_id()); }); } draw_target.finish(); buffer } fn create_layer_buffer(&mut self, tile: &mut BufferRequest, scale: f32) -> Box { // Create an empty native surface. We mark it as not leaking // in case it dies in transit to the compositor task. let width = tile.screen_rect.size.width; let height = tile.screen_rect.size.height; let mut native_surface = tile.native_surface.take().unwrap_or_else(|| { NativeSurface::new(native_display!(self), Size2D::new(width as i32, height as i32)) }); native_surface.mark_wont_leak(); box LayerBuffer { native_surface: native_surface, rect: tile.page_rect, screen_pos: tile.screen_rect, resolution: scale, painted_with_cpu: self.gl_context.is_none(), content_age: tile.content_age, } } } enum MsgToWorkerThread { Exit, PaintTile(usize, BufferRequest, Arc, f32, LayerKind), } enum MsgFromWorkerThread { PaintedTile(Box), } pub static THREAD_TINT_COLORS: [Color; 8] = [ Color { r: 6.0 / 255.0, g: 153.0 / 255.0, b: 198.0 / 255.0, a: 0.7 }, Color { r: 255.0 / 255.0, g: 212.0 / 255.0, b: 83.0 / 255.0, a: 0.7 }, Color { r: 116.0 / 255.0, g: 29.0 / 255.0, b: 109.0 / 255.0, a: 0.7 }, Color { r: 204.0 / 255.0, g: 158.0 / 255.0, b: 199.0 / 255.0, a: 0.7 }, Color { r: 242.0 / 255.0, g: 46.0 / 255.0, b: 121.0 / 255.0, a: 0.7 }, Color { r: 116.0 / 255.0, g: 203.0 / 255.0, b: 196.0 / 255.0, a: 0.7 }, Color { r: 255.0 / 255.0, g: 249.0 / 255.0, b: 201.0 / 255.0, a: 0.7 }, Color { r: 137.0 / 255.0, g: 196.0 / 255.0, b: 78.0 / 255.0, a: 0.7 }, ];