Auto merge of #50699 - Zoxc:blocking-queries, r=mw
Blocking Rayon queries r? @michaelwoerister
This commit is contained in:
commit
c131bdcaff
13 changed files with 617 additions and 49 deletions
|
@ -15,9 +15,12 @@ fmt_macros = { path = "../libfmt_macros" }
|
|||
graphviz = { path = "../libgraphviz" }
|
||||
jobserver = "0.1"
|
||||
lazy_static = "1.0.0"
|
||||
scoped-tls = { version = "0.1.1", features = ["nightly"] }
|
||||
log = { version = "0.4", features = ["release_max_level_info", "std"] }
|
||||
polonius-engine = "0.5.0"
|
||||
proc_macro = { path = "../libproc_macro" }
|
||||
rustc-rayon = "0.1.1"
|
||||
rustc-rayon-core = "0.1.1"
|
||||
rustc_apfloat = { path = "../librustc_apfloat" }
|
||||
rustc_target = { path = "../librustc_target" }
|
||||
rustc_data_structures = { path = "../librustc_data_structures" }
|
||||
|
@ -26,6 +29,7 @@ serialize = { path = "../libserialize" }
|
|||
syntax = { path = "../libsyntax" }
|
||||
syntax_pos = { path = "../libsyntax_pos" }
|
||||
backtrace = "0.3.3"
|
||||
parking_lot = "0.5.5"
|
||||
byteorder = { version = "1.1", features = ["i128"]}
|
||||
chalk-engine = { version = "0.6.0", default-features=false }
|
||||
|
||||
|
|
|
@ -67,6 +67,7 @@
|
|||
#![feature(unboxed_closures)]
|
||||
#![feature(trace_macros)]
|
||||
#![feature(trusted_len)]
|
||||
#![feature(vec_remove_item)]
|
||||
#![feature(catch_expr)]
|
||||
#![feature(integer_atomics)]
|
||||
#![feature(test)]
|
||||
|
@ -83,13 +84,17 @@ extern crate fmt_macros;
|
|||
extern crate getopts;
|
||||
extern crate graphviz;
|
||||
#[macro_use] extern crate lazy_static;
|
||||
#[macro_use] extern crate scoped_tls;
|
||||
#[cfg(windows)]
|
||||
extern crate libc;
|
||||
extern crate polonius_engine;
|
||||
extern crate rustc_target;
|
||||
#[macro_use] extern crate rustc_data_structures;
|
||||
extern crate serialize;
|
||||
extern crate parking_lot;
|
||||
extern crate rustc_errors as errors;
|
||||
extern crate rustc_rayon as rayon;
|
||||
extern crate rustc_rayon_core as rayon_core;
|
||||
#[macro_use] extern crate log;
|
||||
#[macro_use] extern crate syntax;
|
||||
extern crate syntax_pos;
|
||||
|
|
|
@ -1699,16 +1699,21 @@ impl<'a, 'tcx> Lift<'tcx> for &'a Slice<CanonicalVarInfo> {
|
|||
pub mod tls {
|
||||
use super::{GlobalCtxt, TyCtxt};
|
||||
|
||||
use std::cell::Cell;
|
||||
use std::fmt;
|
||||
use std::mem;
|
||||
use syntax_pos;
|
||||
use ty::maps;
|
||||
use errors::{Diagnostic, TRACK_DIAGNOSTICS};
|
||||
use rustc_data_structures::OnDrop;
|
||||
use rustc_data_structures::sync::{self, Lrc};
|
||||
use rustc_data_structures::sync::{self, Lrc, Lock};
|
||||
use dep_graph::OpenTask;
|
||||
|
||||
#[cfg(not(parallel_queries))]
|
||||
use std::cell::Cell;
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
use rayon_core;
|
||||
|
||||
/// This is the implicit state of rustc. It contains the current
|
||||
/// TyCtxt and query. It is updated when creating a local interner or
|
||||
/// executing a new query. Whenever there's a TyCtxt value available
|
||||
|
@ -1732,9 +1737,29 @@ pub mod tls {
|
|||
pub task: &'a OpenTask,
|
||||
}
|
||||
|
||||
// A thread local value which stores a pointer to the current ImplicitCtxt
|
||||
/// Sets Rayon's thread local variable which is preserved for Rayon jobs
|
||||
/// to `value` during the call to `f`. It is restored to its previous value after.
|
||||
/// This is used to set the pointer to the new ImplicitCtxt.
|
||||
#[cfg(parallel_queries)]
|
||||
fn set_tlv<F: FnOnce() -> R, R>(value: usize, f: F) -> R {
|
||||
rayon_core::tlv::with(value, f)
|
||||
}
|
||||
|
||||
/// Gets Rayon's thread local variable which is preserved for Rayon jobs.
|
||||
/// This is used to get the pointer to the current ImplicitCtxt.
|
||||
#[cfg(parallel_queries)]
|
||||
fn get_tlv() -> usize {
|
||||
rayon_core::tlv::get()
|
||||
}
|
||||
|
||||
/// A thread local variable which stores a pointer to the current ImplicitCtxt
|
||||
#[cfg(not(parallel_queries))]
|
||||
thread_local!(static TLV: Cell<usize> = Cell::new(0));
|
||||
|
||||
/// Sets TLV to `value` during the call to `f`.
|
||||
/// It is restored to its previous value after.
|
||||
/// This is used to set the pointer to the new ImplicitCtxt.
|
||||
#[cfg(not(parallel_queries))]
|
||||
fn set_tlv<F: FnOnce() -> R, R>(value: usize, f: F) -> R {
|
||||
let old = get_tlv();
|
||||
let _reset = OnDrop(move || TLV.with(|tlv| tlv.set(old)));
|
||||
|
@ -1742,6 +1767,8 @@ pub mod tls {
|
|||
f()
|
||||
}
|
||||
|
||||
/// This is used to get the pointer to the current ImplicitCtxt.
|
||||
#[cfg(not(parallel_queries))]
|
||||
fn get_tlv() -> usize {
|
||||
TLV.with(|tlv| tlv.get())
|
||||
}
|
||||
|
@ -1810,6 +1837,15 @@ pub mod tls {
|
|||
where F: for<'a> FnOnce(TyCtxt<'a, 'gcx, 'gcx>) -> R
|
||||
{
|
||||
with_thread_locals(|| {
|
||||
// Update GCX_PTR to indicate there's a GlobalCtxt available
|
||||
GCX_PTR.with(|lock| {
|
||||
*lock.lock() = gcx as *const _ as usize;
|
||||
});
|
||||
// Set GCX_PTR back to 0 when we exit
|
||||
let _on_drop = OnDrop(move || {
|
||||
GCX_PTR.with(|lock| *lock.lock() = 0);
|
||||
});
|
||||
|
||||
let tcx = TyCtxt {
|
||||
gcx,
|
||||
interners: &gcx.global_interners,
|
||||
|
@ -1826,6 +1862,32 @@ pub mod tls {
|
|||
})
|
||||
}
|
||||
|
||||
/// Stores a pointer to the GlobalCtxt if one is available.
|
||||
/// This is used to access the GlobalCtxt in the deadlock handler
|
||||
/// given to Rayon.
|
||||
scoped_thread_local!(pub static GCX_PTR: Lock<usize>);
|
||||
|
||||
/// Creates a TyCtxt and ImplicitCtxt based on the GCX_PTR thread local.
|
||||
/// This is used in the deadlock handler.
|
||||
pub unsafe fn with_global<F, R>(f: F) -> R
|
||||
where F: for<'a, 'gcx, 'tcx> FnOnce(TyCtxt<'a, 'gcx, 'tcx>) -> R
|
||||
{
|
||||
let gcx = GCX_PTR.with(|lock| *lock.lock());
|
||||
assert!(gcx != 0);
|
||||
let gcx = &*(gcx as *const GlobalCtxt<'_>);
|
||||
let tcx = TyCtxt {
|
||||
gcx,
|
||||
interners: &gcx.global_interners,
|
||||
};
|
||||
let icx = ImplicitCtxt {
|
||||
query: None,
|
||||
tcx,
|
||||
layout_depth: 0,
|
||||
task: &OpenTask::Ignore,
|
||||
};
|
||||
enter_context(&icx, |_| f(tcx))
|
||||
}
|
||||
|
||||
/// Allows access to the current ImplicitCtxt in a closure if one is available
|
||||
pub fn with_context_opt<F, R>(f: F) -> R
|
||||
where F: for<'a, 'gcx, 'tcx> FnOnce(Option<&ImplicitCtxt<'a, 'gcx, 'tcx>>) -> R
|
||||
|
|
|
@ -8,13 +8,31 @@
|
|||
// option. This file may not be copied, modified, or distributed
|
||||
// except according to those terms.
|
||||
|
||||
use rustc_data_structures::sync::{Lock, Lrc};
|
||||
#![allow(warnings)]
|
||||
|
||||
use std::mem;
|
||||
use rustc_data_structures::sync::{Lock, LockGuard, Lrc, Weak};
|
||||
use rustc_data_structures::OnDrop;
|
||||
use syntax_pos::Span;
|
||||
use ty::tls;
|
||||
use ty::maps::Query;
|
||||
use ty::maps::plumbing::CycleError;
|
||||
use ty::context::TyCtxt;
|
||||
use errors::Diagnostic;
|
||||
use std::process;
|
||||
use std::fmt;
|
||||
use std::collections::HashSet;
|
||||
#[cfg(parallel_queries)]
|
||||
use {
|
||||
rayon_core,
|
||||
parking_lot::{Mutex, Condvar},
|
||||
std::sync::atomic::Ordering,
|
||||
std::thread,
|
||||
std::iter,
|
||||
std::iter::FromIterator,
|
||||
syntax_pos::DUMMY_SP,
|
||||
rustc_data_structures::stable_hasher::{StableHasherResult, StableHasher, HashStable},
|
||||
};
|
||||
|
||||
/// Indicates the state of a query for a given key in a query map
|
||||
pub(super) enum QueryResult<'tcx> {
|
||||
|
@ -42,6 +60,10 @@ pub struct QueryJob<'tcx> {
|
|||
|
||||
/// Diagnostic messages which are emitted while the query executes
|
||||
pub diagnostics: Lock<Vec<Diagnostic>>,
|
||||
|
||||
/// The latch which is used to wait on this job
|
||||
#[cfg(parallel_queries)]
|
||||
latch: QueryLatch<'tcx>,
|
||||
}
|
||||
|
||||
impl<'tcx> QueryJob<'tcx> {
|
||||
|
@ -51,6 +73,8 @@ impl<'tcx> QueryJob<'tcx> {
|
|||
diagnostics: Lock::new(Vec::new()),
|
||||
info,
|
||||
parent,
|
||||
#[cfg(parallel_queries)]
|
||||
latch: QueryLatch::new(),
|
||||
}
|
||||
}
|
||||
|
||||
|
@ -62,6 +86,36 @@ impl<'tcx> QueryJob<'tcx> {
|
|||
&self,
|
||||
tcx: TyCtxt<'_, 'tcx, 'lcx>,
|
||||
span: Span,
|
||||
) -> Result<(), CycleError<'tcx>> {
|
||||
#[cfg(not(parallel_queries))]
|
||||
{
|
||||
self.find_cycle_in_stack(tcx, span)
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
{
|
||||
tls::with_related_context(tcx, move |icx| {
|
||||
let mut waiter = Lrc::new(QueryWaiter {
|
||||
query: icx.query.clone(),
|
||||
span,
|
||||
cycle: Lock::new(None),
|
||||
condvar: Condvar::new(),
|
||||
});
|
||||
self.latch.await(&waiter);
|
||||
|
||||
match Lrc::get_mut(&mut waiter).unwrap().cycle.get_mut().take() {
|
||||
None => Ok(()),
|
||||
Some(cycle) => Err(cycle)
|
||||
}
|
||||
})
|
||||
}
|
||||
}
|
||||
|
||||
#[cfg(not(parallel_queries))]
|
||||
fn find_cycle_in_stack<'lcx>(
|
||||
&self,
|
||||
tcx: TyCtxt<'_, 'tcx, 'lcx>,
|
||||
span: Span,
|
||||
) -> Result<(), CycleError<'tcx>> {
|
||||
// Get the current executing query (waiter) and find the waitee amongst its parents
|
||||
let mut current_job = tls::with_related_context(tcx, |icx| icx.query.clone());
|
||||
|
@ -93,5 +147,379 @@ impl<'tcx> QueryJob<'tcx> {
|
|||
///
|
||||
/// This does nothing for single threaded rustc,
|
||||
/// as there are no concurrent jobs which could be waiting on us
|
||||
pub fn signal_complete(&self) {}
|
||||
pub fn signal_complete(&self) {
|
||||
#[cfg(parallel_queries)]
|
||||
self.latch.set();
|
||||
}
|
||||
|
||||
fn as_ptr(&self) -> *const QueryJob<'tcx> {
|
||||
self as *const _
|
||||
}
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
struct QueryWaiter<'tcx> {
|
||||
query: Option<Lrc<QueryJob<'tcx>>>,
|
||||
condvar: Condvar,
|
||||
span: Span,
|
||||
cycle: Lock<Option<CycleError<'tcx>>>,
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
impl<'tcx> QueryWaiter<'tcx> {
|
||||
fn notify(&self, registry: &rayon_core::Registry) {
|
||||
rayon_core::mark_unblocked(registry);
|
||||
self.condvar.notify_one();
|
||||
}
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
struct QueryLatchInfo<'tcx> {
|
||||
complete: bool,
|
||||
waiters: Vec<Lrc<QueryWaiter<'tcx>>>,
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
struct QueryLatch<'tcx> {
|
||||
info: Mutex<QueryLatchInfo<'tcx>>,
|
||||
}
|
||||
|
||||
#[cfg(parallel_queries)]
|
||||
impl<'tcx> QueryLatch<'tcx> {
|
||||
fn new() -> Self {
|
||||
QueryLatch {
|
||||
info: Mutex::new(QueryLatchInfo {
|
||||
complete: false,
|
||||
waiters: Vec::new(),
|
||||
}),
|
||||
}
|
||||
}
|
||||
|
||||
/// Awaits the caller on this latch by blocking the current thread.
|
||||
fn await(&self, waiter: &Lrc<QueryWaiter<'tcx>>) {
|
||||
let mut info = self.info.lock();
|
||||
if !info.complete {
|
||||
// We push the waiter on to the `waiters` list. It can be accessed inside
|
||||
// the `wait` call below, by 1) the `set` method or 2) by deadlock detection.
|
||||
// Both of these will remove it from the `waiters` list before resuming
|
||||
// this thread.
|
||||
info.waiters.push(waiter.clone());
|
||||
|
||||
// If this detects a deadlock and the deadlock handler wants to resume this thread
|
||||
// we have to be in the `wait` call. This is ensured by the deadlock handler
|
||||
// getting the self.info lock.
|
||||
rayon_core::mark_blocked();
|
||||
waiter.condvar.wait(&mut info);
|
||||
}
|
||||
}
|
||||
|
||||
/// Sets the latch and resumes all waiters on it
|
||||
fn set(&self) {
|
||||
let mut info = self.info.lock();
|
||||
debug_assert!(!info.complete);
|
||||
info.complete = true;
|
||||
let registry = rayon_core::Registry::current();
|
||||
for waiter in info.waiters.drain(..) {
|
||||
waiter.notify(®istry);
|
||||
}
|
||||
}
|
||||
|
||||
/// Remove a single waiter from the list of waiters.
|
||||
/// This is used to break query cycles.
|
||||
fn extract_waiter(
|
||||
&self,
|
||||
waiter: usize,
|
||||
) -> Lrc<QueryWaiter<'tcx>> {
|
||||
let mut info = self.info.lock();
|
||||
debug_assert!(!info.complete);
|
||||
// Remove the waiter from the list of waiters
|
||||
info.waiters.remove(waiter)
|
||||
}
|
||||
}
|
||||
|
||||
/// A resumable waiter of a query. The usize is the index into waiters in the query's latch
|
||||
#[cfg(parallel_queries)]
|
||||
type Waiter<'tcx> = (Lrc<QueryJob<'tcx>>, usize);
|
||||
|
||||
/// Visits all the non-resumable and resumable waiters of a query.
|
||||
/// Only waiters in a query are visited.
|
||||
/// `visit` is called for every waiter and is passed a query waiting on `query_ref`
|
||||
/// and a span indicating the reason the query waited on `query_ref`.
|
||||
/// If `visit` returns Some, this function returns.
|
||||
/// For visits of non-resumable waiters it returns the return value of `visit`.
|
||||
/// For visits of resumable waiters it returns Some(Some(Waiter)) which has the
|
||||
/// required information to resume the waiter.
|
||||
/// If all `visit` calls returns None, this function also returns None.
|
||||
#[cfg(parallel_queries)]
|
||||
fn visit_waiters<'tcx, F>(query: Lrc<QueryJob<'tcx>>, mut visit: F) -> Option<Option<Waiter<'tcx>>>
|
||||
where
|
||||
F: FnMut(Span, Lrc<QueryJob<'tcx>>) -> Option<Option<Waiter<'tcx>>>
|
||||
{
|
||||
// Visit the parent query which is a non-resumable waiter since it's on the same stack
|
||||
if let Some(ref parent) = query.parent {
|
||||
if let Some(cycle) = visit(query.info.span, parent.clone()) {
|
||||
return Some(cycle);
|
||||
}
|
||||
}
|
||||
|
||||
// Visit the explict waiters which use condvars and are resumable
|
||||
for (i, waiter) in query.latch.info.lock().waiters.iter().enumerate() {
|
||||
if let Some(ref waiter_query) = waiter.query {
|
||||
if visit(waiter.span, waiter_query.clone()).is_some() {
|
||||
// Return a value which indicates that this waiter can be resumed
|
||||
return Some(Some((query.clone(), i)));
|
||||
}
|
||||
}
|
||||
}
|
||||
None
|
||||
}
|
||||
|
||||
/// Look for query cycles by doing a depth first search starting at `query`.
|
||||
/// `span` is the reason for the `query` to execute. This is initially DUMMY_SP.
|
||||
/// If a cycle is detected, this initial value is replaced with the span causing
|
||||
/// the cycle.
|
||||
#[cfg(parallel_queries)]
|
||||
fn cycle_check<'tcx>(query: Lrc<QueryJob<'tcx>>,
|
||||
span: Span,
|
||||
stack: &mut Vec<(Span, Lrc<QueryJob<'tcx>>)>,
|
||||
visited: &mut HashSet<*const QueryJob<'tcx>>
|
||||
) -> Option<Option<Waiter<'tcx>>> {
|
||||
if visited.contains(&query.as_ptr()) {
|
||||
return if let Some(p) = stack.iter().position(|q| q.1.as_ptr() == query.as_ptr()) {
|
||||
// We detected a query cycle, fix up the initial span and return Some
|
||||
|
||||
// Remove previous stack entries
|
||||
stack.splice(0..p, iter::empty());
|
||||
// Replace the span for the first query with the cycle cause
|
||||
stack[0].0 = span;
|
||||
Some(None)
|
||||
} else {
|
||||
None
|
||||
}
|
||||
}
|
||||
|
||||
// Mark this query is visited and add it to the stack
|
||||
visited.insert(query.as_ptr());
|
||||
stack.push((span, query.clone()));
|
||||
|
||||
// Visit all the waiters
|
||||
let r = visit_waiters(query, |span, successor| {
|
||||
cycle_check(successor, span, stack, visited)
|
||||
});
|
||||
|
||||
// Remove the entry in our stack if we didn't find a cycle
|
||||
if r.is_none() {
|
||||
stack.pop();
|
||||
}
|
||||
|
||||
r
|
||||
}
|
||||
|
||||
/// Finds out if there's a path to the compiler root (aka. code which isn't in a query)
|
||||
/// from `query` without going through any of the queries in `visited`.
|
||||
/// This is achieved with a depth first search.
|
||||
#[cfg(parallel_queries)]
|
||||
fn connected_to_root<'tcx>(
|
||||
query: Lrc<QueryJob<'tcx>>,
|
||||
visited: &mut HashSet<*const QueryJob<'tcx>>
|
||||
) -> bool {
|
||||
// We already visited this or we're deliberately ignoring it
|
||||
if visited.contains(&query.as_ptr()) {
|
||||
return false;
|
||||
}
|
||||
|
||||
// This query is connected to the root (it has no query parent), return true
|
||||
if query.parent.is_none() {
|
||||
return true;
|
||||
}
|
||||
|
||||
visited.insert(query.as_ptr());
|
||||
|
||||
let mut connected = false;
|
||||
|
||||
visit_waiters(query, |_, successor| {
|
||||
if connected_to_root(successor, visited) {
|
||||
Some(None)
|
||||
} else {
|
||||
None
|
||||
}
|
||||
}).is_some()
|
||||
}
|
||||
|
||||
/// Looks for query cycles starting from the last query in `jobs`.
|
||||
/// If a cycle is found, all queries in the cycle is removed from `jobs` and
|
||||
/// the function return true.
|
||||
/// If a cycle was not found, the starting query is removed from `jobs` and
|
||||
/// the function returns false.
|
||||
#[cfg(parallel_queries)]
|
||||
fn remove_cycle<'tcx>(
|
||||
jobs: &mut Vec<Lrc<QueryJob<'tcx>>>,
|
||||
wakelist: &mut Vec<Lrc<QueryWaiter<'tcx>>>,
|
||||
tcx: TyCtxt<'_, 'tcx, '_>
|
||||
) -> bool {
|
||||
let mut visited = HashSet::new();
|
||||
let mut stack = Vec::new();
|
||||
// Look for a cycle starting with the last query in `jobs`
|
||||
if let Some(waiter) = cycle_check(jobs.pop().unwrap(),
|
||||
DUMMY_SP,
|
||||
&mut stack,
|
||||
&mut visited) {
|
||||
// Reverse the stack so earlier entries require later entries
|
||||
stack.reverse();
|
||||
|
||||
// Extract the spans and queries into separate arrays
|
||||
let mut spans: Vec<_> = stack.iter().map(|e| e.0).collect();
|
||||
let queries = stack.into_iter().map(|e| e.1);
|
||||
|
||||
// Shift the spans so that queries are matched with the span for their waitee
|
||||
let last = spans.pop().unwrap();
|
||||
spans.insert(0, last);
|
||||
|
||||
// Zip them back together
|
||||
let mut stack: Vec<_> = spans.into_iter().zip(queries).collect();
|
||||
|
||||
// Remove the queries in our cycle from the list of jobs to look at
|
||||
for r in &stack {
|
||||
if let Some(pos) = jobs.iter().position(|j| j.as_ptr() == r.1.as_ptr()) {
|
||||
jobs.remove(pos);
|
||||
}
|
||||
}
|
||||
|
||||
// Find the queries in the cycle which are
|
||||
// connected to queries outside the cycle
|
||||
let entry_points: Vec<Lrc<QueryJob<'tcx>>> = stack.iter().filter_map(|query| {
|
||||
// Mark all the other queries in the cycle as already visited
|
||||
let mut visited = HashSet::from_iter(stack.iter().filter_map(|q| {
|
||||
if q.1.as_ptr() != query.1.as_ptr() {
|
||||
Some(q.1.as_ptr())
|
||||
} else {
|
||||
None
|
||||
}
|
||||
}));
|
||||
|
||||
if connected_to_root(query.1.clone(), &mut visited) {
|
||||
Some(query.1.clone())
|
||||
} else {
|
||||
None
|
||||
}
|
||||
}).collect();
|
||||
|
||||
// Deterministically pick an entry point
|
||||
// FIXME: Sort this instead
|
||||
let mut hcx = tcx.create_stable_hashing_context();
|
||||
let entry_point = entry_points.iter().min_by_key(|q| {
|
||||
let mut stable_hasher = StableHasher::<u64>::new();
|
||||
q.info.query.hash_stable(&mut hcx, &mut stable_hasher);
|
||||
stable_hasher.finish()
|
||||
}).unwrap().as_ptr();
|
||||
|
||||
// Shift the stack until our entry point is first
|
||||
while stack[0].1.as_ptr() != entry_point {
|
||||
let last = stack.pop().unwrap();
|
||||
stack.insert(0, last);
|
||||
}
|
||||
|
||||
// Create the cycle error
|
||||
let mut error = CycleError {
|
||||
usage: None,
|
||||
cycle: stack.iter().map(|&(s, ref q)| QueryInfo {
|
||||
span: s,
|
||||
query: q.info.query.clone(),
|
||||
} ).collect(),
|
||||
};
|
||||
|
||||
// We unwrap `waiter` here since there must always be one
|
||||
// edge which is resumeable / waited using a query latch
|
||||
let (waitee_query, waiter_idx) = waiter.unwrap();
|
||||
|
||||
// Extract the waiter we want to resume
|
||||
let waiter = waitee_query.latch.extract_waiter(waiter_idx);
|
||||
|
||||
// Set the cycle error so it will be picked up when resumed
|
||||
*waiter.cycle.lock() = Some(error);
|
||||
|
||||
// Put the waiter on the list of things to resume
|
||||
wakelist.push(waiter);
|
||||
|
||||
true
|
||||
} else {
|
||||
false
|
||||
}
|
||||
}
|
||||
|
||||
/// Creates a new thread and forwards information in thread locals to it.
|
||||
/// The new thread runs the deadlock handler.
|
||||
/// Must only be called when a deadlock is about to happen.
|
||||
#[cfg(parallel_queries)]
|
||||
pub unsafe fn handle_deadlock() {
|
||||
use syntax;
|
||||
use syntax_pos;
|
||||
|
||||
let registry = rayon_core::Registry::current();
|
||||
|
||||
let gcx_ptr = tls::GCX_PTR.with(|gcx_ptr| {
|
||||
gcx_ptr as *const _
|
||||
});
|
||||
let gcx_ptr = &*gcx_ptr;
|
||||
|
||||
let syntax_globals = syntax::GLOBALS.with(|syntax_globals| {
|
||||
syntax_globals as *const _
|
||||
});
|
||||
let syntax_globals = &*syntax_globals;
|
||||
|
||||
let syntax_pos_globals = syntax_pos::GLOBALS.with(|syntax_pos_globals| {
|
||||
syntax_pos_globals as *const _
|
||||
});
|
||||
let syntax_pos_globals = &*syntax_pos_globals;
|
||||
thread::spawn(move || {
|
||||
tls::GCX_PTR.set(gcx_ptr, || {
|
||||
syntax_pos::GLOBALS.set(syntax_pos_globals, || {
|
||||
syntax_pos::GLOBALS.set(syntax_pos_globals, || {
|
||||
tls::with_thread_locals(|| {
|
||||
tls::with_global(|tcx| deadlock(tcx, ®istry))
|
||||
})
|
||||
})
|
||||
})
|
||||
})
|
||||
});
|
||||
}
|
||||
|
||||
/// Detects query cycles by using depth first search over all active query jobs.
|
||||
/// If a query cycle is found it will break the cycle by finding an edge which
|
||||
/// uses a query latch and then resuming that waiter.
|
||||
/// There may be multiple cycles involved in a deadlock, so this searches
|
||||
/// all active queries for cycles before finally resuming all the waiters at once.
|
||||
#[cfg(parallel_queries)]
|
||||
fn deadlock(tcx: TyCtxt<'_, '_, '_>, registry: &rayon_core::Registry) {
|
||||
let on_panic = OnDrop(|| {
|
||||
eprintln!("deadlock handler panicked, aborting process");
|
||||
process::abort();
|
||||
});
|
||||
|
||||
let mut wakelist = Vec::new();
|
||||
let mut jobs: Vec<_> = tcx.maps.collect_active_jobs();
|
||||
|
||||
let mut found_cycle = false;
|
||||
|
||||
while jobs.len() > 0 {
|
||||
if remove_cycle(&mut jobs, &mut wakelist, tcx) {
|
||||
found_cycle = true;
|
||||
}
|
||||
}
|
||||
|
||||
// Check that a cycle was found. It is possible for a deadlock to occur without
|
||||
// a query cycle if a query which can be waited on uses Rayon to do multithreading
|
||||
// internally. Such a query (X) may be executing on 2 threads (A and B) and A may
|
||||
// wait using Rayon on B. Rayon may then switch to executing another query (Y)
|
||||
// which in turn will wait on X causing a deadlock. We have a false dependency from
|
||||
// X to Y due to Rayon waiting and a true dependency from Y to X. The algorithm here
|
||||
// only considers the true dependency and won't detect a cycle.
|
||||
assert!(found_cycle);
|
||||
|
||||
// FIXME: Ensure this won't cause a deadlock before we return
|
||||
for waiter in wakelist.into_iter() {
|
||||
waiter.notify(registry);
|
||||
}
|
||||
|
||||
on_panic.disable();
|
||||
}
|
||||
|
|
|
@ -63,10 +63,12 @@ use syntax::symbol::Symbol;
|
|||
#[macro_use]
|
||||
mod plumbing;
|
||||
use self::plumbing::*;
|
||||
pub use self::plumbing::force_from_dep_node;
|
||||
pub use self::plumbing::{force_from_dep_node, CycleError};
|
||||
|
||||
mod job;
|
||||
pub use self::job::{QueryJob, QueryInfo};
|
||||
#[cfg(parallel_queries)]
|
||||
pub use self::job::handle_deadlock;
|
||||
|
||||
mod keys;
|
||||
pub use self::keys::Key;
|
||||
|
|
|
@ -223,7 +223,7 @@ impl<'a, 'tcx, Q: QueryDescription<'tcx>> Drop for JobOwner<'a, 'tcx, Q> {
|
|||
}
|
||||
|
||||
#[derive(Clone)]
|
||||
pub(super) struct CycleError<'tcx> {
|
||||
pub struct CycleError<'tcx> {
|
||||
/// The query and related span which uses the cycle
|
||||
pub(super) usage: Option<(Span, Query<'tcx>)>,
|
||||
pub(super) cycle: Vec<QueryInfo<'tcx>>,
|
||||
|
@ -632,7 +632,15 @@ macro_rules! define_maps {
|
|||
$($(#[$attr:meta])*
|
||||
[$($modifiers:tt)*] fn $name:ident: $node:ident($K:ty) -> $V:ty,)*) => {
|
||||
|
||||
use std::mem;
|
||||
use ty::maps::job::QueryResult;
|
||||
use rustc_data_structures::sync::Lock;
|
||||
use {
|
||||
rustc_data_structures::stable_hasher::HashStable,
|
||||
rustc_data_structures::stable_hasher::StableHasherResult,
|
||||
rustc_data_structures::stable_hasher::StableHasher,
|
||||
ich::StableHashingContext
|
||||
};
|
||||
|
||||
define_map_struct! {
|
||||
tcx: $tcx,
|
||||
|
@ -647,10 +655,25 @@ macro_rules! define_maps {
|
|||
$($name: Lock::new(QueryMap::new())),*
|
||||
}
|
||||
}
|
||||
|
||||
pub fn collect_active_jobs(&self) -> Vec<Lrc<QueryJob<$tcx>>> {
|
||||
let mut jobs = Vec::new();
|
||||
|
||||
// We use try_lock here since we are only called from the
|
||||
// deadlock handler, and this shouldn't be locked
|
||||
$(for v in self.$name.try_lock().unwrap().active.values() {
|
||||
match *v {
|
||||
QueryResult::Started(ref job) => jobs.push(job.clone()),
|
||||
_ => (),
|
||||
}
|
||||
})*
|
||||
|
||||
return jobs;
|
||||
}
|
||||
}
|
||||
|
||||
#[allow(bad_style)]
|
||||
#[derive(Copy, Clone, Debug, PartialEq, Eq)]
|
||||
#[derive(Copy, Clone, Debug, PartialEq, Eq, Hash)]
|
||||
pub enum Query<$tcx> {
|
||||
$($(#[$attr])* $name($K)),*
|
||||
}
|
||||
|
@ -692,6 +715,17 @@ macro_rules! define_maps {
|
|||
}
|
||||
}
|
||||
|
||||
impl<'a, $tcx> HashStable<StableHashingContext<'a>> for Query<$tcx> {
|
||||
fn hash_stable<W: StableHasherResult>(&self,
|
||||
hcx: &mut StableHashingContext<'a>,
|
||||
hasher: &mut StableHasher<W>) {
|
||||
mem::discriminant(self).hash_stable(hcx, hasher);
|
||||
match *self {
|
||||
$(Query::$name(key) => key.hash_stable(hcx, hasher),)*
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
pub mod queries {
|
||||
use std::marker::PhantomData;
|
||||
|
||||
|
|
Loading…
Add table
Add a link
Reference in a new issue