Auto merge of #115401 - Zoxc:freeze, r=oli-obk
Add `FreezeLock` type and use it to store `Definitions` This adds a `FreezeLock` type which allows mutation using a lock until the value is frozen where it can be accessed lock-free. It's used to store `Definitions` in `Untracked` instead of a `RwLock`. Unlike the current scheme of leaking read guards this doesn't deadlock if definitions is written to after no mutation are expected.
This commit is contained in:
commit
a0c28cd9dc
@ -2,19 +2,17 @@
|
|||||||
use rustc_data_structures::sorted_map::SortedMap;
|
use rustc_data_structures::sorted_map::SortedMap;
|
||||||
use rustc_hir as hir;
|
use rustc_hir as hir;
|
||||||
use rustc_hir::def_id::LocalDefId;
|
use rustc_hir::def_id::LocalDefId;
|
||||||
use rustc_hir::definitions;
|
|
||||||
use rustc_hir::intravisit::{self, Visitor};
|
use rustc_hir::intravisit::{self, Visitor};
|
||||||
use rustc_hir::*;
|
use rustc_hir::*;
|
||||||
use rustc_index::{Idx, IndexVec};
|
use rustc_index::{Idx, IndexVec};
|
||||||
use rustc_middle::span_bug;
|
use rustc_middle::span_bug;
|
||||||
use rustc_session::Session;
|
use rustc_middle::ty::TyCtxt;
|
||||||
use rustc_span::source_map::SourceMap;
|
|
||||||
use rustc_span::{Span, DUMMY_SP};
|
use rustc_span::{Span, DUMMY_SP};
|
||||||
|
|
||||||
/// A visitor that walks over the HIR and collects `Node`s into a HIR map.
|
/// A visitor that walks over the HIR and collects `Node`s into a HIR map.
|
||||||
pub(super) struct NodeCollector<'a, 'hir> {
|
pub(super) struct NodeCollector<'a, 'hir> {
|
||||||
/// Source map
|
tcx: TyCtxt<'hir>,
|
||||||
source_map: &'a SourceMap,
|
|
||||||
bodies: &'a SortedMap<ItemLocalId, &'hir Body<'hir>>,
|
bodies: &'a SortedMap<ItemLocalId, &'hir Body<'hir>>,
|
||||||
|
|
||||||
/// Outputs
|
/// Outputs
|
||||||
@ -25,14 +23,11 @@ pub(super) struct NodeCollector<'a, 'hir> {
|
|||||||
parent_node: hir::ItemLocalId,
|
parent_node: hir::ItemLocalId,
|
||||||
|
|
||||||
owner: OwnerId,
|
owner: OwnerId,
|
||||||
|
|
||||||
definitions: &'a definitions::Definitions,
|
|
||||||
}
|
}
|
||||||
|
|
||||||
#[instrument(level = "debug", skip(sess, definitions, bodies))]
|
#[instrument(level = "debug", skip(tcx, bodies))]
|
||||||
pub(super) fn index_hir<'hir>(
|
pub(super) fn index_hir<'hir>(
|
||||||
sess: &Session,
|
tcx: TyCtxt<'hir>,
|
||||||
definitions: &definitions::Definitions,
|
|
||||||
item: hir::OwnerNode<'hir>,
|
item: hir::OwnerNode<'hir>,
|
||||||
bodies: &SortedMap<ItemLocalId, &'hir Body<'hir>>,
|
bodies: &SortedMap<ItemLocalId, &'hir Body<'hir>>,
|
||||||
) -> (IndexVec<ItemLocalId, Option<ParentedNode<'hir>>>, FxHashMap<LocalDefId, ItemLocalId>) {
|
) -> (IndexVec<ItemLocalId, Option<ParentedNode<'hir>>>, FxHashMap<LocalDefId, ItemLocalId>) {
|
||||||
@ -42,8 +37,7 @@ pub(super) fn index_hir<'hir>(
|
|||||||
// used.
|
// used.
|
||||||
nodes.push(Some(ParentedNode { parent: ItemLocalId::INVALID, node: item.into() }));
|
nodes.push(Some(ParentedNode { parent: ItemLocalId::INVALID, node: item.into() }));
|
||||||
let mut collector = NodeCollector {
|
let mut collector = NodeCollector {
|
||||||
source_map: sess.source_map(),
|
tcx,
|
||||||
definitions,
|
|
||||||
owner: item.def_id(),
|
owner: item.def_id(),
|
||||||
parent_node: ItemLocalId::new(0),
|
parent_node: ItemLocalId::new(0),
|
||||||
nodes,
|
nodes,
|
||||||
@ -79,11 +73,17 @@ fn insert(&mut self, span: Span, hir_id: HirId, node: Node<'hir>) {
|
|||||||
span,
|
span,
|
||||||
"inconsistent HirId at `{:?}` for `{:?}`: \
|
"inconsistent HirId at `{:?}` for `{:?}`: \
|
||||||
current_dep_node_owner={} ({:?}), hir_id.owner={} ({:?})",
|
current_dep_node_owner={} ({:?}), hir_id.owner={} ({:?})",
|
||||||
self.source_map.span_to_diagnostic_string(span),
|
self.tcx.sess.source_map().span_to_diagnostic_string(span),
|
||||||
node,
|
node,
|
||||||
self.definitions.def_path(self.owner.def_id).to_string_no_crate_verbose(),
|
self.tcx
|
||||||
|
.definitions_untracked()
|
||||||
|
.def_path(self.owner.def_id)
|
||||||
|
.to_string_no_crate_verbose(),
|
||||||
self.owner,
|
self.owner,
|
||||||
self.definitions.def_path(hir_id.owner.def_id).to_string_no_crate_verbose(),
|
self.tcx
|
||||||
|
.definitions_untracked()
|
||||||
|
.def_path(hir_id.owner.def_id)
|
||||||
|
.to_string_no_crate_verbose(),
|
||||||
hir_id.owner,
|
hir_id.owner,
|
||||||
)
|
)
|
||||||
}
|
}
|
||||||
|
@ -671,8 +671,7 @@ fn make_owner_info(&mut self, node: hir::OwnerNode<'hir>) -> &'hir hir::OwnerInf
|
|||||||
} else {
|
} else {
|
||||||
(None, None)
|
(None, None)
|
||||||
};
|
};
|
||||||
let (nodes, parenting) =
|
let (nodes, parenting) = index::index_hir(self.tcx, node, &bodies);
|
||||||
index::index_hir(self.tcx.sess, &*self.tcx.definitions_untracked(), node, &bodies);
|
|
||||||
let nodes = hir::OwnerNodes { opt_hash_including_bodies, nodes, bodies };
|
let nodes = hir::OwnerNodes { opt_hash_including_bodies, nodes, bodies };
|
||||||
let attrs = hir::AttributeMap { map: attrs, opt_hash: attrs_hash };
|
let attrs = hir::AttributeMap { map: attrs, opt_hash: attrs_hash };
|
||||||
|
|
||||||
|
@ -61,6 +61,9 @@
|
|||||||
|
|
||||||
mod vec;
|
mod vec;
|
||||||
|
|
||||||
|
mod freeze;
|
||||||
|
pub use freeze::{FreezeLock, FreezeReadGuard, FreezeWriteGuard};
|
||||||
|
|
||||||
mod mode {
|
mod mode {
|
||||||
use super::Ordering;
|
use super::Ordering;
|
||||||
use std::sync::atomic::AtomicU8;
|
use std::sync::atomic::AtomicU8;
|
||||||
|
108
compiler/rustc_data_structures/src/sync/freeze.rs
Normal file
108
compiler/rustc_data_structures/src/sync/freeze.rs
Normal file
@ -0,0 +1,108 @@
|
|||||||
|
use crate::sync::{AtomicBool, ReadGuard, RwLock, WriteGuard};
|
||||||
|
#[cfg(parallel_compiler)]
|
||||||
|
use crate::sync::{DynSend, DynSync};
|
||||||
|
use std::{
|
||||||
|
cell::UnsafeCell,
|
||||||
|
marker::PhantomData,
|
||||||
|
ops::{Deref, DerefMut},
|
||||||
|
sync::atomic::Ordering,
|
||||||
|
};
|
||||||
|
|
||||||
|
/// A type which allows mutation using a lock until
|
||||||
|
/// the value is frozen and can be accessed lock-free.
|
||||||
|
///
|
||||||
|
/// Unlike `RwLock`, it can be used to prevent mutation past a point.
|
||||||
|
#[derive(Default)]
|
||||||
|
pub struct FreezeLock<T> {
|
||||||
|
data: UnsafeCell<T>,
|
||||||
|
frozen: AtomicBool,
|
||||||
|
|
||||||
|
/// This lock protects writes to the `data` and `frozen` fields.
|
||||||
|
lock: RwLock<()>,
|
||||||
|
}
|
||||||
|
|
||||||
|
#[cfg(parallel_compiler)]
|
||||||
|
unsafe impl<T: DynSync + DynSend> DynSync for FreezeLock<T> {}
|
||||||
|
|
||||||
|
impl<T> FreezeLock<T> {
|
||||||
|
#[inline]
|
||||||
|
pub fn new(value: T) -> Self {
|
||||||
|
Self { data: UnsafeCell::new(value), frozen: AtomicBool::new(false), lock: RwLock::new(()) }
|
||||||
|
}
|
||||||
|
|
||||||
|
#[inline]
|
||||||
|
pub fn read(&self) -> FreezeReadGuard<'_, T> {
|
||||||
|
FreezeReadGuard {
|
||||||
|
_lock_guard: if self.frozen.load(Ordering::Acquire) {
|
||||||
|
None
|
||||||
|
} else {
|
||||||
|
Some(self.lock.read())
|
||||||
|
},
|
||||||
|
lock: self,
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
#[inline]
|
||||||
|
#[track_caller]
|
||||||
|
pub fn write(&self) -> FreezeWriteGuard<'_, T> {
|
||||||
|
let _lock_guard = self.lock.write();
|
||||||
|
// Use relaxed ordering since we're in the write lock.
|
||||||
|
assert!(!self.frozen.load(Ordering::Relaxed), "still mutable");
|
||||||
|
FreezeWriteGuard { _lock_guard, lock: self, marker: PhantomData }
|
||||||
|
}
|
||||||
|
|
||||||
|
#[inline]
|
||||||
|
pub fn freeze(&self) -> &T {
|
||||||
|
if !self.frozen.load(Ordering::Acquire) {
|
||||||
|
// Get the lock to ensure no concurrent writes and that we release the latest write.
|
||||||
|
let _lock = self.lock.write();
|
||||||
|
self.frozen.store(true, Ordering::Release);
|
||||||
|
}
|
||||||
|
|
||||||
|
// SAFETY: This is frozen so the data cannot be modified and shared access is sound.
|
||||||
|
unsafe { &*self.data.get() }
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
/// A guard holding shared access to a `FreezeLock` which is in a locked state or frozen.
|
||||||
|
#[must_use = "if unused the FreezeLock may immediately unlock"]
|
||||||
|
pub struct FreezeReadGuard<'a, T> {
|
||||||
|
_lock_guard: Option<ReadGuard<'a, ()>>,
|
||||||
|
lock: &'a FreezeLock<T>,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl<'a, T: 'a> Deref for FreezeReadGuard<'a, T> {
|
||||||
|
type Target = T;
|
||||||
|
#[inline]
|
||||||
|
fn deref(&self) -> &T {
|
||||||
|
// SAFETY: If `lock` is not frozen, `_lock_guard` holds the lock to the `UnsafeCell` so
|
||||||
|
// this has shared access until the `FreezeReadGuard` is dropped. If `lock` is frozen,
|
||||||
|
// the data cannot be modified and shared access is sound.
|
||||||
|
unsafe { &*self.lock.data.get() }
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
/// A guard holding mutable access to a `FreezeLock` which is in a locked state or frozen.
|
||||||
|
#[must_use = "if unused the FreezeLock may immediately unlock"]
|
||||||
|
pub struct FreezeWriteGuard<'a, T> {
|
||||||
|
_lock_guard: WriteGuard<'a, ()>,
|
||||||
|
lock: &'a FreezeLock<T>,
|
||||||
|
marker: PhantomData<&'a mut T>,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl<'a, T: 'a> Deref for FreezeWriteGuard<'a, T> {
|
||||||
|
type Target = T;
|
||||||
|
#[inline]
|
||||||
|
fn deref(&self) -> &T {
|
||||||
|
// SAFETY: `self._lock_guard` holds the lock to the `UnsafeCell` so this has shared access.
|
||||||
|
unsafe { &*self.lock.data.get() }
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl<'a, T: 'a> DerefMut for FreezeWriteGuard<'a, T> {
|
||||||
|
#[inline]
|
||||||
|
fn deref_mut(&mut self) -> &mut T {
|
||||||
|
// SAFETY: `self._lock_guard` holds the lock to the `UnsafeCell` so this has mutable access.
|
||||||
|
unsafe { &mut *self.lock.data.get() }
|
||||||
|
}
|
||||||
|
}
|
@ -237,6 +237,10 @@ pub fn check_crate(tcx: TyCtxt<'_>) -> Result<(), ErrorGuaranteed> {
|
|||||||
tcx.hir().for_each_module(|module| tcx.ensure().check_mod_item_types(module))
|
tcx.hir().for_each_module(|module| tcx.ensure().check_mod_item_types(module))
|
||||||
});
|
});
|
||||||
|
|
||||||
|
// Freeze definitions as we don't add new ones at this point. This improves performance by
|
||||||
|
// allowing lock-free access to them.
|
||||||
|
tcx.untracked().definitions.freeze();
|
||||||
|
|
||||||
// FIXME: Remove this when we implement creating `DefId`s
|
// FIXME: Remove this when we implement creating `DefId`s
|
||||||
// for anon constants during their parents' typeck.
|
// for anon constants during their parents' typeck.
|
||||||
// Typeck all body owners in parallel will produce queries
|
// Typeck all body owners in parallel will produce queries
|
||||||
|
@ -7,7 +7,9 @@
|
|||||||
use rustc_codegen_ssa::CodegenResults;
|
use rustc_codegen_ssa::CodegenResults;
|
||||||
use rustc_data_structures::steal::Steal;
|
use rustc_data_structures::steal::Steal;
|
||||||
use rustc_data_structures::svh::Svh;
|
use rustc_data_structures::svh::Svh;
|
||||||
use rustc_data_structures::sync::{AppendOnlyIndexVec, Lrc, OnceLock, RwLock, WorkerLocal};
|
use rustc_data_structures::sync::{
|
||||||
|
AppendOnlyIndexVec, FreezeLock, Lrc, OnceLock, RwLock, WorkerLocal,
|
||||||
|
};
|
||||||
use rustc_hir::def_id::{StableCrateId, CRATE_DEF_ID, LOCAL_CRATE};
|
use rustc_hir::def_id::{StableCrateId, CRATE_DEF_ID, LOCAL_CRATE};
|
||||||
use rustc_hir::definitions::Definitions;
|
use rustc_hir::definitions::Definitions;
|
||||||
use rustc_incremental::DepGraphFuture;
|
use rustc_incremental::DepGraphFuture;
|
||||||
@ -197,7 +199,7 @@ pub fn global_ctxt(&'tcx self) -> Result<QueryResult<'_, &'tcx GlobalCtxt<'tcx>>
|
|||||||
self.codegen_backend().metadata_loader(),
|
self.codegen_backend().metadata_loader(),
|
||||||
stable_crate_id,
|
stable_crate_id,
|
||||||
)) as _);
|
)) as _);
|
||||||
let definitions = RwLock::new(Definitions::new(stable_crate_id));
|
let definitions = FreezeLock::new(Definitions::new(stable_crate_id));
|
||||||
let source_span = AppendOnlyIndexVec::new();
|
let source_span = AppendOnlyIndexVec::new();
|
||||||
let _id = source_span.push(krate.spans.inner_span);
|
let _id = source_span.push(krate.spans.inner_span);
|
||||||
debug_assert_eq!(_id, CRATE_DEF_ID);
|
debug_assert_eq!(_id, CRATE_DEF_ID);
|
||||||
|
@ -1207,7 +1207,7 @@ pub(super) fn crate_hash(tcx: TyCtxt<'_>, _: LocalCrate) -> Svh {
|
|||||||
source_file_names.hash_stable(&mut hcx, &mut stable_hasher);
|
source_file_names.hash_stable(&mut hcx, &mut stable_hasher);
|
||||||
debugger_visualizers.hash_stable(&mut hcx, &mut stable_hasher);
|
debugger_visualizers.hash_stable(&mut hcx, &mut stable_hasher);
|
||||||
if tcx.sess.opts.incremental_relative_spans() {
|
if tcx.sess.opts.incremental_relative_spans() {
|
||||||
let definitions = tcx.definitions_untracked();
|
let definitions = tcx.untracked().definitions.freeze();
|
||||||
let mut owner_spans: Vec<_> = krate
|
let mut owner_spans: Vec<_> = krate
|
||||||
.owners
|
.owners
|
||||||
.iter_enumerated()
|
.iter_enumerated()
|
||||||
|
@ -39,7 +39,9 @@
|
|||||||
use rustc_data_structures::sharded::{IntoPointer, ShardedHashMap};
|
use rustc_data_structures::sharded::{IntoPointer, ShardedHashMap};
|
||||||
use rustc_data_structures::stable_hasher::{HashStable, StableHasher};
|
use rustc_data_structures::stable_hasher::{HashStable, StableHasher};
|
||||||
use rustc_data_structures::steal::Steal;
|
use rustc_data_structures::steal::Steal;
|
||||||
use rustc_data_structures::sync::{self, Lock, Lrc, MappedReadGuard, ReadGuard, WorkerLocal};
|
use rustc_data_structures::sync::{
|
||||||
|
self, FreezeReadGuard, Lock, Lrc, MappedReadGuard, ReadGuard, WorkerLocal,
|
||||||
|
};
|
||||||
use rustc_data_structures::unord::UnordSet;
|
use rustc_data_structures::unord::UnordSet;
|
||||||
use rustc_errors::{
|
use rustc_errors::{
|
||||||
DecorateLint, DiagnosticBuilder, DiagnosticMessage, ErrorGuaranteed, MultiSpan,
|
DecorateLint, DiagnosticBuilder, DiagnosticMessage, ErrorGuaranteed, MultiSpan,
|
||||||
@ -964,8 +966,8 @@ pub fn iter_local_def_id(self) -> impl Iterator<Item = LocalDefId> + 'tcx {
|
|||||||
i += 1;
|
i += 1;
|
||||||
}
|
}
|
||||||
|
|
||||||
// Leak a read lock once we finish iterating on definitions, to prevent adding new ones.
|
// Freeze definitions once we finish iterating on them, to prevent adding new ones.
|
||||||
definitions.leak();
|
definitions.freeze();
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -974,10 +976,9 @@ pub fn def_path_table(self) -> &'tcx rustc_hir::definitions::DefPathTable {
|
|||||||
// definitions change.
|
// definitions change.
|
||||||
self.dep_graph.read_index(DepNodeIndex::FOREVER_RED_NODE);
|
self.dep_graph.read_index(DepNodeIndex::FOREVER_RED_NODE);
|
||||||
|
|
||||||
// Leak a read lock once we start iterating on definitions, to prevent adding new ones
|
// Freeze definitions once we start iterating on them, to prevent adding new ones
|
||||||
// while iterating. If some query needs to add definitions, it should be `ensure`d above.
|
// while iterating. If some query needs to add definitions, it should be `ensure`d above.
|
||||||
let definitions = self.untracked.definitions.leak();
|
self.untracked.definitions.freeze().def_path_table()
|
||||||
definitions.def_path_table()
|
|
||||||
}
|
}
|
||||||
|
|
||||||
pub fn def_path_hash_to_def_index_map(
|
pub fn def_path_hash_to_def_index_map(
|
||||||
@ -986,10 +987,9 @@ pub fn def_path_hash_to_def_index_map(
|
|||||||
// Create a dependency to the crate to be sure we re-execute this when the amount of
|
// Create a dependency to the crate to be sure we re-execute this when the amount of
|
||||||
// definitions change.
|
// definitions change.
|
||||||
self.ensure().hir_crate(());
|
self.ensure().hir_crate(());
|
||||||
// Leak a read lock once we start iterating on definitions, to prevent adding new ones
|
// Freeze definitions once we start iterating on them, to prevent adding new ones
|
||||||
// while iterating. If some query needs to add definitions, it should be `ensure`d above.
|
// while iterating. If some query needs to add definitions, it should be `ensure`d above.
|
||||||
let definitions = self.untracked.definitions.leak();
|
self.untracked.definitions.freeze().def_path_hash_to_def_index_map()
|
||||||
definitions.def_path_hash_to_def_index_map()
|
|
||||||
}
|
}
|
||||||
|
|
||||||
/// Note that this is *untracked* and should only be used within the query
|
/// Note that this is *untracked* and should only be used within the query
|
||||||
@ -1006,7 +1006,7 @@ pub fn untracked(self) -> &'tcx Untracked {
|
|||||||
/// Note that this is *untracked* and should only be used within the query
|
/// Note that this is *untracked* and should only be used within the query
|
||||||
/// system if the result is otherwise tracked through queries
|
/// system if the result is otherwise tracked through queries
|
||||||
#[inline]
|
#[inline]
|
||||||
pub fn definitions_untracked(self) -> ReadGuard<'tcx, Definitions> {
|
pub fn definitions_untracked(self) -> FreezeReadGuard<'tcx, Definitions> {
|
||||||
self.untracked.definitions.read()
|
self.untracked.definitions.read()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -7,7 +7,7 @@
|
|||||||
use crate::Session;
|
use crate::Session;
|
||||||
use rustc_ast as ast;
|
use rustc_ast as ast;
|
||||||
use rustc_data_structures::owned_slice::OwnedSlice;
|
use rustc_data_structures::owned_slice::OwnedSlice;
|
||||||
use rustc_data_structures::sync::{self, AppendOnlyIndexVec, RwLock};
|
use rustc_data_structures::sync::{self, AppendOnlyIndexVec, FreezeLock, RwLock};
|
||||||
use rustc_hir::def_id::{CrateNum, DefId, LocalDefId, StableCrateId, LOCAL_CRATE};
|
use rustc_hir::def_id::{CrateNum, DefId, LocalDefId, StableCrateId, LOCAL_CRATE};
|
||||||
use rustc_hir::definitions::{DefKey, DefPath, DefPathHash, Definitions};
|
use rustc_hir::definitions::{DefKey, DefPath, DefPathHash, Definitions};
|
||||||
use rustc_span::hygiene::{ExpnHash, ExpnId};
|
use rustc_span::hygiene::{ExpnHash, ExpnId};
|
||||||
@ -261,5 +261,5 @@ pub struct Untracked {
|
|||||||
pub cstore: RwLock<Box<CrateStoreDyn>>,
|
pub cstore: RwLock<Box<CrateStoreDyn>>,
|
||||||
/// Reference span for definitions.
|
/// Reference span for definitions.
|
||||||
pub source_span: AppendOnlyIndexVec<LocalDefId, Span>,
|
pub source_span: AppendOnlyIndexVec<LocalDefId, Span>,
|
||||||
pub definitions: RwLock<Definitions>,
|
pub definitions: FreezeLock<Definitions>,
|
||||||
}
|
}
|
||||||
|
Loading…
Reference in New Issue
Block a user