]> git.lizzy.rs Git - rust.git/blob - src/thread.rs
Auto merge of #2430 - RalfJung:no-global-wrapper, r=RalfJung
[rust.git] / src / thread.rs
1 //! Implements threads.
2
3 use std::cell::RefCell;
4 use std::collections::hash_map::Entry;
5 use std::num::TryFromIntError;
6 use std::time::{Duration, Instant, SystemTime};
7
8 use log::trace;
9
10 use rustc_data_structures::fx::FxHashMap;
11 use rustc_hir::def_id::DefId;
12 use rustc_index::vec::{Idx, IndexVec};
13 use rustc_middle::mir::Mutability;
14
15 use crate::concurrency::data_race;
16 use crate::sync::SynchronizationState;
17 use crate::*;
18
19 #[derive(Clone, Copy, Debug, PartialEq, Eq)]
20 pub enum SchedulingAction {
21     /// Execute step on the active thread.
22     ExecuteStep,
23     /// Execute a timeout callback.
24     ExecuteTimeoutCallback,
25     /// Execute destructors of the active thread.
26     ExecuteDtors,
27     /// Stop the program.
28     Stop,
29 }
30
31 /// Timeout callbacks can be created by synchronization primitives to tell the
32 /// scheduler that they should be called once some period of time passes.
33 type TimeoutCallback<'mir, 'tcx> =
34     Box<dyn FnOnce(&mut InterpCx<'mir, 'tcx, Evaluator<'mir, 'tcx>>) -> InterpResult<'tcx> + 'tcx>;
35
36 /// A thread identifier.
37 #[derive(Clone, Copy, Debug, PartialOrd, Ord, PartialEq, Eq, Hash)]
38 pub struct ThreadId(u32);
39
40 /// The main thread. When it terminates, the whole application terminates.
41 const MAIN_THREAD: ThreadId = ThreadId(0);
42
43 impl ThreadId {
44     pub fn to_u32(self) -> u32 {
45         self.0
46     }
47 }
48
49 impl Idx for ThreadId {
50     fn new(idx: usize) -> Self {
51         ThreadId(u32::try_from(idx).unwrap())
52     }
53
54     fn index(self) -> usize {
55         usize::try_from(self.0).unwrap()
56     }
57 }
58
59 impl TryFrom<u64> for ThreadId {
60     type Error = TryFromIntError;
61     fn try_from(id: u64) -> Result<Self, Self::Error> {
62         u32::try_from(id).map(Self)
63     }
64 }
65
66 impl From<u32> for ThreadId {
67     fn from(id: u32) -> Self {
68         Self(id)
69     }
70 }
71
72 impl ThreadId {
73     pub fn to_u32_scalar(&self) -> Scalar<Provenance> {
74         Scalar::from_u32(self.0)
75     }
76 }
77
78 /// The state of a thread.
79 #[derive(Debug, Copy, Clone, PartialEq, Eq)]
80 pub enum ThreadState {
81     /// The thread is enabled and can be executed.
82     Enabled,
83     /// The thread tried to join the specified thread and is blocked until that
84     /// thread terminates.
85     BlockedOnJoin(ThreadId),
86     /// The thread is blocked on some synchronization primitive. It is the
87     /// responsibility of the synchronization primitives to track threads that
88     /// are blocked by them.
89     BlockedOnSync,
90     /// The thread has terminated its execution. We do not delete terminated
91     /// threads (FIXME: why?).
92     Terminated,
93 }
94
95 /// The join status of a thread.
96 #[derive(Debug, Copy, Clone, PartialEq, Eq)]
97 enum ThreadJoinStatus {
98     /// The thread can be joined.
99     Joinable,
100     /// A thread is detached if its join handle was destroyed and no other
101     /// thread can join it.
102     Detached,
103     /// The thread was already joined by some thread and cannot be joined again.
104     Joined,
105 }
106
107 /// A thread.
108 pub struct Thread<'mir, 'tcx> {
109     state: ThreadState,
110
111     /// Name of the thread.
112     thread_name: Option<Vec<u8>>,
113
114     /// The virtual call stack.
115     stack: Vec<Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>>,
116
117     /// The join status.
118     join_status: ThreadJoinStatus,
119
120     /// The temporary used for storing the argument of
121     /// the call to `miri_start_panic` (the panic payload) when unwinding.
122     /// This is pointer-sized, and matches the `Payload` type in `src/libpanic_unwind/miri.rs`.
123     pub(crate) panic_payload: Option<Scalar<Provenance>>,
124
125     /// Last OS error location in memory. It is a 32-bit integer.
126     pub(crate) last_error: Option<MPlaceTy<'tcx, Provenance>>,
127 }
128
129 impl<'mir, 'tcx> Thread<'mir, 'tcx> {
130     /// Check if the thread is done executing (no more stack frames). If yes,
131     /// change the state to terminated and return `true`.
132     fn check_terminated(&mut self) -> bool {
133         if self.state == ThreadState::Enabled {
134             if self.stack.is_empty() {
135                 self.state = ThreadState::Terminated;
136                 return true;
137             }
138         }
139         false
140     }
141
142     /// Get the name of the current thread, or `<unnamed>` if it was not set.
143     fn thread_name(&self) -> &[u8] {
144         if let Some(ref thread_name) = self.thread_name { thread_name } else { b"<unnamed>" }
145     }
146 }
147
148 impl<'mir, 'tcx> std::fmt::Debug for Thread<'mir, 'tcx> {
149     fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
150         write!(
151             f,
152             "{}({:?}, {:?})",
153             String::from_utf8_lossy(self.thread_name()),
154             self.state,
155             self.join_status
156         )
157     }
158 }
159
160 impl<'mir, 'tcx> Default for Thread<'mir, 'tcx> {
161     fn default() -> Self {
162         Self {
163             state: ThreadState::Enabled,
164             thread_name: None,
165             stack: Vec::new(),
166             join_status: ThreadJoinStatus::Joinable,
167             panic_payload: None,
168             last_error: None,
169         }
170     }
171 }
172
173 impl<'mir, 'tcx> Thread<'mir, 'tcx> {
174     fn new(name: &str) -> Self {
175         let mut thread = Thread::default();
176         thread.thread_name = Some(Vec::from(name.as_bytes()));
177         thread
178     }
179 }
180
181 /// A specific moment in time.
182 #[derive(Debug)]
183 pub enum Time {
184     Monotonic(Instant),
185     RealTime(SystemTime),
186 }
187
188 impl Time {
189     /// How long do we have to wait from now until the specified time?
190     fn get_wait_time(&self) -> Duration {
191         match self {
192             Time::Monotonic(instant) => instant.saturating_duration_since(Instant::now()),
193             Time::RealTime(time) =>
194                 time.duration_since(SystemTime::now()).unwrap_or(Duration::new(0, 0)),
195         }
196     }
197 }
198
199 /// Callbacks are used to implement timeouts. For example, waiting on a
200 /// conditional variable with a timeout creates a callback that is called after
201 /// the specified time and unblocks the thread. If another thread signals on the
202 /// conditional variable, the signal handler deletes the callback.
203 struct TimeoutCallbackInfo<'mir, 'tcx> {
204     /// The callback should be called no earlier than this time.
205     call_time: Time,
206     /// The called function.
207     callback: TimeoutCallback<'mir, 'tcx>,
208 }
209
210 impl<'mir, 'tcx> std::fmt::Debug for TimeoutCallbackInfo<'mir, 'tcx> {
211     fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
212         write!(f, "TimeoutCallback({:?})", self.call_time)
213     }
214 }
215
216 /// A set of threads.
217 #[derive(Debug)]
218 pub struct ThreadManager<'mir, 'tcx> {
219     /// Identifier of the currently active thread.
220     active_thread: ThreadId,
221     /// Threads used in the program.
222     ///
223     /// Note that this vector also contains terminated threads.
224     threads: IndexVec<ThreadId, Thread<'mir, 'tcx>>,
225     /// This field is pub(crate) because the synchronization primitives
226     /// (`crate::sync`) need a way to access it.
227     pub(crate) sync: SynchronizationState,
228     /// A mapping from a thread-local static to an allocation id of a thread
229     /// specific allocation.
230     thread_local_alloc_ids: RefCell<FxHashMap<(DefId, ThreadId), Pointer<Provenance>>>,
231     /// A flag that indicates that we should change the active thread.
232     yield_active_thread: bool,
233     /// Callbacks that are called once the specified time passes.
234     timeout_callbacks: FxHashMap<ThreadId, TimeoutCallbackInfo<'mir, 'tcx>>,
235 }
236
237 impl<'mir, 'tcx> Default for ThreadManager<'mir, 'tcx> {
238     fn default() -> Self {
239         let mut threads = IndexVec::new();
240         // Create the main thread and add it to the list of threads.
241         let mut main_thread = Thread::new("main");
242         // The main thread can *not* be joined on.
243         main_thread.join_status = ThreadJoinStatus::Detached;
244         threads.push(main_thread);
245         Self {
246             active_thread: ThreadId::new(0),
247             threads,
248             sync: SynchronizationState::default(),
249             thread_local_alloc_ids: Default::default(),
250             yield_active_thread: false,
251             timeout_callbacks: FxHashMap::default(),
252         }
253     }
254 }
255
256 impl<'mir, 'tcx: 'mir> ThreadManager<'mir, 'tcx> {
257     /// Check if we have an allocation for the given thread local static for the
258     /// active thread.
259     fn get_thread_local_alloc_id(&self, def_id: DefId) -> Option<Pointer<Provenance>> {
260         self.thread_local_alloc_ids.borrow().get(&(def_id, self.active_thread)).cloned()
261     }
262
263     /// Set the pointer for the allocation of the given thread local
264     /// static for the active thread.
265     ///
266     /// Panics if a thread local is initialized twice for the same thread.
267     fn set_thread_local_alloc(&self, def_id: DefId, ptr: Pointer<Provenance>) {
268         self.thread_local_alloc_ids
269             .borrow_mut()
270             .try_insert((def_id, self.active_thread), ptr)
271             .unwrap();
272     }
273
274     /// Borrow the stack of the active thread.
275     pub fn active_thread_stack(&self) -> &[Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>] {
276         &self.threads[self.active_thread].stack
277     }
278
279     /// Mutably borrow the stack of the active thread.
280     fn active_thread_stack_mut(
281         &mut self,
282     ) -> &mut Vec<Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>> {
283         &mut self.threads[self.active_thread].stack
284     }
285
286     pub fn all_stacks(
287         &self,
288     ) -> impl Iterator<Item = &[Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>]> {
289         self.threads.iter().map(|t| &t.stack[..])
290     }
291
292     /// Create a new thread and returns its id.
293     fn create_thread(&mut self) -> ThreadId {
294         let new_thread_id = ThreadId::new(self.threads.len());
295         self.threads.push(Default::default());
296         new_thread_id
297     }
298
299     /// Set an active thread and return the id of the thread that was active before.
300     fn set_active_thread_id(&mut self, id: ThreadId) -> ThreadId {
301         let active_thread_id = self.active_thread;
302         self.active_thread = id;
303         assert!(self.active_thread.index() < self.threads.len());
304         active_thread_id
305     }
306
307     /// Get the id of the currently active thread.
308     pub fn get_active_thread_id(&self) -> ThreadId {
309         self.active_thread
310     }
311
312     /// Get the total number of threads that were ever spawn by this program.
313     pub fn get_total_thread_count(&self) -> usize {
314         self.threads.len()
315     }
316
317     /// Get the total of threads that are currently live, i.e., not yet terminated.
318     /// (They might be blocked.)
319     pub fn get_live_thread_count(&self) -> usize {
320         self.threads.iter().filter(|t| !matches!(t.state, ThreadState::Terminated)).count()
321     }
322
323     /// Has the given thread terminated?
324     fn has_terminated(&self, thread_id: ThreadId) -> bool {
325         self.threads[thread_id].state == ThreadState::Terminated
326     }
327
328     /// Have all threads terminated?
329     fn have_all_terminated(&self) -> bool {
330         self.threads.iter().all(|thread| thread.state == ThreadState::Terminated)
331     }
332
333     /// Enable the thread for execution. The thread must be terminated.
334     fn enable_thread(&mut self, thread_id: ThreadId) {
335         assert!(self.has_terminated(thread_id));
336         self.threads[thread_id].state = ThreadState::Enabled;
337     }
338
339     /// Get a mutable borrow of the currently active thread.
340     fn active_thread_mut(&mut self) -> &mut Thread<'mir, 'tcx> {
341         &mut self.threads[self.active_thread]
342     }
343
344     /// Get a shared borrow of the currently active thread.
345     fn active_thread_ref(&self) -> &Thread<'mir, 'tcx> {
346         &self.threads[self.active_thread]
347     }
348
349     /// Mark the thread as detached, which means that no other thread will try
350     /// to join it and the thread is responsible for cleaning up.
351     fn detach_thread(&mut self, id: ThreadId) -> InterpResult<'tcx> {
352         if self.threads[id].join_status != ThreadJoinStatus::Joinable {
353             throw_ub_format!("trying to detach thread that was already detached or joined");
354         }
355         self.threads[id].join_status = ThreadJoinStatus::Detached;
356         Ok(())
357     }
358
359     /// Mark that the active thread tries to join the thread with `joined_thread_id`.
360     fn join_thread(
361         &mut self,
362         joined_thread_id: ThreadId,
363         data_race: Option<&mut data_race::GlobalState>,
364     ) -> InterpResult<'tcx> {
365         if self.threads[joined_thread_id].join_status != ThreadJoinStatus::Joinable {
366             throw_ub_format!("trying to join a detached or already joined thread");
367         }
368         if joined_thread_id == self.active_thread {
369             throw_ub_format!("trying to join itself");
370         }
371         assert!(
372             self.threads
373                 .iter()
374                 .all(|thread| thread.state != ThreadState::BlockedOnJoin(joined_thread_id)),
375             "a joinable thread already has threads waiting for its termination"
376         );
377         // Mark the joined thread as being joined so that we detect if other
378         // threads try to join it.
379         self.threads[joined_thread_id].join_status = ThreadJoinStatus::Joined;
380         if self.threads[joined_thread_id].state != ThreadState::Terminated {
381             // The joined thread is still running, we need to wait for it.
382             self.active_thread_mut().state = ThreadState::BlockedOnJoin(joined_thread_id);
383             trace!(
384                 "{:?} blocked on {:?} when trying to join",
385                 self.active_thread,
386                 joined_thread_id
387             );
388         } else {
389             // The thread has already terminated - mark join happens-before
390             if let Some(data_race) = data_race {
391                 data_race.thread_joined(self, self.active_thread, joined_thread_id);
392             }
393         }
394         Ok(())
395     }
396
397     /// Set the name of the active thread.
398     fn set_active_thread_name(&mut self, new_thread_name: Vec<u8>) {
399         self.active_thread_mut().thread_name = Some(new_thread_name);
400     }
401
402     /// Get the name of the active thread.
403     pub fn get_active_thread_name(&self) -> &[u8] {
404         self.active_thread_ref().thread_name()
405     }
406
407     /// Get the name of the given thread.
408     pub fn get_thread_name(&self, thread: ThreadId) -> &[u8] {
409         self.threads[thread].thread_name()
410     }
411
412     /// Put the thread into the blocked state.
413     fn block_thread(&mut self, thread: ThreadId) {
414         let state = &mut self.threads[thread].state;
415         assert_eq!(*state, ThreadState::Enabled);
416         *state = ThreadState::BlockedOnSync;
417     }
418
419     /// Put the blocked thread into the enabled state.
420     fn unblock_thread(&mut self, thread: ThreadId) {
421         let state = &mut self.threads[thread].state;
422         assert_eq!(*state, ThreadState::BlockedOnSync);
423         *state = ThreadState::Enabled;
424     }
425
426     /// Change the active thread to some enabled thread.
427     fn yield_active_thread(&mut self) {
428         // We do not yield immediately, as swapping out the current stack while executing a MIR statement
429         // could lead to all sorts of confusion.
430         // We should only switch stacks between steps.
431         self.yield_active_thread = true;
432     }
433
434     /// Register the given `callback` to be called once the `call_time` passes.
435     ///
436     /// The callback will be called with `thread` being the active thread, and
437     /// the callback may not change the active thread.
438     fn register_timeout_callback(
439         &mut self,
440         thread: ThreadId,
441         call_time: Time,
442         callback: TimeoutCallback<'mir, 'tcx>,
443     ) {
444         self.timeout_callbacks
445             .try_insert(thread, TimeoutCallbackInfo { call_time, callback })
446             .unwrap();
447     }
448
449     /// Unregister the callback for the `thread`.
450     fn unregister_timeout_callback_if_exists(&mut self, thread: ThreadId) {
451         self.timeout_callbacks.remove(&thread);
452     }
453
454     /// Get a callback that is ready to be called.
455     fn get_ready_callback(&mut self) -> Option<(ThreadId, TimeoutCallback<'mir, 'tcx>)> {
456         // We iterate over all threads in the order of their indices because
457         // this allows us to have a deterministic scheduler.
458         for thread in self.threads.indices() {
459             match self.timeout_callbacks.entry(thread) {
460                 Entry::Occupied(entry) =>
461                     if entry.get().call_time.get_wait_time() == Duration::new(0, 0) {
462                         return Some((thread, entry.remove().callback));
463                     },
464                 Entry::Vacant(_) => {}
465             }
466         }
467         None
468     }
469
470     /// Wakes up threads joining on the active one and deallocates thread-local statics.
471     /// The `AllocId` that can now be freed are returned.
472     fn thread_terminated(
473         &mut self,
474         mut data_race: Option<&mut data_race::GlobalState>,
475     ) -> Vec<Pointer<Provenance>> {
476         let mut free_tls_statics = Vec::new();
477         {
478             let mut thread_local_statics = self.thread_local_alloc_ids.borrow_mut();
479             thread_local_statics.retain(|&(_def_id, thread), &mut alloc_id| {
480                 if thread != self.active_thread {
481                     // Keep this static around.
482                     return true;
483                 }
484                 // Delete this static from the map and from memory.
485                 // We cannot free directly here as we cannot use `?` in this context.
486                 free_tls_statics.push(alloc_id);
487                 false
488             });
489         }
490         // Set the thread into a terminated state in the data-race detector.
491         if let Some(ref mut data_race) = data_race {
492             data_race.thread_terminated(self);
493         }
494         // Check if we need to unblock any threads.
495         let mut joined_threads = vec![]; // store which threads joined, we'll need it
496         for (i, thread) in self.threads.iter_enumerated_mut() {
497             if thread.state == ThreadState::BlockedOnJoin(self.active_thread) {
498                 // The thread has terminated, mark happens-before edge to joining thread
499                 if data_race.is_some() {
500                     joined_threads.push(i);
501                 }
502                 trace!("unblocking {:?} because {:?} terminated", i, self.active_thread);
503                 thread.state = ThreadState::Enabled;
504             }
505         }
506         for &i in &joined_threads {
507             data_race.as_mut().unwrap().thread_joined(self, i, self.active_thread);
508         }
509         free_tls_statics
510     }
511
512     /// Decide which action to take next and on which thread.
513     ///
514     /// The currently implemented scheduling policy is the one that is commonly
515     /// used in stateless model checkers such as Loom: run the active thread as
516     /// long as we can and switch only when we have to (the active thread was
517     /// blocked, terminated, or has explicitly asked to be preempted).
518     fn schedule(&mut self) -> InterpResult<'tcx, SchedulingAction> {
519         // Check whether the thread has **just** terminated (`check_terminated`
520         // checks whether the thread has popped all its stack and if yes, sets
521         // the thread state to terminated).
522         if self.threads[self.active_thread].check_terminated() {
523             return Ok(SchedulingAction::ExecuteDtors);
524         }
525         // If we get here again and the thread is *still* terminated, there are no more dtors to run.
526         if self.threads[MAIN_THREAD].state == ThreadState::Terminated {
527             // The main thread terminated; stop the program.
528             // We do *not* run TLS dtors of remaining threads, which seems to match rustc behavior.
529             return Ok(SchedulingAction::Stop);
530         }
531         // This thread and the program can keep going.
532         if self.threads[self.active_thread].state == ThreadState::Enabled
533             && !self.yield_active_thread
534         {
535             // The currently active thread is still enabled, just continue with it.
536             return Ok(SchedulingAction::ExecuteStep);
537         }
538         // The active thread yielded. Let's see if there are any timeouts to take care of. We do
539         // this *before* running any other thread, to ensure that timeouts "in the past" fire before
540         // any other thread can take an action. This ensures that for `pthread_cond_timedwait`, "an
541         // error is returned if [...] the absolute time specified by abstime has already been passed
542         // at the time of the call".
543         // <https://pubs.opengroup.org/onlinepubs/9699919799/functions/pthread_cond_timedwait.html>
544         let potential_sleep_time =
545             self.timeout_callbacks.values().map(|info| info.call_time.get_wait_time()).min();
546         if potential_sleep_time == Some(Duration::new(0, 0)) {
547             return Ok(SchedulingAction::ExecuteTimeoutCallback);
548         }
549         // No callbacks scheduled, pick a regular thread to execute.
550         // The active thread blocked or yielded. So we go search for another enabled thread.
551         // Curcially, we start searching at the current active thread ID, rather than at 0, since we
552         // want to avoid always scheduling threads 0 and 1 without ever making progress in thread 2.
553         //
554         // `skip(N)` means we start iterating at thread N, so we skip 1 more to start just *after*
555         // the active thread. Then after that we look at `take(N)`, i.e., the threads *before* the
556         // active thread.
557         let threads = self
558             .threads
559             .iter_enumerated()
560             .skip(self.active_thread.index() + 1)
561             .chain(self.threads.iter_enumerated().take(self.active_thread.index()));
562         for (id, thread) in threads {
563             debug_assert_ne!(self.active_thread, id);
564             if thread.state == ThreadState::Enabled {
565                 self.active_thread = id;
566                 break;
567             }
568         }
569         self.yield_active_thread = false;
570         if self.threads[self.active_thread].state == ThreadState::Enabled {
571             return Ok(SchedulingAction::ExecuteStep);
572         }
573         // We have not found a thread to execute.
574         if self.threads.iter().all(|thread| thread.state == ThreadState::Terminated) {
575             unreachable!("all threads terminated without the main thread terminating?!");
576         } else if let Some(sleep_time) = potential_sleep_time {
577             // All threads are currently blocked, but we have unexecuted
578             // timeout_callbacks, which may unblock some of the threads. Hence,
579             // sleep until the first callback.
580             std::thread::sleep(sleep_time);
581             Ok(SchedulingAction::ExecuteTimeoutCallback)
582         } else {
583             throw_machine_stop!(TerminationInfo::Deadlock);
584         }
585     }
586 }
587
588 // Public interface to thread management.
589 impl<'mir, 'tcx: 'mir> EvalContextExt<'mir, 'tcx> for crate::MiriEvalContext<'mir, 'tcx> {}
590 pub trait EvalContextExt<'mir, 'tcx: 'mir>: crate::MiriEvalContextExt<'mir, 'tcx> {
591     /// Get a thread-specific allocation id for the given thread-local static.
592     /// If needed, allocate a new one.
593     fn get_or_create_thread_local_alloc(
594         &mut self,
595         def_id: DefId,
596     ) -> InterpResult<'tcx, Pointer<Provenance>> {
597         let this = self.eval_context_mut();
598         let tcx = this.tcx;
599         if let Some(old_alloc) = this.machine.threads.get_thread_local_alloc_id(def_id) {
600             // We already have a thread-specific allocation id for this
601             // thread-local static.
602             Ok(old_alloc)
603         } else {
604             // We need to allocate a thread-specific allocation id for this
605             // thread-local static.
606             // First, we compute the initial value for this static.
607             if tcx.is_foreign_item(def_id) {
608                 throw_unsup_format!("foreign thread-local statics are not supported");
609             }
610             let allocation = tcx.eval_static_initializer(def_id)?;
611             let mut allocation = allocation.inner().clone();
612             // This allocation will be deallocated when the thread dies, so it is not in read-only memory.
613             allocation.mutability = Mutability::Mut;
614             // Create a fresh allocation with this content.
615             let new_alloc = this.allocate_raw_ptr(allocation, MiriMemoryKind::Tls.into())?;
616             this.machine.threads.set_thread_local_alloc(def_id, new_alloc);
617             Ok(new_alloc)
618         }
619     }
620
621     #[inline]
622     fn create_thread(&mut self) -> ThreadId {
623         let this = self.eval_context_mut();
624         let id = this.machine.threads.create_thread();
625         if let Some(data_race) = &mut this.machine.data_race {
626             data_race.thread_created(&this.machine.threads, id);
627         }
628         id
629     }
630
631     #[inline]
632     fn detach_thread(&mut self, thread_id: ThreadId) -> InterpResult<'tcx> {
633         let this = self.eval_context_mut();
634         this.machine.threads.detach_thread(thread_id)
635     }
636
637     #[inline]
638     fn join_thread(&mut self, joined_thread_id: ThreadId) -> InterpResult<'tcx> {
639         let this = self.eval_context_mut();
640         this.machine.threads.join_thread(joined_thread_id, this.machine.data_race.as_mut())?;
641         Ok(())
642     }
643
644     #[inline]
645     fn set_active_thread(&mut self, thread_id: ThreadId) -> ThreadId {
646         let this = self.eval_context_mut();
647         this.machine.threads.set_active_thread_id(thread_id)
648     }
649
650     #[inline]
651     fn get_active_thread(&self) -> ThreadId {
652         let this = self.eval_context_ref();
653         this.machine.threads.get_active_thread_id()
654     }
655
656     #[inline]
657     fn active_thread_mut(&mut self) -> &mut Thread<'mir, 'tcx> {
658         let this = self.eval_context_mut();
659         this.machine.threads.active_thread_mut()
660     }
661
662     #[inline]
663     fn active_thread_ref(&self) -> &Thread<'mir, 'tcx> {
664         let this = self.eval_context_ref();
665         this.machine.threads.active_thread_ref()
666     }
667
668     #[inline]
669     fn get_total_thread_count(&self) -> usize {
670         let this = self.eval_context_ref();
671         this.machine.threads.get_total_thread_count()
672     }
673
674     #[inline]
675     fn has_terminated(&self, thread_id: ThreadId) -> bool {
676         let this = self.eval_context_ref();
677         this.machine.threads.has_terminated(thread_id)
678     }
679
680     #[inline]
681     fn have_all_terminated(&self) -> bool {
682         let this = self.eval_context_ref();
683         this.machine.threads.have_all_terminated()
684     }
685
686     #[inline]
687     fn enable_thread(&mut self, thread_id: ThreadId) {
688         let this = self.eval_context_mut();
689         this.machine.threads.enable_thread(thread_id);
690     }
691
692     #[inline]
693     fn active_thread_stack(&self) -> &[Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>] {
694         let this = self.eval_context_ref();
695         this.machine.threads.active_thread_stack()
696     }
697
698     #[inline]
699     fn active_thread_stack_mut(
700         &mut self,
701     ) -> &mut Vec<Frame<'mir, 'tcx, Provenance, FrameData<'tcx>>> {
702         let this = self.eval_context_mut();
703         this.machine.threads.active_thread_stack_mut()
704     }
705
706     #[inline]
707     fn set_active_thread_name(&mut self, new_thread_name: Vec<u8>) {
708         let this = self.eval_context_mut();
709         this.machine.threads.set_active_thread_name(new_thread_name);
710     }
711
712     #[inline]
713     fn get_active_thread_name<'c>(&'c self) -> &'c [u8]
714     where
715         'mir: 'c,
716     {
717         let this = self.eval_context_ref();
718         this.machine.threads.get_active_thread_name()
719     }
720
721     #[inline]
722     fn block_thread(&mut self, thread: ThreadId) {
723         let this = self.eval_context_mut();
724         this.machine.threads.block_thread(thread);
725     }
726
727     #[inline]
728     fn unblock_thread(&mut self, thread: ThreadId) {
729         let this = self.eval_context_mut();
730         this.machine.threads.unblock_thread(thread);
731     }
732
733     #[inline]
734     fn yield_active_thread(&mut self) {
735         let this = self.eval_context_mut();
736         this.machine.threads.yield_active_thread();
737     }
738
739     #[inline]
740     fn maybe_preempt_active_thread(&mut self) {
741         use rand::Rng as _;
742
743         let this = self.eval_context_mut();
744         if this.machine.rng.get_mut().gen_bool(this.machine.preemption_rate) {
745             this.yield_active_thread();
746         }
747     }
748
749     #[inline]
750     fn register_timeout_callback(
751         &mut self,
752         thread: ThreadId,
753         call_time: Time,
754         callback: TimeoutCallback<'mir, 'tcx>,
755     ) {
756         let this = self.eval_context_mut();
757         this.machine.threads.register_timeout_callback(thread, call_time, callback);
758     }
759
760     #[inline]
761     fn unregister_timeout_callback_if_exists(&mut self, thread: ThreadId) {
762         let this = self.eval_context_mut();
763         this.machine.threads.unregister_timeout_callback_if_exists(thread);
764     }
765
766     /// Execute a timeout callback on the callback's thread.
767     #[inline]
768     fn run_timeout_callback(&mut self) -> InterpResult<'tcx> {
769         let this = self.eval_context_mut();
770         let (thread, callback) =
771             if let Some((thread, callback)) = this.machine.threads.get_ready_callback() {
772                 (thread, callback)
773             } else {
774                 // get_ready_callback can return None if the computer's clock
775                 // was shifted after calling the scheduler and before the call
776                 // to get_ready_callback (see issue
777                 // https://github.com/rust-lang/miri/issues/1763). In this case,
778                 // just do nothing, which effectively just returns to the
779                 // scheduler.
780                 return Ok(());
781             };
782         // This back-and-forth with `set_active_thread` is here because of two
783         // design decisions:
784         // 1. Make the caller and not the callback responsible for changing
785         //    thread.
786         // 2. Make the scheduler the only place that can change the active
787         //    thread.
788         let old_thread = this.set_active_thread(thread);
789         callback(this)?;
790         this.set_active_thread(old_thread);
791         Ok(())
792     }
793
794     /// Decide which action to take next and on which thread.
795     #[inline]
796     fn schedule(&mut self) -> InterpResult<'tcx, SchedulingAction> {
797         let this = self.eval_context_mut();
798         this.machine.threads.schedule()
799     }
800
801     /// Handles thread termination of the active thread: wakes up threads joining on this one,
802     /// and deallocated thread-local statics.
803     ///
804     /// This is called from `tls.rs` after handling the TLS dtors.
805     #[inline]
806     fn thread_terminated(&mut self) -> InterpResult<'tcx> {
807         let this = self.eval_context_mut();
808         for ptr in this.machine.threads.thread_terminated(this.machine.data_race.as_mut()) {
809             this.deallocate_ptr(ptr.into(), None, MiriMemoryKind::Tls.into())?;
810         }
811         Ok(())
812     }
813 }